Uses of Interface
org.springframework.integration.support.management.ManageableLifecycle
Packages that use ManageableLifecycle
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 representing various channel types.
Provides classes related to channel interception.
Provides core classes.
Provides classes for the Debezium inbound channel adapters.
Root package of the Spring Integration Java DSL.
Provides core classes related to Endpoints.
Provides classes supporting inbound endpoints.
Base package for File support.
Base package for supporting remote files.
Provides classes supporting the synchronization of remote and
 local file directories.
Classes used for tailing file system files.
Provides classes supporting the filter pattern.
Provides classes supporting inbound endpoints.
Provides classes supporting messaging gateways.
Provides classes implementing various types of message handler.
Provides classes for message handlers support.
Provides classes supporting inbound endpoints.
Provides classes supporting the capture of message history.
Provides classes supporting inbound 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.
Base package for JMS Support.
Base package for JMX support.
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 inbound Spring Integration MqttAdapter components.
Provides Spring Integration components for doing outbound operations.
Provides classes related to Redis-backed channels.
Provides classes supporting inbound endpoints.
Provides classes supporting the router pattern.
Provides classes representing inbound RSocket components.
Provides classes supporting the Scatter-Gather pattern.
Provides classes supporting inbound endpoints.
Inbound Channel Adapters implementations for SMB protocol.
Provides classes supporting the splitter pattern.
Provides classes which represent inbound STOMP components.
Provides classes which represent outbound STOMP components.
Provides classes related to management support.
Provides classes for inbound endpoints.
Contains core-implementation of various Transformers which includes Enrichers and Filters.
Provides classes supporting inbound endpoints.
Provides classes which represent inbound WebSocket components.
Provides several inbound and outbound Web Service components.
Provides classes shared across all XMPP components.
Provides XMPP inbound Endpoint implementations that extend
 
