Uses of Interface
org.springframework.integration.support.context.NamedComponent
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.
Root package of the Spring Integration Java DSL.
Provides core classes related to Endpoints.
Provides classes supporting inbound endpoints.
Provides classes supporting outbound endpoints.
Provides classes supporting inbound endpoints.
Base package for File support.
Base package for supporting remote files.
Provides classes supporting remote file gateways.
Provides classes supporting remote file message handlers.
Provides classes supporting the synchronization of remote and
local file directories.
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 inbound endpoints.
Provides classes for the FTP outbound channel adapter.
Provides classes supporting messaging gateways.
Provides classes related to the runtime object graph.
Provides classes for GraphQL outbound channel adapters.
Provides classes implementing various types of message handler.
Provides classes that are used to advise
MessageHandler
s with
cross-cutting concerns.Provides classes supporting inbound endpoints.
Provides classes supporting outbound endpoints.
Provides classes supporting the capture of message history.
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 inbound Spring Integration Jpa components.
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 inbound components.
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 related to messaging
using Spring
Resource
sProvides classes supporting the router pattern.
Provides classes representing inbound RSocket components.
Provides classes representing outbound RSocket components.
Provides classes supporting the Scatter-Gather pattern.
Base package for scripting support.
Provides classes supporting SFTP gateways.
Provides classes supporting inbound endpoints.
Provides classes for the SFTP outbound channel adapter.
Inbound Channel Adapters implementations for SMB protocol.
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 related to management support.
Provides global utility support classes for the runtime system.
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.
-
Uses of NamedComponent 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
This Endpoint serves as a barrier for messages that should not be processed yet.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 NamedComponent in org.springframework.integration.amqp.channel
Modifier and TypeClassDescriptionclass
The baseAbstractMessageChannel
implementation for AMQP.class
TheAbstractSubscribableAmqpChannel
implementation for one-to-one subscription over AMQP queue.class
APollableChannel
implementation that is backed by an AMQP Queue.class
TheAbstractSubscribableAmqpChannel
extension for pub-sub semantics based on theFanoutExchange
. -
Uses of NamedComponent 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.class
Adapter that receives Messages from an AMQP Queue, converts them into Spring Integration Messages, and sends the results to a Message Channel.class
A pollableMessageSource
for RabbitMQ. -
Uses of NamedComponent 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.class
MessageHandler
based onRabbitStreamOperations
. -
Uses of NamedComponent in org.springframework.integration.camel.outbound
Modifier and TypeClassDescriptionclass
AMessageHandler
for calling Apache Camel route and produce (optionally) a reply. -
Uses of NamedComponent in org.springframework.integration.cassandra.outbound
Modifier and TypeClassDescriptionclass
AnAbstractReplyProducingMessageHandler
implementation for Cassandra outbound operations. -
Uses of NamedComponent in org.springframework.integration.channel
Modifier and TypeClassDescriptionclass
TheAbstractSubscribableChannel
base implementation for those inheritors which logic may be based on theExecutor
.class
Base class forMessageChannel
implementations providing common properties such as the channel name.class
Base class for all pollable channels.class
Base implementation ofMessageChannel
that invokes the subscribedhandler(s)
by delegating to aMessageDispatcher
.class
Converts a channel to a name, retaining a reference to the channel keyed by the name.class
A channel that invokes a single subscriber for each sent Message.class
An implementation ofMessageChannel
that delegates to an instance ofUnicastingDispatcher
which in turn delegates all dispatching invocations to anExecutor
.final class
SpecializedSubscribableChannel
for a single final subscriber set up during bean instantiation (unlike otherSubscribableChannel
s where theMessageHandler
is subscribed when the endpoint is started).class
TheAbstractMessageChannel
implementation for the Reactive StreamsPublisher
based on the Project ReactorFlux
.class
A channel implementation that essentially behaves like "/dev/null".class
A message channel that prioritizes messages based on aComparator
.class
A channel that sends Messages to each of its subscribers.class
Simple implementation of a message channel.class
A zero-capacity version ofQueueChannel
that delegates to aSynchronousQueue
internally. -
Uses of NamedComponent in org.springframework.integration.codec
-
Uses of NamedComponent in org.springframework.integration.context
Modifier and TypeClassDescriptionclass
A base class that provides convenient access to the bean factory as well asTaskScheduler
andConversionService
instances. -
Uses of NamedComponent in org.springframework.integration.dsl
Modifier and TypeClassDescriptionclass
The standard implementation of theIntegrationFlow
interface instantiated by the Framework. -
Uses of NamedComponent in org.springframework.integration.endpoint
Modifier and TypeInterfaceDescriptioninterface
Message consumers implement this interface, the message handler within a consumer may or may not emit output messages.Modifier and TypeClassDescriptionclass
The base class for Message Endpoint implementations.class
A message source that can limit the number of remote objects it fetches.class
Abstract message source.class
AnAbstractEndpoint
extension for Polling Consumer pattern basics.class
Message Endpoint that connects anyMessageHandler
implementation to aSubscribableChannel
.class
class
AMessageProducerSupport
sub-class that provides ExpressionMessageProducerSupport.payloadExpression evaluation with result as a payload for Message to send.class
TheMessageSource
strategy implementation to produce aMessage
from underlying MessageProcessorMessageSource.messageProcessor for polling endpoints.class
A support class for producer endpoints that provides a setter for the output channel and a convenience method for sending Messages.class
AMessageSource
implementation that invokes a no-argument method so that its return value may be sent to a channel.class
Message Endpoint that connects anyMessageHandler
implementation to aPollableChannel
.class
TheMessageProducerSupport
to adapt a providedMessageSource
into aFlux
and let it be subscribed in theMessageProducerSupport.subscribeToPublisher(org.reactivestreams.Publisher<? extends org.springframework.messaging.Message<?>>)
.class
AnAbstractEndpoint
implementation for Reactive Streams subscription into an input channel and reactive consumption of messages from that channel.class
A Channel Adapter implementation for connecting aMessageSource
to aMessageChannel
. -
Uses of NamedComponent in org.springframework.integration.event.inbound
Modifier and TypeClassDescriptionclass
An inbound Channel Adapter that implementsGenericApplicationListener
and passes SpringApplicationEvents
within messages. -
Uses of NamedComponent in org.springframework.integration.event.outbound
Modifier and TypeClassDescriptionclass
-
Uses of NamedComponent in org.springframework.integration.feed.inbound
Modifier and TypeClassDescriptionclass
This implementation ofMessageSource
will produce individualSyndEntry
s for a feed identified with the 'feedUrl' attribute. -
Uses of NamedComponent in org.springframework.integration.file
Modifier and TypeClassDescriptionclass
MessageSource
that creates messages from a file system directory.class
AMessageHandler
implementation that writes the Message payload to a file. -
Uses of NamedComponent in org.springframework.integration.file.remote
Modifier and TypeClassDescriptionclass
A message source that produces a message with anInputStream
payload referencing a remote file. -
Uses of NamedComponent in org.springframework.integration.file.remote.gateway
Modifier and TypeClassDescriptionclass
Base class for Outbound Gateways that perform remote file operations. -
Uses of NamedComponent in org.springframework.integration.file.remote.handler
Modifier and TypeClassDescriptionclass
AMessageHandler
implementation that transfers files to a remote server. -
Uses of NamedComponent in org.springframework.integration.file.remote.synchronizer
Modifier and TypeClassDescriptionclass
Factors out the common logic between the FTP and SFTP adapters. -
Uses of NamedComponent in org.springframework.integration.file.splitter
Modifier and TypeClassDescriptionclass
TheAbstractMessageSplitter
implementation to split theFile
Message payload to lines. -
Uses of NamedComponent 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 NamedComponent in org.springframework.integration.filter
-
Uses of NamedComponent in org.springframework.integration.ftp.gateway
Modifier and TypeClassDescriptionclass
Outbound Gateway for performing remote file operations via FTP/FTPS. -
Uses of NamedComponent in org.springframework.integration.ftp.inbound
Modifier and TypeClassDescriptionclass
AMessageSource
implementation for FTP.class
Message source for streaming FTP remote file contents. -
Uses of NamedComponent in org.springframework.integration.ftp.outbound
Modifier and TypeClassDescriptionclass
The FTP specificFileTransferringMessageHandler
extension. -
Uses of NamedComponent in org.springframework.integration.gateway
Modifier and TypeClassDescriptionclass
AGatewayProxyFactoryBean
extension for Java configuration.class
TheAbstractReplyProducingMessageHandler
implementation for mid-flow Gateway.class
Generates 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.class
A convenient base class for connecting application code toMessageChannel
s for sending, receiving, or request-reply operations. -
Uses of NamedComponent in org.springframework.integration.graph
Modifier and TypeMethodDescriptionvoid
IntegrationGraphServer.setAdditionalPropertiesCallback
(Function<NamedComponent, Map<String, Object>> additionalPropertiesCallback) Specify a callbackFunction
to be called against eachNamedComponent
to populate additional properties to the targetIntegrationNode
. -
Uses of NamedComponent in org.springframework.integration.graphql.outbound
Modifier and TypeClassDescriptionclass
AnAbstractReplyProducingMessageHandler
capable of fielding GraphQL Query, Mutation and Subscription requests. -
Uses of NamedComponent in org.springframework.integration.handler
Modifier and TypeClassDescriptionclass
Base class forMessageHandler
implementations.class
The baseAbstractMessageHandler
implementation for theMessageProducer
.class
Base class forReactiveMessageHandler
implementations.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
AMessageHandler
that evaluates the providedExpression
expecting a void return.class
MessageHandler implementation that simply logs the Message or its payload depending on the value of the 'shouldLogFullMessage' or SpEL 'logExpression' property.class
A compositeMessageHandler
implementation that invokes a chain of MessageHandler instances in order.class
Base class for Message handling components that provides basic validation and error handling capabilities.class
AMessageHandler
that invokes the specified method on the provided object.class
TheAbstractReplyProducingMessageHandler
wrapper around rawMessageHandler
for request-reply scenarios, e.g.class
-
Uses of NamedComponent in org.springframework.integration.handler.advice
Modifier and TypeClassDescriptionclass
The baseHandleMessageAdvice
for advices which can be applied only for theMessageHandler.handleMessage(Message)
.class
Base class forMessageHandler
advice classes.class
TheAbstractRequestHandlerAdvice
implementation for cachingAbstractReplyProducingMessageHandler.RequestHandler#handleRequestMessage(Message)
results.class
Used to adviseMessageHandler
s.class
TheMethodInterceptor
implementation for the Idempotent Receiver E.I.class
AnAbstractRequestHandlerAdvice
extension for a rate limiting to service method calls.class
A circuit breaker that stops calling a failing service after threshold failures, until halfOpenAfter milliseconds has elapsed.class
Uses spring-retry to perform stateless or stateful retry. -
Uses of NamedComponent 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 Distributed SQL Message Source is a message source which runs defined distributed query in the cluster and returns results in the light of iteration type.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 NamedComponent in org.springframework.integration.hazelcast.outbound
Modifier and TypeClassDescriptionclass
MessageHandler implementation that writesMessage
or payload to defined Hazelcast distributed cache object. -
Uses of NamedComponent in org.springframework.integration.history
Modifier and TypeMethodDescriptionstatic <T> Message<T>
MessageHistory.write
(Message<T> message, NamedComponent component) static <T> Message<T>
MessageHistory.write
(Message<T> messageArg, NamedComponent component, MessageBuilderFactory messageBuilderFactory) -
Uses of NamedComponent in org.springframework.integration.http.inbound
Modifier and TypeClassDescriptionclass
TheMessagingGatewaySupport
extension for HTTP Inbound endpoints with basic properties.class
Inbound HTTP endpoint that implements Spring'sController
interface to be used with a DispatcherServlet front controller.class
Base class for HTTP request handling endpoints.class
Inbound Messaging Gateway that handles HTTP Requests. -
Uses of NamedComponent 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 NamedComponent in org.springframework.integration.ip
Modifier and TypeClassDescriptionclass
Base class for inbound TCP/UDP Channel Adapters.class
Base class for UDP MessageHandlers. -
Uses of NamedComponent in org.springframework.integration.ip.tcp
Modifier and TypeClassDescriptionclass
Inbound Gateway using a server connection factory - threading is controlled by the factory.class
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.class
Tcp outbound channel adapter using a TcpConnection to send data - if the connection factory is a server factory, the TcpListener owns the connections. -
Uses of NamedComponent in org.springframework.integration.ip.tcp.connection
Modifier and TypeClassDescriptionclass
Abstract class for client connection factories; client connection factories establish outgoing connections.class
Base class for all connection factories.class
Base class for all server connection factories.class
Connection factory that caches connections from the underlying target factory.class
Given a list of connection factories, serves upTcpConnection
s that can iterate over a connection from each factory until the write succeeds or the list is exhausted.class
A client connection factory that createsTcpNetConnection
s.class
Implements a server connection factory that producesTcpNetConnection
s using aServerSocket
.class
A client connection factory that createsTcpNioConnection
s.class
/** Implements a server connection factory that producesTcpNioConnection
s using aServerSocketChannel
.class
A client connection factory that binds a connection to a thread. -
Uses of NamedComponent 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
AMessageHandler
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.class
A channel adapter to receive incoming UDP packets.class
AMessageHandler
implementation that maps a Message into a UDP datagram packet and sends that to the specified host and port. -
Uses of NamedComponent in org.springframework.integration.jdbc
Modifier and TypeClassDescriptionclass
A message handler that executes an SQL update.class
class
A polling channel adapter that creates messages from the payload returned by executing a select query.class
A message handler that executes Stored Procedures for update purposes.class
AnAbstractReplyProducingMessageHandler
implementation for performing RDBMS stored procedures which return results.class
A polling channel adapter that creates messages from the payload returned by executing a stored procedure or Sql function. -
Uses of NamedComponent in org.springframework.integration.jdbc.channel
Modifier and TypeClassDescriptionclass
AnAbstractSubscribableChannel
for receiving push notifications for messages send to a group id of aJdbcChannelMessageStore
. -
Uses of NamedComponent in org.springframework.integration.jms
Modifier and TypeClassDescriptionclass
class
JMS MessageListener that converts a JMS Message into a Spring Integration Message and sends that Message to a channel.class
A source for receiving JMS Messages with a polling listener.class
A wrapper around theJmsMessageDrivenEndpoint
implementingMessagingGatewaySupport
.class
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.class
A MessageConsumer that sends the converted Message payload within a JMS Message.class
class
AnAbstractJmsChannel
implementation for message-driven subscriptions. -
Uses of NamedComponent in org.springframework.integration.jmx
Modifier and TypeClassDescriptionclass
AMessageSource
implementation that retrieves the current value of a JMX attribute each timeAbstractMessageSource.receive()
is invoked.class
AMessageSource
implementation that retrieves a snapshot of a filtered subset of the MBean tree.class
A JMXNotificationListener
implementation that will send Messages containing the JMXNotification
instances as their payloads.class
AnAbstractMessageHandler
implementation to publish an incoming message as a JMXNotification
.class
AMessageHandler
implementation for invoking JMX operations based on the Message sent to itsAbstractMessageHandler.handleMessage(Message)
method. -
Uses of NamedComponent in org.springframework.integration.jpa.inbound
Modifier and TypeClassDescriptionclass
Polling message source that produces messages from the result of the provided: entityClass JpQl Select Query Sql Native Query JpQl Named Query Sql Native Named Query . -
Uses of NamedComponent 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 NamedComponent in org.springframework.integration.json
Modifier and TypeClassDescriptionclass
Transformer implementation that converts a JSON string payload into an instance of the provided target Class.class
Transformer implementation that converts a payload instance into a JSON string representation. -
Uses of NamedComponent in org.springframework.integration.kafka.channel
Modifier and TypeClassDescriptionclass
Abstract MessageChannel backed by an Apache Kafka topic.class
Pollable channel backed by an Apache Kafka topic.class
Publish/subscribe channel backed by an Apache Kafka topic.class
Subscribable channel backed by an Apache Kafka topic. -
Uses of NamedComponent in org.springframework.integration.kafka.inbound
Modifier and TypeClassDescriptionclass
KafkaInboundGateway<K,
V, R> Inbound gateway.class
Message-driven channel adapter.class
KafkaMessageSource<K,
V> Polled message source for Apache Kafka. -
Uses of NamedComponent 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 NamedComponent in org.springframework.integration.mail
Modifier and TypeClassDescriptionclass
Base class forMailReceiver
implementations.class
An event-driven Channel Adapter that receives mail messages from a mail server that supports the IMAP "idle" command (see RFC 2177).class
AMailReceiver
implementation for receiving mail messages from a mail server that supports the IMAP protocol.class
MessageSource
implementation that delegates to aMailReceiver
to poll a mailbox.class
AMessageHandler
implementation for sending mail.class
AMailReceiver
implementation that polls a mail server using the POP3 protocol. -
Uses of NamedComponent in org.springframework.integration.mongodb.inbound
Modifier and TypeClassDescriptionclass
AnAbstractMessageSource
extension for common MongoDB sources options and support methods.class
AMessageProducerSupport
for MongoDB Change Stream implementation.class
An instance ofMessageSource
which returns aMessage
with a payload which is the result of execution of aQuery
.class
An instance ofMessageSource
which returns aMessage
with a payload which is the result of execution of aQuery
. -
Uses of NamedComponent in org.springframework.integration.mongodb.outbound
Modifier and TypeClassDescriptionclass
Makes outbound operations to query a MongoDb database using aMongoOperations
.class
Implementation ofMessageHandler
which writes Message payload into a MongoDb collection identified by evaluation of theMongoDbStoringMessageHandler.collectionNameExpression
.class
Implementation ofReactiveMessageHandler
which writes Message payload into a MongoDb collection, using reactive MongoDb support, The collection is identified by evaluation of theReactiveMongoDbStoringMessageHandler.collectionNameExpression
. -
Uses of NamedComponent 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 NamedComponent in org.springframework.integration.mqtt.outbound
Modifier and TypeClassDescriptionclass
Abstract class for MQTT outbound channel adapters.class
Eclipse Paho Implementation.class
TheAbstractMqttMessageHandler
implementation for MQTT v5. -
Uses of NamedComponent in org.springframework.integration.r2dbc.inbound
Modifier and TypeClassDescriptionclass
An instance ofMessageSource
which returns aMessage
with a payload which is the result of execution of query. -
Uses of NamedComponent in org.springframework.integration.r2dbc.outbound
Modifier and TypeClassDescriptionclass
Implementation ofReactiveMessageHandler
which writes Message payload into a Relational Database, using reactive r2dbc support. -
Uses of NamedComponent in org.springframework.integration.redis.channel
Modifier and TypeClassDescriptionclass
AnAbstractMessageChannel
implementation withBroadcastCapableChannel
aspect to provide a pub-sub semantics to consume messages fgrom Redis topic. -
Uses of NamedComponent 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
class
class
Inbound channel adapter which returns a Message representing a view into a Redis store. -
Uses of NamedComponent in org.springframework.integration.redis.outbound
Modifier and TypeClassDescriptionclass
Implementation ofReactiveMessageHandler
which writes Message payload or Message itself (seeReactiveRedisStreamMessageHandler.extractPayload
) into a Redis stream using Reactive Stream operations.class
The Gateway component implementation to perform Redis commands with provided arguments and to return command result.class
class
class
class
Implementation ofMessageHandler
which writes Message data into a Redis store identified by a keyString
. -
Uses of NamedComponent in org.springframework.integration.resource
Modifier and TypeClassDescriptionclass
Implementation ofMessageSource
based onResourcePatternResolver
which will attempt to resolveResource
s based on the pattern specified. -
Uses of NamedComponent in org.springframework.integration.router
Modifier and TypeClassDescriptionclass
Base class for all Message Routers that support mapping from arbitrary String values to Message Channel names.class
Base class for all Message Routers.class
A Message Router that resolves the targetMessageChannel
for messages whose payload is aThrowable
.class
A Message Router implementation that evaluates the specified SpEL expression.class
A Message Router that resolves the MessageChannel from a header value.class
A Message Router that invokes the specified method on the given object.class
A Message Router that resolves theMessageChannel
based on theMessage's
payload type.class
<recipient-list-router id="simpleRouter" input-channel="routingChannelA"> <recipient channel="channel1"/> <recipient channel="channel2"/> </recipient-list-router>
-
Uses of NamedComponent in org.springframework.integration.rsocket.inbound
Modifier and TypeClassDescriptionclass
TheMessagingGatewaySupport
implementation for theIntegrationRSocketEndpoint
. -
Uses of NamedComponent in org.springframework.integration.rsocket.outbound
Modifier and TypeClassDescriptionclass
An Outbound Messaging Gateway for RSocket requests. -
Uses of NamedComponent in org.springframework.integration.scattergather
Modifier and TypeClassDescriptionclass
TheMessageHandler
implementation for the Scatter-Gather EIP pattern. -
Uses of NamedComponent in org.springframework.integration.scripting
Modifier and TypeClassDescriptionclass
TheMessageSource
strategy implementation to produce aMessage
from underlying ScriptExecutingMessageSource.scriptMessageProcessor for polling endpoints. -
Uses of NamedComponent in org.springframework.integration.sftp.gateway
Modifier and TypeClassDescriptionclass
Outbound Gateway for performing remote file operations via SFTP. -
Uses of NamedComponent in org.springframework.integration.sftp.inbound
Modifier and TypeClassDescriptionclass
AMessageSource
implementation for SFTP that delegates to an InboundFileSynchronizer.class
Message source for streaming SFTP remote file contents. -
Uses of NamedComponent in org.springframework.integration.sftp.outbound
-
Uses of NamedComponent in org.springframework.integration.smb.inbound
Modifier and TypeClassDescriptionclass
AMessageSource
implementation for SMB.class
Message source for streaming SMB remote file contents. -
Uses of NamedComponent in org.springframework.integration.smb.outbound
Modifier and TypeClassDescriptionclass
The SMB specificFileTransferringMessageHandler
extension.class
Outbound Gateway for performing remote file operations via SMB. -
Uses of NamedComponent 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 NamedComponent 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 NamedComponent in org.springframework.integration.stomp.outbound
Modifier and TypeClassDescriptionclass
TheAbstractMessageHandler
implementation to send messages to STOMP destinations. -
Uses of NamedComponent in org.springframework.integration.stream
Modifier and TypeClassDescriptionclass
A pollable source for receiving bytes from anInputStream
.class
AMessageHandler
that writes a byte array to anOutputStream
.class
A pollable source forReaders
.class
AMessageHandler
that writes characters to aWriter
. -
Uses of NamedComponent in org.springframework.integration.support.management
Modifier and TypeInterfaceDescriptioninterface
Marker interface indicating that thisIntegrationManagement
component initiates message flow.interface
Base interface for Integration managed components.interface
-
Uses of NamedComponent in org.springframework.integration.support.utils
Modifier and TypeMethodDescriptionstatic String
IntegrationUtils.obtainComponentName
(NamedComponent component) Obtain a component name from the providedNamedComponent
. -
Uses of NamedComponent 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 NamedComponent in org.springframework.integration.test.mock
Modifier and TypeClassDescriptionclass
TheAbstractMessageProducingHandler
extension for the mocking purpose in tests. -
Uses of NamedComponent in org.springframework.integration.transaction
Modifier and TypeClassDescriptionclass
This implementation ofTransactionSynchronizationFactory
allows you to configure SpEL expressions, with their execution being coordinated (synchronized) with a transaction - seeTransactionSynchronization
. -
Uses of NamedComponent in org.springframework.integration.transformer
Modifier and TypeClassDescriptionclass
A base class forTransformer
implementations that modify the payload of aMessage
.class
A base class forTransformer
implementations.class
Transformer that stores a Message and returns a new Message whose payload is the id of the stored Message.class
Transformer that accepts a Message whose payload is a UUID and retrieves the Message associated with that id from a MessageStore if available.class
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
AbstractPayloadTransformer
that delegates to a codec to decode the payload from a byte[].class
AbstractPayloadTransformer
that delegates to a codec to encode the payload into a byte[].class
A Transformer that adds statically configured header values to a Message.class
Transformer that removes Message headers.class
Will transform Map to an instance of Object.class
A reply-producingMessageHandler
that delegates to aTransformer
instance to modify the receivedMessage
and sends the result to its output channel.class
Transforms an object graph into a Map.class
A simple transformer that creates an outbound payload by invoking the inbound payload Object'stoString()
method.class
Transformer that deserializes the inbound byte array payload to an object by delegating to a Converter<byte[], Object>.class
Transformer that serializes the inbound payload into a byte array by delegating to a Converter<Object, byte[]>.class
Transformer that converts the inbound payload to an object by delegating to a Converter<Object, Object>.class
An Apache Avro transformer to create generatedSpecificRecord
objects frombyte[]
.class
An Apache Avro transformer for generatedSpecificRecord
objects.class
Transforms an InputStream payload to a byte[] or String (if a charset is provided).class
Transforms a packet in Syslog (RFC3164) format to a Map. -
Uses of NamedComponent in org.springframework.integration.webflux.inbound
Modifier and TypeClassDescriptionclass
AMessagingGatewaySupport
implementation for Spring WebFlux HTTP requests execution. -
Uses of NamedComponent in org.springframework.integration.webflux.outbound
Modifier and TypeClassDescriptionclass
AMessageHandler
implementation that executes HTTP requests by delegating to a ReactiveWebClient
instance. -
Uses of NamedComponent in org.springframework.integration.websocket.inbound
Modifier and TypeClassDescriptionclass
TheMessageProducerSupport
for inbound WebSocket messages. -
Uses of NamedComponent in org.springframework.integration.websocket.outbound
-
Uses of NamedComponent in org.springframework.integration.ws
Modifier and TypeClassDescriptionclass
class
Base class for outbound Web Service-invoking Messaging Gateways.class
class
An outbound Messaging Gateway for invoking Web Services that also supports marshalling and unmarshalling of the request and response messages.class
class
An outbound Messaging Gateway for invoking a Web Service. -
Uses of NamedComponent in org.springframework.integration.xml.router
Modifier and TypeClassDescriptionclass
Message Router that usesXPathExpression
evaluation to determine channel names. -
Uses of NamedComponent in org.springframework.integration.xml.splitter
Modifier and TypeClassDescriptionclass
Message Splitter that uses anXPathExpression
to split aDocument
,File
orString
payload into aNodeList
. -
Uses of NamedComponent in org.springframework.integration.xml.transformer
Modifier and TypeClassDescriptionclass
Super class for XML transformers.class
An implementation ofAbstractTransformer
that delegates to an OXMMarshaller
.class
Transforms the payload to aSource
using aSourceFactory
.class
An implementation ofTransformer
that delegates to an OXMUnmarshaller
.class
Transformer implementation that evaluates XPath expressions against the message payload and inserts the result of the evaluation into a message header.class
Transformer 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 NamedComponent in org.springframework.integration.xmpp.core
Modifier and TypeClassDescriptionclass
class
-
Uses of NamedComponent 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 NamedComponent in org.springframework.integration.xmpp.outbound
Modifier and TypeClassDescriptionclass
MessageHandler that sends an XMPP Chat Message.class
MessageHandler that publishes updated Presence values for a given XMPP connection. -
Uses of NamedComponent in org.springframework.integration.zeromq.channel
Modifier and TypeClassDescriptionclass
TheSubscribableChannel
implementation over ZeroMQ sockets. -
Uses of NamedComponent in org.springframework.integration.zeromq.inbound
Modifier and TypeClassDescriptionclass
AMessageProducerSupport
implementation for consuming messages from ZeroMq socket. -
Uses of NamedComponent in org.springframework.integration.zeromq.outbound
Modifier and TypeClassDescriptionclass
TheAbstractReactiveMessageHandler
implementation for publishing messages over ZeroMq socket.