Uses of Interface
org.springframework.integration.support.context.NamedComponent
Packages that use 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.
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.
Provides classes supporting inbound endpoints.
Base package for File support.
Outbound channel adapters for file system.
Inbound channel adapters for file system.
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
 
MessageHandlers 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 adapters.
All things related to tcp connections - client and
 server factories; listener and sender interfaces.
Inbound channel adapters for TCP Support.
Outbound channel adapters for TCP Support.
Base package for UDP support.
Inbound channel adapters for UDP Support.
Outbound channel adapters 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.
Inbound channel adapters for JDBC.
Outbound channel adapters for JDBC.
Base package for JMS Support.
JMS-based message channels.
Inbound channel adapters for JMS.
Outbound channel adapters for JMS.
Base package for JMX support.
Inbound channel adapters for JMX support.
Outbound channel adapters 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.
The inbound channel adapters support for Mail protocol.
The outbound channel adapters support for Mail protocol.
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 
ResourcesProvides 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.
The inbound channel adapters for stream support.
The outbound channel adapters 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.
Inbound Web Service components.
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 NamedComponent in org.springframework.integration.aggregatorClasses in org.springframework.integration.aggregator that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.amqp.channelClasses in org.springframework.integration.amqp.channel that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.amqp.inboundClasses in org.springframework.integration.amqp.inbound that implement NamedComponentModifier and TypeClassDescriptionclassAMessagingGatewaySupportimplementation for AMQP 1.0 client.classAMessageProducerSupportimplementation for AMQP 1.0 client.classAdapter 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.classA pollableMessageSourcefor RabbitMQ.
- 
Uses of NamedComponent in org.springframework.integration.amqp.outboundClasses in org.springframework.integration.amqp.outbound that implement NamedComponentModifier and TypeClassDescriptionclassA baseAbstractReplyProducingMessageHandlerextension for AMQP message handlers.classAnAbstractReplyProducingMessageHandlerimplementation for AMQP 1.0 client.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 NamedComponent in org.springframework.integration.camel.outboundClasses in org.springframework.integration.camel.outbound that implement NamedComponentModifier and TypeClassDescriptionclassAMessageHandlerfor calling Apache Camel route and produce (optionally) a reply.
- 
Uses of NamedComponent in org.springframework.integration.cassandra.outboundClasses in org.springframework.integration.cassandra.outbound that implement NamedComponentModifier and TypeClassDescriptionclassAnAbstractReplyProducingMessageHandlerimplementation for Cassandra outbound operations.
- 
Uses of NamedComponent in org.springframework.integration.channelClasses in org.springframework.integration.channel that implement NamedComponentModifier 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.final classSpecializedSubscribableChannelfor a single final subscriber set up during bean instantiation (unlike otherSubscribableChannels where theMessageHandleris subscribed when the endpoint is started).classTheAbstractMessageChannelimplementation for the Reactive StreamsPublisherbased on the Project ReactorFlux.classA channel implementation that essentially behaves like "/dev/null".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 NamedComponent in org.springframework.integration.codecClasses in org.springframework.integration.codec that implement NamedComponent
- 
Uses of NamedComponent in org.springframework.integration.contextClasses in org.springframework.integration.context that implement NamedComponentModifier and TypeClassDescriptionclassA base class that provides convenient access to the bean factory as well asTaskSchedulerandConversionServiceinstances.
- 
Uses of NamedComponent in org.springframework.integration.debezium.inboundClasses in org.springframework.integration.debezium.inbound that implement NamedComponentModifier and TypeClassDescriptionclassDebezium Change Event Channel Adapter.
- 
Uses of NamedComponent in org.springframework.integration.dslClasses in org.springframework.integration.dsl that implement NamedComponentModifier and TypeClassDescriptionclassThe standard implementation of theIntegrationFlowinterface instantiated by the Framework.
- 
Uses of NamedComponent in org.springframework.integration.endpointSubinterfaces of NamedComponent in org.springframework.integration.endpointModifier and TypeInterfaceDescriptioninterfaceMessage consumers implement this interface, the message handler within a consumer may or may not emit output messages.Classes in org.springframework.integration.endpoint that implement NamedComponentModifier and TypeClassDescriptionclassThe base class for Message Endpoint implementations.classA message source that can limit the number of remote objects it fetches.classAbstract message source.classAnAbstractEndpointextension for Polling Consumer pattern basics.classMessage Endpoint that connects anyMessageHandlerimplementation to aSubscribableChannel.classclassAMessageProducerSupportsubclass that provides ExpressionMessageProducerSupport.payloadExpression evaluation with result as a payload for Message to send.classTheMessageSourcestrategy implementation to produce aMessagefrom underlying MessageProcessorMessageSource.messageProcessor for polling endpoints.classA support class for producer endpoints that provides a setter for the output channel and a convenience method for sending Messages.classAMessageSourceimplementation that invokes a no-argument method so that its return value may be sent to a channel.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 NamedComponent in org.springframework.integration.event.inboundClasses in org.springframework.integration.event.inbound that implement NamedComponentModifier and TypeClassDescriptionclassAn inbound Channel Adapter that implementsGenericApplicationListenerand passes SpringApplicationEventswithin messages.
- 
Uses of NamedComponent in org.springframework.integration.event.outboundClasses in org.springframework.integration.event.outbound that implement NamedComponentModifier and TypeClassDescriptionclass
- 
Uses of NamedComponent in org.springframework.integration.feed.inboundClasses in org.springframework.integration.feed.inbound that implement NamedComponentModifier and TypeClassDescriptionclassThis implementation ofMessageSourcewill produce individualSyndEntrys for a feed identified with the 'feedUrl' attribute.
- 
Uses of NamedComponent in org.springframework.integration.fileClasses in org.springframework.integration.file that implement NamedComponentModifier and TypeClassDescriptionclassDeprecated, for removal: This API element is subject to removal in a future version.classDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favorFileWritingMessageHandler
- 
Uses of NamedComponent in org.springframework.integration.file.inboundClasses in org.springframework.integration.file.inbound that implement NamedComponentModifier and TypeClassDescriptionclassMessageSourcethat creates messages from a file system directory.
- 
Uses of NamedComponent in org.springframework.integration.file.outboundClasses in org.springframework.integration.file.outbound that implement NamedComponentModifier and TypeClassDescriptionclassAMessageHandlerimplementation that writes the Message payload to a file.
- 
Uses of NamedComponent in org.springframework.integration.file.remoteClasses in org.springframework.integration.file.remote that implement NamedComponentModifier and TypeClassDescriptionclassA message source that produces a message with anInputStreampayload referencing a remote file.
- 
Uses of NamedComponent in org.springframework.integration.file.remote.gatewayClasses in org.springframework.integration.file.remote.gateway that implement NamedComponentModifier and TypeClassDescriptionclassBase class for Outbound Gateways that perform remote file operations.
- 
Uses of NamedComponent in org.springframework.integration.file.remote.handlerClasses in org.springframework.integration.file.remote.handler that implement NamedComponentModifier and TypeClassDescriptionclassAMessageHandlerimplementation that transfers files to a remote server.
- 
Uses of NamedComponent in org.springframework.integration.file.remote.synchronizerClasses in org.springframework.integration.file.remote.synchronizer that implement NamedComponentModifier and TypeClassDescriptionclassFactors out the common logic between the FTP and SFTP adapters.
- 
Uses of NamedComponent in org.springframework.integration.file.splitterClasses in org.springframework.integration.file.splitter that implement NamedComponentModifier and TypeClassDescriptionclassTheAbstractMessageSplitterimplementation to split theFileMessage payload to lines.
- 
Uses of NamedComponent in org.springframework.integration.file.tailClasses in org.springframework.integration.file.tail that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.filterClasses in org.springframework.integration.filter that implement NamedComponent
- 
Uses of NamedComponent in org.springframework.integration.ftp.gatewayClasses in org.springframework.integration.ftp.gateway that implement NamedComponentModifier and TypeClassDescriptionclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofFtpOutboundGateway
- 
Uses of NamedComponent in org.springframework.integration.ftp.inboundClasses in org.springframework.integration.ftp.inbound that implement NamedComponentModifier and TypeClassDescriptionclassAMessageSourceimplementation for FTP.classMessage source for streaming FTP remote file contents.
- 
Uses of NamedComponent in org.springframework.integration.ftp.outboundClasses in org.springframework.integration.ftp.outbound that implement NamedComponentModifier and TypeClassDescriptionclassThe FTP specificFileTransferringMessageHandlerextension.classOutbound Gateway for performing remote file operations via FTP/FTPS.
- 
Uses of NamedComponent in org.springframework.integration.gatewayClasses in org.springframework.integration.gateway that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.graphMethod parameters in org.springframework.integration.graph with type arguments of type NamedComponentModifier and TypeMethodDescriptionvoidIntegrationGraphServer.setAdditionalPropertiesCallback(@Nullable Function<NamedComponent, Map<String, Object>> additionalPropertiesCallback) Specify a callbackFunctionto be called against eachNamedComponentto populate additional properties to the targetIntegrationNode.
- 
Uses of NamedComponent in org.springframework.integration.graphql.outboundClasses in org.springframework.integration.graphql.outbound that implement NamedComponentModifier and TypeClassDescriptionclassAnAbstractReplyProducingMessageHandlercapable of fielding GraphQL Query, Mutation and Subscription requests.
- 
Uses of NamedComponent in org.springframework.integration.handlerClasses in org.springframework.integration.handler that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.handler.adviceClasses in org.springframework.integration.handler.advice that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.hazelcast.inboundClasses in org.springframework.integration.hazelcast.inbound that implement NamedComponentModifier 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 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.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 NamedComponent in org.springframework.integration.hazelcast.outboundClasses in org.springframework.integration.hazelcast.outbound that implement NamedComponentModifier and TypeClassDescriptionclassMessageHandler implementation that writesMessageor payload to defined Hazelcast distributed cache object.
- 
Uses of NamedComponent in org.springframework.integration.historyMethods in org.springframework.integration.history with parameters of type NamedComponentModifier 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.inboundClasses in org.springframework.integration.http.inbound that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.http.outboundClasses in org.springframework.integration.http.outbound that implement NamedComponentModifier and TypeClassDescriptionclassBase class for http outbound adapter/gateway.classAMessageHandlerimplementation that executes HTTP requests by delegating to aRestTemplateinstance.
- 
Uses of NamedComponent in org.springframework.integration.ipClasses in org.springframework.integration.ip that implement NamedComponentModifier and TypeClassDescriptionclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofAbstractInternetProtocolReceivingChannelAdapterclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofAbstractInternetProtocolSendingMessageHandler
- 
Uses of NamedComponent in org.springframework.integration.ip.tcpClasses in org.springframework.integration.ip.tcp that implement NamedComponentModifier and TypeClassDescriptionclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor orTcpInboundGatewayclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor orTcpOutboundGatewayclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor orTcpReceivingChannelAdapterclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor orTcpSendingMessageHandler
- 
Uses of NamedComponent in org.springframework.integration.ip.tcp.connectionClasses in org.springframework.integration.ip.tcp.connection that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.ip.tcp.inboundClasses in org.springframework.integration.ip.tcp.inbound that implement NamedComponentModifier and TypeClassDescriptionclassInbound Gateway using a server connection factory - threading is controlled by the 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 NamedComponent in org.springframework.integration.ip.tcp.outboundClasses in org.springframework.integration.ip.tcp.outbound that implement NamedComponentModifier and TypeClassDescriptionclassTCP outbound gateway that uses a client connection factory.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 NamedComponent in org.springframework.integration.ip.udpClasses in org.springframework.integration.ip.udp that implement NamedComponentModifier and TypeClassDescriptionclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor orMulticastReceivingChannelAdapterclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor orMulticastSendingMessageHandlerclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor orUnicastReceivingChannelAdapterclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor orUnicastSendingMessageHandler
- 
Uses of NamedComponent in org.springframework.integration.ip.udp.inboundClasses in org.springframework.integration.ip.udp.inbound that implement NamedComponentModifier and TypeClassDescriptionclassBase class for inbound TCP/UDP Channel Adapters.classChannel 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 NamedComponent in org.springframework.integration.ip.udp.outboundClasses in org.springframework.integration.ip.udp.outbound that implement NamedComponentModifier and TypeClassDescriptionclassBase class for UDP MessageHandlers.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.classAMessageHandlerimplementation 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.jdbcClasses in org.springframework.integration.jdbc that implement NamedComponentModifier and TypeClassDescriptionclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofJdbcMessageHandlerclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofJdbcOutboundGatewayclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofJdbcPollingChannelAdapterclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofStoredProcMessageHandlerclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofStoredProcOutboundGatewayclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofStoredProcPollingChannelAdapter
- 
Uses of NamedComponent in org.springframework.integration.jdbc.channelClasses in org.springframework.integration.jdbc.channel that implement NamedComponentModifier and TypeClassDescriptionclassAnAbstractSubscribableChannelfor receiving push notifications for messages send to a group id of aJdbcChannelMessageStore.
- 
Uses of NamedComponent in org.springframework.integration.jdbc.inboundClasses in org.springframework.integration.jdbc.inbound that implement NamedComponentModifier and TypeClassDescriptionclassA polling channel adapter that creates messages from the payload returned by executing a select query.classA 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.outboundClasses in org.springframework.integration.jdbc.outbound that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.jmsClasses in org.springframework.integration.jms that implement NamedComponentModifier and TypeClassDescriptionclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofAbstractJmsChannelclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofChannelPublishingJmsMessageListenerclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofJmsDestinationPollingSourceclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofJmsInboundGatewayclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofJmsMessageDrivenEndpointclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofJmsOutboundGatewayclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofJmsSendingMessageHandlerclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofPollableJmsChannelclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofSubscribableJmsChannel
- 
Uses of NamedComponent in org.springframework.integration.jms.channelClasses in org.springframework.integration.jms.channel that implement NamedComponentModifier and TypeClassDescriptionclassA baseAbstractMessageChannelimplementation for JMS-backed message channels.classA JMS-backed channel from which messages can be received through polling.classAnAbstractJmsChannelimplementation for message-driven subscriptions.
- 
Uses of NamedComponent in org.springframework.integration.jms.inboundClasses in org.springframework.integration.jms.inbound that implement NamedComponentModifier and TypeClassDescriptionclassJMS MessageListener that converts a JMS Message into a Spring Integration Message and sends that Message to a channel.classA source for receiving JMS Messages with a polling listener.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.
- 
Uses of NamedComponent in org.springframework.integration.jms.outboundClasses in org.springframework.integration.jms.outbound that implement NamedComponentModifier and TypeClassDescriptionclassAn outbound Messaging Gateway for request/reply JMS.classA MessageConsumer that sends the converted Message payload within a JMS Message.
- 
Uses of NamedComponent in org.springframework.integration.jmxClasses in org.springframework.integration.jmx that implement NamedComponentModifier and TypeClassDescriptionclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favorAttributePollingMessageSourceclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favorMBeanTreePollingMessageSourceclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favorNotificationListeningMessageProducerclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favorNotificationPublishingMessageHandlerclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favorOperationInvokingMessageHandler
- 
Uses of NamedComponent in org.springframework.integration.jmx.inboundClasses in org.springframework.integration.jmx.inbound that implement NamedComponentModifier and TypeClassDescriptionclassAMessageSourceimplementation that retrieves the current value of a JMX attribute each timeAbstractMessageSource.receive()is invoked.classAMessageSourceimplementation that retrieves a snapshot of a filtered subset of the MBean tree.classA JMXNotificationListenerimplementation that will send Messages containing the JMXNotificationinstances as their payloads.
- 
Uses of NamedComponent in org.springframework.integration.jmx.outboundClasses in org.springframework.integration.jmx.outbound that implement NamedComponentModifier and TypeClassDescriptionclassAnAbstractMessageHandlerimplementation 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 NamedComponent in org.springframework.integration.jpa.inboundClasses in org.springframework.integration.jpa.inbound that implement NamedComponentModifier and TypeClassDescriptionclassPolling 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.outboundClasses in org.springframework.integration.jpa.outbound that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.jsonClasses in org.springframework.integration.json that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.kafka.channelClasses in org.springframework.integration.kafka.channel that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.kafka.inboundClasses in org.springframework.integration.kafka.inbound that implement NamedComponentModifier and TypeClassDescriptionclassKafkaInboundGateway<K,V, R> Inbound gateway.classMessage-driven channel adapter.classKafkaMessageSource<K,V> Polled message source for Apache Kafka.
- 
Uses of NamedComponent in org.springframework.integration.kafka.outboundClasses in org.springframework.integration.kafka.outbound that implement NamedComponentModifier and TypeClassDescriptionclassA Message Handler for Apache Kafka; when supplied with aReplyingKafkaTemplateit is used as the handler in an outbound gateway.
- 
Uses of NamedComponent in org.springframework.integration.mailClasses in org.springframework.integration.mail that implement NamedComponentModifier and TypeClassDescriptionclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofAbstractMailReceiverclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofImapIdleChannelAdapterclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofImapMailReceiverclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofMailReceivingMessageSourceclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofMailSendingMessageHandlerclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofPop3MailReceiver
- 
Uses of NamedComponent in org.springframework.integration.mail.inboundClasses in org.springframework.integration.mail.inbound that implement NamedComponentModifier 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.classMessageSourceimplementation that delegates to aMailReceiverto poll a mailbox.classAMailReceiverimplementation that polls a mail server using the POP3 protocol.
- 
Uses of NamedComponent in org.springframework.integration.mail.outboundClasses in org.springframework.integration.mail.outbound that implement NamedComponent
- 
Uses of NamedComponent in org.springframework.integration.mongodb.inboundClasses in org.springframework.integration.mongodb.inbound that implement NamedComponentModifier and TypeClassDescriptionclassAnAbstractMessageSourceextension for common MongoDB sources options and support methods.classAMessageProducerSupportfor MongoDB Change Stream implementation.classAn instance ofMessageSourcewhich returns aMessagewith a payload which is the result of execution of aQuery.classAn instance ofMessageSourcewhich returns aMessagewith a payload which is the result of execution of aQuery.
- 
Uses of NamedComponent in org.springframework.integration.mongodb.outboundClasses in org.springframework.integration.mongodb.outbound that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.mqtt.inboundClasses in org.springframework.integration.mqtt.inbound that implement NamedComponentModifier and TypeClassDescriptionclassAbstract class for MQTT Message-Driven Channel Adapters.classEclipse Paho Implementation.classTheAbstractMqttMessageDrivenChannelAdapterimplementation for MQTT v5.
- 
Uses of NamedComponent in org.springframework.integration.mqtt.outboundClasses in org.springframework.integration.mqtt.outbound that implement NamedComponentModifier and TypeClassDescriptionclassAbstract class for MQTT outbound channel adapters.classEclipse Paho Implementation.classTheAbstractMqttMessageHandlerimplementation for MQTT v5.
- 
Uses of NamedComponent in org.springframework.integration.r2dbc.inboundClasses in org.springframework.integration.r2dbc.inbound that implement NamedComponentModifier and TypeClassDescriptionclassAn instance ofMessageSourcewhich returns aMessagewith a payload which is the result of execution of query.
- 
Uses of NamedComponent in org.springframework.integration.r2dbc.outboundClasses in org.springframework.integration.r2dbc.outbound that implement NamedComponentModifier and TypeClassDescriptionclassImplementation ofReactiveMessageHandlerwhich writes Message payload into a Relational Database, using reactive r2dbc support.
- 
Uses of NamedComponent in org.springframework.integration.redis.channelClasses in org.springframework.integration.redis.channel that implement NamedComponentModifier and TypeClassDescriptionclassAnAbstractMessageChannelimplementation withBroadcastCapableChannelaspect to provide a pub-sub semantics to consume messages fgrom Redis topic.
- 
Uses of NamedComponent in org.springframework.integration.redis.inboundClasses in org.springframework.integration.redis.inbound that implement NamedComponentModifier and TypeClassDescriptionclassAMessageProducerSupportfor reading messages from a Redis Stream and publishing them into the provided output channel.classclassclassclassInbound channel adapter which returns a Message representing a view into a Redis store.
- 
Uses of NamedComponent in org.springframework.integration.redis.outboundClasses in org.springframework.integration.redis.outbound that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.resourceClasses in org.springframework.integration.resource that implement NamedComponentModifier and TypeClassDescriptionclassImplementation ofMessageSourcebased onResourcePatternResolverwhich will attempt to resolveResources based on the pattern specified.
- 
Uses of NamedComponent in org.springframework.integration.routerClasses in org.springframework.integration.router that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.rsocket.inboundClasses in org.springframework.integration.rsocket.inbound that implement NamedComponentModifier and TypeClassDescriptionclassTheMessagingGatewaySupportimplementation for theIntegrationRSocketEndpoint.
- 
Uses of NamedComponent in org.springframework.integration.rsocket.outboundClasses in org.springframework.integration.rsocket.outbound that implement NamedComponentModifier and TypeClassDescriptionclassAn Outbound Messaging Gateway for RSocket requests.
- 
Uses of NamedComponent in org.springframework.integration.scattergatherClasses in org.springframework.integration.scattergather that implement NamedComponentModifier and TypeClassDescriptionclassTheMessageHandlerimplementation for the Scatter-Gather EIP pattern.
- 
Uses of NamedComponent in org.springframework.integration.scriptingClasses in org.springframework.integration.scripting that implement NamedComponentModifier and TypeClassDescriptionclassTheMessageSourcestrategy implementation to produce aMessagefrom underlying ScriptExecutingMessageSource.scriptMessageProcessor for polling endpoints.
- 
Uses of NamedComponent in org.springframework.integration.sftp.gatewayClasses in org.springframework.integration.sftp.gateway that implement NamedComponentModifier and TypeClassDescriptionclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofSftpOutboundGateway
- 
Uses of NamedComponent in org.springframework.integration.sftp.inboundClasses in org.springframework.integration.sftp.inbound that implement NamedComponentModifier and TypeClassDescriptionclassAMessageSourceimplementation for SFTP that delegates to an InboundFileSynchronizer.classMessage source for streaming SFTP remote file contents.
- 
Uses of NamedComponent in org.springframework.integration.sftp.outboundClasses in org.springframework.integration.sftp.outbound that implement NamedComponentModifier and TypeClassDescriptionclassSubclass ofFileTransferringMessageHandlerfor SFTP.classOutbound Gateway for performing remote file operations via SFTP.
- 
Uses of NamedComponent in org.springframework.integration.smb.inboundClasses in org.springframework.integration.smb.inbound that implement NamedComponentModifier and TypeClassDescriptionclassAMessageSourceimplementation for SMB.classMessage source for streaming SMB remote file contents.
- 
Uses of NamedComponent in org.springframework.integration.smb.outboundClasses in org.springframework.integration.smb.outbound that implement NamedComponentModifier and TypeClassDescriptionclassThe SMB specificFileTransferringMessageHandlerextension.classOutbound Gateway for performing remote file operations via SMB.
- 
Uses of NamedComponent in org.springframework.integration.splitterClasses in org.springframework.integration.splitter that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.stomp.inboundClasses in org.springframework.integration.stomp.inbound that implement NamedComponentModifier and TypeClassDescriptionclassTheMessageProducerSupportfor STOMP protocol to handle STOMP frames from provided destination and send messages to theoutputChannel.
- 
Uses of NamedComponent in org.springframework.integration.stomp.outboundClasses in org.springframework.integration.stomp.outbound that implement NamedComponentModifier and TypeClassDescriptionclassTheAbstractMessageHandlerimplementation to send messages to STOMP destinations.
- 
Uses of NamedComponent in org.springframework.integration.streamClasses in org.springframework.integration.stream that implement NamedComponentModifier and TypeClassDescriptionclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofByteStreamReadingMessageSourceclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofByteStreamWritingMessageHandlerclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofCharacterStreamReadingMessageSourceclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofCharacterStreamWritingMessageHandler
- 
Uses of NamedComponent in org.springframework.integration.stream.inboundClasses in org.springframework.integration.stream.inbound that implement NamedComponentModifier and TypeClassDescriptionclassA pollable source for receiving bytes from anInputStream.classA pollable source forReaders.
- 
Uses of NamedComponent in org.springframework.integration.stream.outboundClasses in org.springframework.integration.stream.outbound that implement NamedComponentModifier and TypeClassDescriptionclassAMessageHandlerthat writes a byte array to anOutputStream.classAMessageHandlerthat writes characters to aWriter.
- 
Uses of NamedComponent in org.springframework.integration.support.managementSubinterfaces of NamedComponent in org.springframework.integration.support.managementModifier and TypeInterfaceDescriptioninterfaceMarker interface indicating that thisIntegrationManagementcomponent initiates message flow.interfaceBase interface for Integration managed components.interface
- 
Uses of NamedComponent in org.springframework.integration.support.utilsMethods in org.springframework.integration.support.utils with parameters of type NamedComponentModifier and TypeMethodDescriptionstatic StringIntegrationUtils.obtainComponentName(NamedComponent component) Obtain a component name from the providedNamedComponent.
- 
Uses of NamedComponent in org.springframework.integration.syslog.inboundClasses in org.springframework.integration.syslog.inbound that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.test.mockClasses in org.springframework.integration.test.mock that implement NamedComponentModifier and TypeClassDescriptionclassTheAbstractMessageProducingHandlerextension for the mocking purpose in tests.
- 
Uses of NamedComponent in org.springframework.integration.transactionClasses in org.springframework.integration.transaction that implement NamedComponentModifier and TypeClassDescriptionclassThis implementation ofTransactionSynchronizationFactoryallows you to configure SpEL expressions, with their execution being coordinated (synchronized) with a transaction - seeTransactionSynchronization.
- 
Uses of NamedComponent in org.springframework.integration.transformerClasses in org.springframework.integration.transformer that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.webflux.inboundClasses in org.springframework.integration.webflux.inbound that implement NamedComponentModifier and TypeClassDescriptionclassAMessagingGatewaySupportimplementation for Spring WebFlux HTTP requests execution.
- 
Uses of NamedComponent in org.springframework.integration.webflux.outboundClasses in org.springframework.integration.webflux.outbound that implement NamedComponentModifier and TypeClassDescriptionclassAMessageHandlerimplementation that executes HTTP requests by delegating to a ReactiveWebClientinstance.
- 
Uses of NamedComponent in org.springframework.integration.websocket.inboundClasses in org.springframework.integration.websocket.inbound that implement NamedComponentModifier and TypeClassDescriptionclassTheMessageProducerSupportfor inbound WebSocket messages.
- 
Uses of NamedComponent in org.springframework.integration.websocket.outboundClasses in org.springframework.integration.websocket.outbound that implement NamedComponent
- 
Uses of NamedComponent in org.springframework.integration.wsClasses in org.springframework.integration.ws that implement NamedComponentModifier and TypeClassDescriptionclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofAbstractWebServiceInboundGatewayclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofAbstractWebServiceOutboundGatewayclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofMarshallingWebServiceInboundGatewayclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofMarshallingWebServiceOutboundGatewayclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofSimpleWebServiceInboundGatewayclassDeprecated, for removal: This API element is subject to removal in a future version.since 7.0 in favor ofSimpleWebServiceOutboundGateway
- 
Uses of NamedComponent in org.springframework.integration.ws.inboundClasses in org.springframework.integration.ws.inbound that implement NamedComponentModifier and TypeClassDescriptionclassclassclass
- 
Uses of NamedComponent in org.springframework.integration.ws.outboundClasses in org.springframework.integration.ws.outbound that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.xml.routerClasses in org.springframework.integration.xml.router that implement NamedComponentModifier and TypeClassDescriptionclassMessage Router that usesXPathExpressionevaluation to determine channel names.
- 
Uses of NamedComponent in org.springframework.integration.xml.splitterClasses in org.springframework.integration.xml.splitter that implement NamedComponentModifier and TypeClassDescriptionclassMessage Splitter that uses anXPathExpressionto split aDocument,FileorStringpayload into aNodeList.
- 
Uses of NamedComponent in org.springframework.integration.xml.transformerClasses in org.springframework.integration.xml.transformer that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.xmpp.coreClasses in org.springframework.integration.xmpp.core that implement NamedComponentModifier and TypeClassDescriptionclassclass
- 
Uses of NamedComponent in org.springframework.integration.xmpp.inboundClasses in org.springframework.integration.xmpp.inbound that implement NamedComponentModifier 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 NamedComponent in org.springframework.integration.xmpp.outboundClasses in org.springframework.integration.xmpp.outbound that implement NamedComponentModifier and TypeClassDescriptionclassMessageHandler that sends an XMPP Chat Message.classMessageHandler that publishes updated Presence values for a given XMPP connection.
- 
Uses of NamedComponent in org.springframework.integration.zeromq.channelClasses in org.springframework.integration.zeromq.channel that implement NamedComponentModifier and TypeClassDescriptionclassTheSubscribableChannelimplementation over ZeroMQ sockets.
- 
Uses of NamedComponent in org.springframework.integration.zeromq.inboundClasses in org.springframework.integration.zeromq.inbound that implement NamedComponentModifier and TypeClassDescriptionclassAMessageProducerSupportimplementation for consuming messages from ZeroMq socket.
- 
Uses of NamedComponent in org.springframework.integration.zeromq.outboundClasses in org.springframework.integration.zeromq.outbound that implement NamedComponentModifier and TypeClassDescriptionclassTheAbstractReactiveMessageHandlerimplementation for publishing messages over ZeroMq socket.
- 
Uses of NamedComponent in org.springframework.integration.zip.splitterClasses in org.springframework.integration.zip.splitter that implement NamedComponent
- 
Uses of NamedComponent in org.springframework.integration.zip.transformerClasses in org.springframework.integration.zip.transformer that implement NamedComponentModifier 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.
FileReadingMessageSource