AbstractXmppConnectionAwareEndpoint.Provides classes for inbound channel adapters over ZeroMQ.
Provides classes for outbound channel adapters over ZeroMQ.
- 
Uses of ManageableLifecycle in org.springframework.integration.aggregatorClasses in org.springframework.integration.aggregator that implement ManageableLifecycleModifier and TypeClassDescriptionclassAbstract Message handler that holds a buffer of correlated messages in aMessageStore.classAggregator specific implementation ofAbstractCorrelatingMessageHandler.classTheMessageGroupProcessorimplementation with delegation to the provideddelegateand optional aggregation for headers.classTheAbstractMessageProducingHandlerimplementation for aggregation logic based on Reactor'sFlux.groupBy(java.util.function.Function<? super T, ? extends K>)andFlux.window(int)operators.classCorrelationStrategyimplementation that works as an adapter to another bean.classMessageGroupProcessor that serves as an adapter for the invocation of a POJO method.classA MessageListProcessor implementation that invokes a method on a target POJO.classAReleaseStrategythat invokes a method on a plain old Java object.classResequencer specific implementation ofAbstractCorrelatingMessageHandler.
- 
Uses of ManageableLifecycle in org.springframework.integration.amqp.channelClasses in org.springframework.integration.amqp.channel that implement ManageableLifecycleModifier and TypeClassDescriptionclassTheAbstractSubscribableAmqpChannelimplementation for one-to-one subscription over AMQP queue.classTheAbstractSubscribableAmqpChannelextension for pub-sub semantics based on theFanoutExchange.
- 
Uses of ManageableLifecycle in org.springframework.integration.amqp.inboundClasses in org.springframework.integration.amqp.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassAdapter that receives Messages from an AMQP Queue, converts them into Spring Integration messages and sends the results to a Message Channel.classAdapter that receives Messages from an AMQP Queue, converts them into Spring Integration messages and sends the results to a Message Channel.
- 
Uses of ManageableLifecycle in org.springframework.integration.amqp.outboundClasses in org.springframework.integration.amqp.outbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassA baseAbstractReplyProducingMessageHandlerextension for AMQP message handlers.classAdapter that converts and sends Messages to an AMQP Exchange.classAn outbound gateway where the sending thread is released immediately and the reply is sent on the async template's listener container thread.
- 
Uses of ManageableLifecycle in org.springframework.integration.channelClasses in org.springframework.integration.channel that implement ManageableLifecycleModifier and TypeClassDescriptionclassConverts a channel to a name, retaining a reference to the channel keyed by the name.
- 
Uses of ManageableLifecycle in org.springframework.integration.channel.interceptorClasses in org.springframework.integration.channel.interceptor that implement ManageableLifecycleModifier and TypeClassDescriptionclassAChannelInterceptorthat publishes a copy of the intercepted message to a secondary target while still sending the original message to the main channel.
- 
Uses of ManageableLifecycle in org.springframework.integration.coreSubinterfaces of ManageableLifecycle in org.springframework.integration.coreModifier and TypeInterfaceDescriptioninterfaceEndpoints implementing this interface can be paused/resumed.
- 
Uses of ManageableLifecycle in org.springframework.integration.debezium.inboundClasses in org.springframework.integration.debezium.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassDebezium Change Event Channel Adapter.
- 
Uses of ManageableLifecycle in org.springframework.integration.dslClasses in org.springframework.integration.dsl that implement ManageableLifecycleModifier and TypeClassDescriptionclassThe baseAdapterclass for theIntegrationFlowabstraction.
- 
Uses of ManageableLifecycle in org.springframework.integration.endpointClasses in org.springframework.integration.endpoint that implement ManageableLifecycleModifier and TypeClassDescriptionclassThe base class for Message Endpoint implementations.classAnAbstractEndpointextension for Polling Consumer pattern basics.classMessage Endpoint that connects anyMessageHandlerimplementation to aSubscribableChannel.classAMessageProducerSupportsubclass that provides ExpressionMessageProducerSupport.payloadExpression evaluation with result as a payload for Message to send.classA support class for producer endpoints that provides a setter for the output channel and a convenience method for sending Messages.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 ManageableLifecycle in org.springframework.integration.event.inboundClasses in org.springframework.integration.event.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassAn inbound Channel Adapter that implementsGenericApplicationListenerand passes SpringApplicationEventswithin messages.
- 
Uses of ManageableLifecycle in org.springframework.integration.fileClasses in org.springframework.integration.file that implement ManageableLifecycleModifier and TypeClassDescriptionclassMessageSourcethat creates messages from a file system directory.classAMessageHandlerimplementation that writes the Message payload to a file.
- 
Uses of ManageableLifecycle in org.springframework.integration.file.remoteClasses in org.springframework.integration.file.remote that implement ManageableLifecycleModifier and TypeClassDescriptionclassA message source that produces a message with anInputStreampayload referencing a remote file.
- 
Uses of ManageableLifecycle in org.springframework.integration.file.remote.synchronizerClasses in org.springframework.integration.file.remote.synchronizer that implement ManageableLifecycleModifier and TypeClassDescriptionclassFactors out the common logic between the FTP and SFTP adapters.
- 
Uses of ManageableLifecycle in org.springframework.integration.file.tailClasses in org.springframework.integration.file.tail that implement ManageableLifecycleModifier 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 ManageableLifecycle in org.springframework.integration.filterClasses in org.springframework.integration.filter that implement ManageableLifecycleModifier and TypeClassDescriptionclassA base class forMessageSelectorimplementations that delegate to aMessageProcessor.classAMessageSelectorimplementation that evaluates a SpEL expression.classMessage Handler that delegates to aMessageSelector.classA method-invoking implementation ofMessageSelector.classAMessageSelectorimplementation that evaluates a simple SpEL expression - relies on theSimpleEvaluationContext.
- 
Uses of ManageableLifecycle in org.springframework.integration.ftp.inboundClasses in org.springframework.integration.ftp.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassAMessageSourceimplementation for FTP.classMessage source for streaming FTP remote file contents.
- 
Uses of ManageableLifecycle in org.springframework.integration.gatewayClasses in org.springframework.integration.gateway that implement ManageableLifecycleModifier 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 ManageableLifecycle in org.springframework.integration.handlerClasses in org.springframework.integration.handler that implement ManageableLifecycleModifier and TypeClassDescriptionclassA compositeMessageHandlerimplementation that invokes a chain of MessageHandler instances in order.classAMessageHandlerthat invokes the specified method on the provided object.classA MessageProcessor implementation that invokes a method on a target Object.classTheAbstractReplyProducingMessageHandlerwrapper around rawMessageHandlerfor request-reply scenarios, e.g.classThe standard Service Activator pattern implementation.
- 
Uses of ManageableLifecycle in org.springframework.integration.handler.supportClasses in org.springframework.integration.handler.support that implement ManageableLifecycleModifier and TypeClassDescriptionclassA helper class for processors that invoke a method on a target Object using a combination of message payload(s) and headers as arguments.
- 
Uses of ManageableLifecycle in org.springframework.integration.hazelcast.inboundClasses in org.springframework.integration.hazelcast.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassHazelcast Base Event-Driven Message Producer.classHazelcast Cluster Monitor Event Driven Message Producer is a message producer which enablesHazelcastClusterMonitorMessageProducer.HazelcastClusterMonitorListenerlistener in order to listen cluster related events and sends events to related channel.classHazelcast Continuous Query Message Producer is a message producer which enablesAbstractHazelcastMessageProducer.HazelcastEntryListenerwith aSqlPredicatein order to listen related distributed map events in the light of defined predicate and sends events to related channel.classHazelcast Event Driven Message Producer is a message producer which enablesAbstractHazelcastMessageProducer.HazelcastEntryListener,HazelcastEventDrivenMessageProducer.HazelcastItemListenerandHazelcastEventDrivenMessageProducer.HazelcastMessageListenerlisteners in order to listen related cache events and sends events to related channel.
- 
Uses of ManageableLifecycle in org.springframework.integration.historyClasses in org.springframework.integration.history that implement ManageableLifecycle
- 
Uses of ManageableLifecycle in org.springframework.integration.http.inboundClasses in org.springframework.integration.http.inbound that implement ManageableLifecycleModifier 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 ManageableLifecycle in org.springframework.integration.ipClasses in org.springframework.integration.ip that implement ManageableLifecycleModifier and TypeClassDescriptionclassBase class for inbound TCP/UDP Channel Adapters.classBase class for UDP MessageHandlers.
- 
Uses of ManageableLifecycle in org.springframework.integration.ip.tcpClasses in org.springframework.integration.ip.tcp that implement ManageableLifecycleModifier and TypeClassDescriptionclassInbound Gateway using a server connection factory - threading is controlled by the factory.classTCP outbound gateway that uses a client connection factory.classTcp inbound channel adapter using a TcpConnection to receive data - if the connection factory is a server factory, this Listener owns the connections.classTcp outbound channel adapter using a TcpConnection to send data - if the connection factory is a server factory, the TcpListener owns the connections.
- 
Uses of ManageableLifecycle in org.springframework.integration.ip.tcp.connectionSubinterfaces of ManageableLifecycle in org.springframework.integration.ip.tcp.connectionModifier and TypeInterfaceDescriptioninterfaceA factory used to create TcpConnection objects.Classes in org.springframework.integration.ip.tcp.connection that implement ManageableLifecycleModifier 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 ManageableLifecycle in org.springframework.integration.ip.udpClasses in org.springframework.integration.ip.udp that implement ManageableLifecycleModifier and TypeClassDescriptionclassChannel adapter that joins a multicast group and receives incoming packets and sends them to an output channel.classAMessageHandlerimplementation that maps a Message into a UDP datagram packet and sends that to the specified multicast address (224.0.0.0 to 239.255.255.255) and port.classA channel adapter to receive incoming UDP packets.classAMessageHandlerimplementation that maps a Message into a UDP datagram packet and sends that to the specified host and port.
- 
Uses of ManageableLifecycle in org.springframework.integration.jmsClasses in org.springframework.integration.jms that implement ManageableLifecycleModifier and TypeClassDescriptionclassA wrapper around theJmsMessageDrivenEndpointimplementingMessagingGatewaySupport.classA message-driven endpoint that receive JMS messages, converts them into Spring Integration Messages, and then sends the result to a channel.classAn outbound Messaging Gateway for request/reply JMS.classAnAbstractJmsChannelimplementation for message-driven subscriptions.
- 
Uses of ManageableLifecycle in org.springframework.integration.jmxClasses in org.springframework.integration.jmx that implement ManageableLifecycleModifier and TypeClassDescriptionclassA JMXNotificationListenerimplementation that will send Messages containing the JMXNotificationinstances as their payloads.
- 
Uses of ManageableLifecycle in org.springframework.integration.kafka.channelClasses in org.springframework.integration.kafka.channel that implement ManageableLifecycleModifier and TypeClassDescriptionclassPublish/subscribe channel backed by an Apache Kafka topic.classSubscribable channel backed by an Apache Kafka topic.
- 
Uses of ManageableLifecycle in org.springframework.integration.kafka.inboundClasses in org.springframework.integration.kafka.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassKafkaInboundGateway<K,V, R> Inbound gateway.classMessage-driven channel adapter.classKafkaMessageSource<K,V> Polled message source for Apache Kafka.
- 
Uses of ManageableLifecycle in org.springframework.integration.kafka.outboundClasses in org.springframework.integration.kafka.outbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassA Message Handler for Apache Kafka; when supplied with aReplyingKafkaTemplateit is used as the handler in an outbound gateway.
- 
Uses of ManageableLifecycle in org.springframework.integration.mailClasses in org.springframework.integration.mail that implement ManageableLifecycleModifier and TypeClassDescriptionclassAn event-driven Channel Adapter that receives mail messages from a mail server that supports the IMAP "idle" command (see RFC 2177).
- 
Uses of ManageableLifecycle in org.springframework.integration.mongodb.inboundClasses in org.springframework.integration.mongodb.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassAMessageProducerSupportfor MongoDB Change Stream implementation.
- 
Uses of ManageableLifecycle in org.springframework.integration.mqtt.inboundClasses in org.springframework.integration.mqtt.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassAbstract class for MQTT Message-Driven Channel Adapters.classEclipse Paho Implementation.classTheAbstractMqttMessageDrivenChannelAdapterimplementation for MQTT v5.
- 
Uses of ManageableLifecycle in org.springframework.integration.mqtt.outboundClasses in org.springframework.integration.mqtt.outbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassAbstract class for MQTT outbound channel adapters.classEclipse Paho Implementation.classTheAbstractMqttMessageHandlerimplementation for MQTT v5.
- 
Uses of ManageableLifecycle in org.springframework.integration.redis.channelClasses in org.springframework.integration.redis.channel that implement ManageableLifecycleModifier and TypeClassDescriptionclassAnAbstractMessageChannelimplementation withBroadcastCapableChannelaspect to provide a pub-sub semantics to consume messages fgrom Redis topic.
- 
Uses of ManageableLifecycle in org.springframework.integration.redis.inboundClasses in org.springframework.integration.redis.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassAMessageProducerSupportfor reading messages from a Redis Stream and publishing them into the provided output channel.classclassclass
- 
Uses of ManageableLifecycle in org.springframework.integration.routerClasses in org.springframework.integration.router that implement ManageableLifecycleModifier and TypeClassDescriptionclassA Message Router implementation that evaluates the specified SpEL expression.classA Message Router that invokes the specified method on the given object.
- 
Uses of ManageableLifecycle in org.springframework.integration.rsocket.inboundClasses in org.springframework.integration.rsocket.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassTheMessagingGatewaySupportimplementation for theIntegrationRSocketEndpoint.
- 
Uses of ManageableLifecycle in org.springframework.integration.scattergatherClasses in org.springframework.integration.scattergather that implement ManageableLifecycleModifier and TypeClassDescriptionclassTheMessageHandlerimplementation for the Scatter-Gather EIP pattern.
- 
Uses of ManageableLifecycle in org.springframework.integration.sftp.inboundClasses in org.springframework.integration.sftp.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassAMessageSourceimplementation for SFTP that delegates to an InboundFileSynchronizer.classMessage source for streaming SFTP remote file contents.
- 
Uses of ManageableLifecycle in org.springframework.integration.smb.inboundClasses in org.springframework.integration.smb.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassAMessageSourceimplementation for SMB.classMessage source for streaming SMB remote file contents.
- 
Uses of ManageableLifecycle in org.springframework.integration.splitterClasses in org.springframework.integration.splitter that implement ManageableLifecycleModifier and TypeClassDescriptionclassA Message Splitter implementation that evaluates the specified SpEL expression.classA Message Splitter implementation that invokes the specified method on the given object.
- 
Uses of ManageableLifecycle in org.springframework.integration.stomp.inboundClasses in org.springframework.integration.stomp.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassTheMessageProducerSupportfor STOMP protocol to handle STOMP frames from provided destination and send messages to theoutputChannel.
- 
Uses of ManageableLifecycle in org.springframework.integration.stomp.outboundClasses in org.springframework.integration.stomp.outbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassTheAbstractMessageHandlerimplementation to send messages to STOMP destinations.
- 
Uses of ManageableLifecycle in org.springframework.integration.support.managementSubinterfaces of ManageableLifecycle in org.springframework.integration.support.managementModifier and TypeInterfaceDescriptioninterfaceExtendManageableLifecycleto make those methods manageable.
- 
Uses of ManageableLifecycle in org.springframework.integration.syslog.inboundClasses in org.springframework.integration.syslog.inbound that implement ManageableLifecycleModifier 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 ManageableLifecycle in org.springframework.integration.transformerClasses in org.springframework.integration.transformer that implement ManageableLifecycleModifier and TypeClassDescriptionclassBase class for Message Transformers that delegate to aMessageProcessor.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.classA Message Transformer implementation that evaluates the specified SpEL expression.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.
- 
Uses of ManageableLifecycle in org.springframework.integration.webflux.inboundClasses in org.springframework.integration.webflux.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassAMessagingGatewaySupportimplementation for Spring WebFlux HTTP requests execution.
- 
Uses of ManageableLifecycle in org.springframework.integration.websocket.inboundClasses in org.springframework.integration.websocket.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassTheMessageProducerSupportfor inbound WebSocket messages.
- 
Uses of ManageableLifecycle in org.springframework.integration.wsClasses in org.springframework.integration.ws that implement ManageableLifecycleModifier and TypeClassDescriptionclassclassclass
- 
Uses of ManageableLifecycle in org.springframework.integration.xmpp.coreClasses in org.springframework.integration.xmpp.core that implement ManageableLifecycle
- 
Uses of ManageableLifecycle in org.springframework.integration.xmpp.inboundClasses in org.springframework.integration.xmpp.inbound that implement ManageableLifecycleModifier 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 ManageableLifecycle in org.springframework.integration.zeromq.inboundClasses in org.springframework.integration.zeromq.inbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassAMessageProducerSupportimplementation for consuming messages from ZeroMq socket.
- 
Uses of ManageableLifecycle in org.springframework.integration.zeromq.outboundClasses in org.springframework.integration.zeromq.outbound that implement ManageableLifecycleModifier and TypeClassDescriptionclassTheAbstractReactiveMessageHandlerimplementation for publishing messages over ZeroMq socket.