Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbstractAggregatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
- 
Base class for MessageGroupProcessor implementations that aggregate the group of Messages into a single Message.
- AbstractAggregatingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
- AbstractAmqpChannel - Class in org.springframework.integration.amqp.channel
- 
The baseAbstractMessageChannelimplementation for AMQP.
- AbstractAmqpOutboundEndpoint - Class in org.springframework.integration.amqp.outbound
- 
A baseAbstractReplyProducingMessageHandlerextension for AMQP message handlers.
- AbstractAmqpOutboundEndpoint() - Constructor for class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- AbstractAmqpOutboundEndpoint.CorrelationDataWrapper - Class in org.springframework.integration.amqp.outbound
- AbstractBatchingMessageGroupStore - Class in org.springframework.integration.store
- AbstractBatchingMessageGroupStore() - Constructor for class org.springframework.integration.store.AbstractBatchingMessageGroupStore
- AbstractByteArraySerializer - Class in org.springframework.integration.ip.tcp.serializer
- 
Base class for (de)serializers that provide a mechanism to reconstruct a byte array from an arbitrary stream.
- AbstractByteArraySerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
- AbstractCandidate - Class in org.springframework.integration.leader
- 
Base implementation of aCandidate.
- AbstractCandidate() - Constructor for class org.springframework.integration.leader.AbstractCandidate
- 
Instantiate a abstract candidate.
- AbstractCandidate(String, String) - Constructor for class org.springframework.integration.leader.AbstractCandidate
- 
Instantiate a abstract candidate.
- AbstractChannelAdapterParser - Class in org.springframework.integration.config.xml
- 
Base parser for Channel Adapters.
- AbstractChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.AbstractChannelAdapterParser
- AbstractChannelParser - Class in org.springframework.integration.config.xml
- 
Base class for channel parsers.
- AbstractChannelParser() - Constructor for class org.springframework.integration.config.xml.AbstractChannelParser
- AbstractClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
- 
Abstract class for client connection factories; client connection factories establish outgoing connections.
- AbstractClientConnectionFactory(String, int) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
- 
Construct a factory that will established connections to the host and port.
- AbstractConfigurableMongoDbMessageStore - Class in org.springframework.integration.mongodb.store
- 
The abstract MongoDBAbstractMessageGroupStoreimplementation to provide configuration for common options for implementations of this class.
- AbstractConfigurableMongoDbMessageStore(MongoTemplate, String) - Constructor for class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- AbstractConfigurableMongoDbMessageStore(MongoDatabaseFactory, String) - Constructor for class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- AbstractConfigurableMongoDbMessageStore(MongoDatabaseFactory, MappingMongoConverter, String) - Constructor for class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- AbstractConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
- 
Base class for all connection factories.
- AbstractConnectionFactory(int) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- AbstractConnectionFactory(String, int) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- AbstractConnectionFactorySpec<S,C> - Class in org.springframework.integration.ip.dsl
- AbstractConnectionFactorySpec(C) - Constructor for class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
- AbstractConsumerEndpointParser - Class in org.springframework.integration.config.xml
- 
Base class parser for elements that create Message Endpoints.
- AbstractConsumerEndpointParser() - Constructor for class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
- AbstractCorrelatingMessageHandler - Class in org.springframework.integration.aggregator
- 
Abstract Message handler that holds a buffer of correlated messages in aMessageStore.
- AbstractCorrelatingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- AbstractCorrelatingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- AbstractCorrelatingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- AbstractCorrelatingMessageHandler.SequenceAwareMessageGroup - Class in org.springframework.integration.aggregator
- AbstractCorrelatingMessageHandlerParser - Class in org.springframework.integration.config.xml
- 
Base class for parsers that create an instance ofAbstractCorrelatingMessageHandler.
- AbstractCorrelatingMessageHandlerParser() - Constructor for class org.springframework.integration.config.xml.AbstractCorrelatingMessageHandlerParser
- AbstractDirectoryAwareFileListFilter<F> - Class in org.springframework.integration.file.filters
- 
A file list filter that can be configured to always accept (pass) directories.
- AbstractDirectoryAwareFileListFilter() - Constructor for class org.springframework.integration.file.filters.AbstractDirectoryAwareFileListFilter
- AbstractDispatcher - Class in org.springframework.integration.dispatcher
- 
Base class forMessageDispatcherimplementations.
- AbstractDispatcher() - Constructor for class org.springframework.integration.dispatcher.AbstractDispatcher
- AbstractEndpoint - Class in org.springframework.integration.endpoint
- 
The base class for Message Endpoint implementations.
- AbstractEndpoint() - Constructor for class org.springframework.integration.endpoint.AbstractEndpoint
- AbstractEvaluationContextFactoryBean - Class in org.springframework.integration.config
- 
Abstract class for integration evaluation context factory beans.
- AbstractEvaluationContextFactoryBean() - Constructor for class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
- AbstractExecutorChannel - Class in org.springframework.integration.channel
- 
TheAbstractSubscribableChannelbase implementation for those inheritors which logic may be based on theExecutor.
- AbstractExecutorChannel(Executor) - Constructor for class org.springframework.integration.channel.AbstractExecutorChannel
- AbstractExecutorChannel.MessageHandlingTask - Class in org.springframework.integration.channel
- AbstractExpressionEvaluator - Class in org.springframework.integration.util
- AbstractExpressionEvaluator() - Constructor for class org.springframework.integration.util.AbstractExpressionEvaluator
- AbstractFetchLimitingMessageSource<T> - Class in org.springframework.integration.endpoint
- 
A message source that can limit the number of remote objects it fetches.
- AbstractFetchLimitingMessageSource() - Constructor for class org.springframework.integration.endpoint.AbstractFetchLimitingMessageSource
- AbstractFileInfo<F> - Class in org.springframework.integration.file.remote
- 
Abstract implementation ofFileInfo; provides a setter for the remote directory and a generic toString implementation.
- AbstractFileInfo() - Constructor for class org.springframework.integration.file.remote.AbstractFileInfo
- AbstractFileListFilter<F> - Class in org.springframework.integration.file.filters
- 
A convenience base class for anyFileListFilterwhose criteria can be evaluated against each File in isolation.
- AbstractFileListFilter() - Constructor for class org.springframework.integration.file.filters.AbstractFileListFilter
- AbstractFileLockerFilter - Class in org.springframework.integration.file.locking
- 
Convenience base class for implementing FileLockers that check a lock before accepting a file.
- AbstractFileLockerFilter() - Constructor for class org.springframework.integration.file.locking.AbstractFileLockerFilter
- AbstractFilePayloadTransformer<T> - Class in org.springframework.integration.file.transformer
- 
Base class for transformers that convert a File payload.
- AbstractFilePayloadTransformer() - Constructor for class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
- AbstractFilePayloadTransformerParser - Class in org.springframework.integration.file.config
- 
Base class for File payload transformer parsers.
- AbstractFilePayloadTransformerParser() - Constructor for class org.springframework.integration.file.config.AbstractFilePayloadTransformerParser
- AbstractFtpSessionFactory<T> - Class in org.springframework.integration.ftp.session
- 
Base class for FTP SessionFactory implementations.
- AbstractFtpSessionFactory() - Constructor for class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
- AbstractHandleMessageAdvice - Class in org.springframework.integration.handler.advice
- 
The baseHandleMessageAdvicefor advices which can be applied only for theMessageHandler.handleMessage(Message).
- AbstractHandleMessageAdvice() - Constructor for class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
- AbstractHazelcastEventListener() - Constructor for class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer.AbstractHazelcastEventListener
- AbstractHazelcastMessageProducer - Class in org.springframework.integration.hazelcast.inbound
- 
Hazelcast Base Event-Driven Message Producer.
- AbstractHazelcastMessageProducer(DistributedObject) - Constructor for class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer
- AbstractHazelcastMessageProducer.AbstractHazelcastEventListener<E> - Class in org.springframework.integration.hazelcast.inbound
- 
A base event listener abstraction.
- AbstractHazelcastMessageProducer.HazelcastEntryListener<K,V> - Class in org.springframework.integration.hazelcast.inbound
- 
TheAbstractHazelcastMessageProducer.AbstractHazelcastEventListenerimplementation for theAbstractIMapEvents.
- AbstractHeaderMapper<T> - Class in org.springframework.integration.mapping
- 
Abstract base class forRequestReplyHeaderMapperimplementations.
- AbstractHeaderMapper(String, Collection<String>, Collection<String>) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper
- 
Create a new instance.
- AbstractHeaderMapper.CompositeHeaderMatcher - Class in org.springframework.integration.mapping
- 
A compositeAbstractHeaderMapper.HeaderMatcherthat matches if one of providedAbstractHeaderMapper.HeaderMatchers matches to theheaderName.
- AbstractHeaderMapper.ContentBasedHeaderMatcher - Class in org.springframework.integration.mapping
- 
A content-basedAbstractHeaderMapper.HeaderMatcherthat matches if the specified header is contained within a list of candidates.
- AbstractHeaderMapper.HeaderMatcher - Interface in org.springframework.integration.mapping
- 
Strategy interface to determine if a given header name matches.
- AbstractHeaderMapper.PatternBasedHeaderMatcher - Class in org.springframework.integration.mapping
- 
A pattern-basedAbstractHeaderMapper.HeaderMatcherthat matches if the specified header matches one of the specified simple patterns.
- AbstractHeaderMapper.PrefixBasedMatcher - Class in org.springframework.integration.mapping
- 
A prefix-basedAbstractHeaderMapper.HeaderMatcherthat matches if the specified header starts with a configurable prefix.
- AbstractHeaderMapper.SinglePatternBasedHeaderMatcher - Class in org.springframework.integration.mapping
- 
A pattern-basedAbstractHeaderMapper.HeaderMatcherthat matches if the specified header matches the specified simple pattern.
- AbstractHeaderValueMessageProcessor<T> - Class in org.springframework.integration.transformer.support
- AbstractHeaderValueMessageProcessor() - Constructor for class org.springframework.integration.transformer.support.AbstractHeaderValueMessageProcessor
- AbstractHttpRequestExecutingMessageHandler - Class in org.springframework.integration.http.outbound
- 
Base class for http outbound adapter/gateway.
- AbstractHttpRequestExecutingMessageHandler(Expression) - Constructor for class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
- AbstractInboundFileSynchronizer<F> - Class in org.springframework.integration.file.remote.synchronizer
- 
Base class charged with knowing how to connect to a remote file system, scan it for new files and then download the files.
- AbstractInboundFileSynchronizer(SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
- 
Create a synchronizer with theSessionFactoryused to acquireSessioninstances.
- AbstractInboundFileSynchronizingMessageSource<F> - Class in org.springframework.integration.file.remote.synchronizer
- 
Factors out the common logic between the FTP and SFTP adapters.
- AbstractInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<F>) - Constructor for class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
- AbstractInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<F>, Comparator<File>) - Constructor for class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
- AbstractInboundGatewayParser - Class in org.springframework.integration.config.xml
- 
Base class for inbound gateway parsers.
- AbstractInboundGatewayParser() - Constructor for class org.springframework.integration.config.xml.AbstractInboundGatewayParser
- AbstractIntegrationMessageBuilder<T> - Class in org.springframework.integration.support
- AbstractIntegrationMessageBuilder() - Constructor for class org.springframework.integration.support.AbstractIntegrationMessageBuilder
- AbstractIntegrationNamespaceHandler - Class in org.springframework.integration.config.xml
- 
Base class for NamespaceHandlers that registers a BeanFactoryPostProcessor for configuring default bean definitions.
- AbstractIntegrationNamespaceHandler() - Constructor for class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
- AbstractInternetProtocolReceivingChannelAdapter - Class in org.springframework.integration.ip
- 
Base class for inbound TCP/UDP Channel Adapters.
- AbstractInternetProtocolReceivingChannelAdapter(int) - Constructor for class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
- AbstractInternetProtocolSendingMessageHandler - Class in org.springframework.integration.ip
- 
Base class for UDP MessageHandlers.
- AbstractInternetProtocolSendingMessageHandler(String, int) - Constructor for class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
- AbstractJacksonJsonObjectMapper<N,P, - Class in org.springframework.integration.support.jsonJ> 
- 
Base class for JacksonJsonObjectMapperimplementations.
- AbstractJacksonJsonObjectMapper() - Constructor for class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
- AbstractJmsChannel - Class in org.springframework.integration.jms
- 
A baseAbstractMessageChannelimplementation for JMS-backed message channels.
- AbstractJmsChannel(JmsTemplate) - Constructor for class org.springframework.integration.jms.AbstractJmsChannel
- AbstractJpaOutboundGatewayParser - Class in org.springframework.integration.jpa.config.xml
- 
The Abstract Parser for the JPA Outbound Gateways.
- AbstractJpaOutboundGatewayParser() - Constructor for class org.springframework.integration.jpa.config.xml.AbstractJpaOutboundGatewayParser
- AbstractJsonInboundMessageMapper<P> - Class in org.springframework.integration.support.json
- 
AbstractInboundMessageMapperimplementation that maps incoming JSON messages to aMessagewith the specified payload type.
- AbstractJsonInboundMessageMapper(Type) - Constructor for class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
- AbstractKafkaChannel - Class in org.springframework.integration.kafka.channel
- 
Abstract MessageChannel backed by an Apache Kafka topic.
- AbstractKafkaChannel(KafkaOperations<?, ?>, String) - Constructor for class org.springframework.integration.kafka.channel.AbstractKafkaChannel
- 
Construct an instance with the providedKafkaOperationsand topic.
- AbstractKafkaChannelSpec<S,C> - Class in org.springframework.integration.kafka.dsl
- 
Spec for a message channel backed by an Apache Kafka topic.
- AbstractKafkaChannelSpec() - Constructor for class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
- AbstractKeyValueMessageStore - Class in org.springframework.integration.store
- 
Base class for implementations of Key/Value styleMessageGroupStoreandMessageStore.
- AbstractKeyValueMessageStore() - Constructor for class org.springframework.integration.store.AbstractKeyValueMessageStore
- AbstractKeyValueMessageStore(String) - Constructor for class org.springframework.integration.store.AbstractKeyValueMessageStore
- 
Construct an instance based on the provided prefix for keys to distinguish between different store instances in the same target key-value database.
- AbstractKryoCodec - Class in org.springframework.integration.codec.kryo
- 
Base class forCodecs usingKryo.
- AbstractKryoCodec() - Constructor for class org.springframework.integration.codec.kryo.AbstractKryoCodec
- AbstractKryoRegistrar - Class in org.springframework.integration.codec.kryo
- 
Base class forKryoRegistrarimplementations.
- AbstractKryoRegistrar() - Constructor for class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
- AbstractLastModifiedFileListFilter<F> - Class in org.springframework.integration.file.filters
- 
TheFileListFilterimplementation to filter those files which lastModified is less than theAbstractLastModifiedFileListFilter.agein comparison with theInstant.now().
- AbstractLastModifiedFileListFilter() - Constructor for class org.springframework.integration.file.filters.AbstractLastModifiedFileListFilter
- AbstractLastModifiedFileListFilter(Duration) - Constructor for class org.springframework.integration.file.filters.AbstractLastModifiedFileListFilter
- AbstractLeaderEvent - Class in org.springframework.integration.leader.event
- 
BaseApplicationEventclass for leader based events.
- AbstractLeaderEvent(Object) - Constructor for class org.springframework.integration.leader.event.AbstractLeaderEvent
- 
Create a new ApplicationEvent.
- AbstractLeaderEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.AbstractLeaderEvent
- 
Create a new ApplicationEvent.
- AbstractMailMessageTransformer<T> - Class in org.springframework.integration.mail.transformer
- 
Base class for Transformers that convert from a JavaMail Message to a Spring Integration Message.
- AbstractMailMessageTransformer() - Constructor for class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
- AbstractMailReceiver - Class in org.springframework.integration.mail
- 
Base class forMailReceiverimplementations.
- AbstractMailReceiver() - Constructor for class org.springframework.integration.mail.AbstractMailReceiver
- AbstractMailReceiver(URLName) - Constructor for class org.springframework.integration.mail.AbstractMailReceiver
- AbstractMailReceiver(String) - Constructor for class org.springframework.integration.mail.AbstractMailReceiver
- AbstractMappingMessageRouter - Class in org.springframework.integration.router
- 
Base class for all Message Routers that support mapping from arbitrary String values to Message Channel names.
- AbstractMappingMessageRouter() - Constructor for class org.springframework.integration.router.AbstractMappingMessageRouter
- AbstractMarkerFilePresentFileListFilter<F> - Class in org.springframework.integration.file.filters
- 
A FileListFilter that only passes files matched by one or moreFileListFilterif a corresponding marker file is also present to indicate a file transfer is complete.
- AbstractMarkerFilePresentFileListFilter(Map<FileListFilter<F>, Function<String, String>>) - Constructor for class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
- 
Construct an instance with a map ofFileListFilterand functions be applied to the name of a matched file when looking for the marker file.
- AbstractMarkerFilePresentFileListFilter(FileListFilter<F>) - Constructor for class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
- 
Construct an instance with a singleFileListFilterand ".complete" will be appended to the name of a matched file when looking for the marker file.
- AbstractMarkerFilePresentFileListFilter(FileListFilter<F>, String) - Constructor for class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
- 
Construct an instance with a singleFileListFilterand a suffix that will will be appended to the name of a matched file when looking for the marker file.
- AbstractMarkerFilePresentFileListFilter(FileListFilter<F>, Function<String, String>) - Constructor for class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
- 
Construct an instance with a singleFileListFilterand a function that will be applied to the name of a matched file when looking for the marker file.
- AbstractMessageChannel - Class in org.springframework.integration.channel
- 
Base class forMessageChannelimplementations providing common properties such as the channel name.
- AbstractMessageChannel() - Constructor for class org.springframework.integration.channel.AbstractMessageChannel
- AbstractMessageChannel.ChannelInterceptorList - Class in org.springframework.integration.channel
- 
A convenience wrapper class for the list of ChannelInterceptors.
- AbstractMessageGroupStore - Class in org.springframework.integration.store
- AbstractMessageGroupStore() - Constructor for class org.springframework.integration.store.AbstractMessageGroupStore
- AbstractMessageGroupStore(boolean) - Constructor for class org.springframework.integration.store.AbstractMessageGroupStore
- AbstractMessageHandler - Class in org.springframework.integration.handler
- 
Base class forMessageHandlerimplementations.
- AbstractMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractMessageHandler
- AbstractMessageListenerContainerSpec<S,C> - Class in org.springframework.integration.amqp.dsl
- 
Base class for container specs for containers that extendAbstractMessageListenerContainer.
- AbstractMessageListenerContainerSpec(C) - Constructor for class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- AbstractMessageProcessingSelector - Class in org.springframework.integration.filter
- 
A base class forMessageSelectorimplementations that delegate to aMessageProcessor.
- AbstractMessageProcessingSelector(MessageProcessor<Boolean>) - Constructor for class org.springframework.integration.filter.AbstractMessageProcessingSelector
- AbstractMessageProcessingTransformer - Class in org.springframework.integration.transformer
- 
Base class for Message Transformers that delegate to aMessageProcessor.
- AbstractMessageProcessingTransformer(MessageProcessor<?>) - Constructor for class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
- AbstractMessageProcessor<T> - Class in org.springframework.integration.handler
- AbstractMessageProcessor() - Constructor for class org.springframework.integration.handler.AbstractMessageProcessor
- AbstractMessageProducingHandler - Class in org.springframework.integration.handler
- 
The baseAbstractMessageHandlerimplementation for theMessageProducer.
- AbstractMessageProducingHandler() - Constructor for class org.springframework.integration.handler.AbstractMessageProducingHandler
- AbstractMessageRouter - Class in org.springframework.integration.router
- 
Base class for all Message Routers.
- AbstractMessageRouter() - Constructor for class org.springframework.integration.router.AbstractMessageRouter
- AbstractMessageSource<T> - Class in org.springframework.integration.endpoint
- 
Abstract message source.
- AbstractMessageSource() - Constructor for class org.springframework.integration.endpoint.AbstractMessageSource
- AbstractMessageSplitter - Class in org.springframework.integration.splitter
- 
Base class for Message-splitting handlers.
- AbstractMessageSplitter() - Constructor for class org.springframework.integration.splitter.AbstractMessageSplitter
- AbstractMeter(MeterRegistry) - Constructor for class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.AbstractMeter
- AbstractMethodAnnotationPostProcessor<T> - Class in org.springframework.integration.config
- 
Base class for Method-level annotation post-processors.
- AbstractMethodAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- AbstractMethodAnnotationPostProcessor.BeanDefinitionPropertiesMapper - Record Class in org.springframework.integration.config
- AbstractMongoDbMessageSource<T> - Class in org.springframework.integration.mongodb.inbound
- 
AnAbstractMessageSourceextension for common MongoDB sources options and support methods.
- AbstractMongoDbMessageSource(Expression) - Constructor for class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
- AbstractMongoDbMessageSourceSpec<S,H> - Class in org.springframework.integration.mongodb.dsl
- 
AMessageSourceSpecextension for common MongoDB sources options.
- AbstractMongoDbMessageSourceSpec() - Constructor for class org.springframework.integration.mongodb.dsl.AbstractMongoDbMessageSourceSpec
- AbstractMqttClientManager<T,C> - Class in org.springframework.integration.mqtt.core
- 
Abstract class for MQTT client managers which can be a base for any common v3/v5 client manager implementation.
- AbstractMqttClientManager(String) - Constructor for class org.springframework.integration.mqtt.core.AbstractMqttClientManager
- AbstractMqttMessageDrivenChannelAdapter<T,C> - Class in org.springframework.integration.mqtt.inbound
- 
Abstract class for MQTT Message-Driven Channel Adapters.
- AbstractMqttMessageDrivenChannelAdapter(String, String, String...) - Constructor for class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
- AbstractMqttMessageDrivenChannelAdapter(ClientManager<T, C>, String...) - Constructor for class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
- AbstractMqttMessageHandler<T,C> - Class in org.springframework.integration.mqtt.outbound
- 
Abstract class for MQTT outbound channel adapters.
- AbstractMqttMessageHandler(String, String) - Constructor for class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
- AbstractMqttMessageHandler(ClientManager<T, C>) - Constructor for class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
- AbstractOutboundChannelAdapterParser - Class in org.springframework.integration.config.xml
- 
Base class for outbound Channel Adapter parsers.
- AbstractOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
- AbstractOutboundGatewayParser - Class in org.springframework.integration.config.xml
- 
Base class for url-based outbound gateway parsers.
- AbstractOutboundGatewayParser() - Constructor for class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
- AbstractPayloadTransformer<T,U> - Class in org.springframework.integration.transformer
- 
A base class forTransformerimplementations that modify the payload of aMessage.
- AbstractPayloadTransformer() - Constructor for class org.springframework.integration.transformer.AbstractPayloadTransformer
- AbstractPersistentAcceptOnceFileListFilter<F> - Class in org.springframework.integration.file.filters
- 
Stores "seen" files in a MetadataStore to survive application restarts.
- AbstractPersistentAcceptOnceFileListFilter(ConcurrentMetadataStore, String) - Constructor for class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- AbstractPollableChannel - Class in org.springframework.integration.channel
- 
Base class for all pollable channels.
- AbstractPollableChannel() - Constructor for class org.springframework.integration.channel.AbstractPollableChannel
- AbstractPollingEndpoint - Class in org.springframework.integration.endpoint
- 
AnAbstractEndpointextension for Polling Consumer pattern basics.
- AbstractPollingEndpoint() - Constructor for class org.springframework.integration.endpoint.AbstractPollingEndpoint
- AbstractPollingInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
- 
Base parser for inbound Channel Adapters that poll a source.
- AbstractPollingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.AbstractPollingInboundChannelAdapterParser
- AbstractPooledBufferByteArraySerializer - Class in org.springframework.integration.ip.tcp.serializer
- 
Base class for deserializers that cannot determine the buffer size needed.
- AbstractPooledBufferByteArraySerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
- AbstractReactiveMessageHandler - Class in org.springframework.integration.handler
- 
Base class forReactiveMessageHandlerimplementations.
- AbstractReactiveMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractReactiveMessageHandler
- AbstractRecentFileListFilter<F> - Class in org.springframework.integration.file.filters
- 
TheFileListFilterto accept only files which are recent according to providedage: thelastModifiedof the file is more than the age in comparison with the current time.
- AbstractRecentFileListFilter() - Constructor for class org.springframework.integration.file.filters.AbstractRecentFileListFilter
- 
Construct an instance with default age as 1 day.
- AbstractRecentFileListFilter(Duration) - Constructor for class org.springframework.integration.file.filters.AbstractRecentFileListFilter
- AbstractRegexPatternFileListFilter<F> - Class in org.springframework.integration.file.filters
- 
Filters a listing of files by qualifying their 'name' against a regular expression (an instance ofPattern).
- AbstractRegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
- AbstractRegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
- AbstractRemoteFileInboundChannelAdapterParser - Class in org.springframework.integration.file.config
- 
Abstract base class for parsing remote file inbound channel adapters.
- AbstractRemoteFileInboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
- AbstractRemoteFileOutboundGateway<F> - Class in org.springframework.integration.file.remote.gateway
- 
Base class for Outbound Gateways that perform remote file operations.
- AbstractRemoteFileOutboundGateway(RemoteFileTemplate<F>, String, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- 
Construct an instance with the supplied remote file template, a command ('ls', 'get' etc.), and an expression to determine the remote path (file or directory).
- AbstractRemoteFileOutboundGateway(RemoteFileTemplate<F>, AbstractRemoteFileOutboundGateway.Command, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- 
Construct an instance with the supplied remote file template, a command ('ls', 'get' etc.), and an expression to determine the remote path (file or directory).
- AbstractRemoteFileOutboundGateway(RemoteFileTemplate<F>, MessageSessionCallback<F, ?>) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- 
Construct an instance with the supplied remote file template and callback for performing operations on the session.
- AbstractRemoteFileOutboundGateway(SessionFactory<F>, String, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- 
Construct an instance with the supplied session factory, a command ('ls', 'get' etc.), and an expression to determine the remote path (file or directory).
- AbstractRemoteFileOutboundGateway(SessionFactory<F>, AbstractRemoteFileOutboundGateway.Command, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- 
Construct an instance with the supplied session factory, a command ('ls', 'get' etc.), and an expression to determine the remote path (file or directory).
- AbstractRemoteFileOutboundGateway(SessionFactory<F>, MessageSessionCallback<F, ?>) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- 
Construct an instance using the provided session factory and callback for performing operations on the session.
- AbstractRemoteFileOutboundGateway.Command - Enum Class in org.springframework.integration.file.remote.gateway
- 
Enumeration of commands supported by the gateways.
- AbstractRemoteFileOutboundGateway.Option - Enum Class in org.springframework.integration.file.remote.gateway
- 
Enumeration of options supported by various commands.
- AbstractRemoteFileOutboundGatewayParser - Class in org.springframework.integration.file.config
- AbstractRemoteFileOutboundGatewayParser() - Constructor for class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
- AbstractRemoteFileStreamingInboundChannelAdapterParser - Class in org.springframework.integration.file.config
- 
Abstract base class for parsing remote file streaming inbound channel adapters.
- AbstractRemoteFileStreamingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
- AbstractRemoteFileStreamingMessageSource<F> - Class in org.springframework.integration.file.remote
- 
A message source that produces a message with anInputStreampayload referencing a remote file.
- AbstractRemoteFileStreamingMessageSource(RemoteFileTemplate<? extends F>, Comparator<? extends F>) - Constructor for class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
- AbstractReplyProducingMessageHandler - Class in org.springframework.integration.handler
- 
Base class for MessageHandlers that are capable of producing replies.
- AbstractReplyProducingMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
- AbstractReplyProducingMessageHandler.RequestHandler - Interface in org.springframework.integration.handler
- 
An implementation of this interface is used to wrap theAbstractReplyProducingMessageHandler.handleRequestMessage(Message)method.
- AbstractReplyProducingPostProcessingMessageHandler - Class in org.springframework.integration.handler
- AbstractReplyProducingPostProcessingMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
- AbstractRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
- 
Base class forMessageHandleradvice classes.
- AbstractRequestHandlerAdvice() - Constructor for class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
- AbstractRequestHandlerAdvice.ExecutionCallback - Interface in org.springframework.integration.handler.advice
- 
Called by subclasses in doInvoke() to proceed() the invocation.
- AbstractRequestHandlerAdvice.ThrowableHolderException - Exception Class in org.springframework.integration.handler.advice
- AbstractRequestResponseScenarioTests - Class in org.springframework.integration.test.support
- 
Convenience class for testing Spring Integration request-response message scenarios.
- AbstractRequestResponseScenarioTests() - Constructor for class org.springframework.integration.test.support.AbstractRequestResponseScenarioTests
- AbstractResponseValidator<T> - Class in org.springframework.integration.test.support
- 
The base class for response validators used forRequestResponseScenarios
- AbstractResponseValidator() - Constructor for class org.springframework.integration.test.support.AbstractResponseValidator
- AbstractRouterParser - Class in org.springframework.integration.config.xml
- 
Base parser for routers.
- AbstractRouterParser() - Constructor for class org.springframework.integration.config.xml.AbstractRouterParser
- AbstractRouterSpec<S,R> - Class in org.springframework.integration.dsl
- AbstractRouterSpec(R) - Constructor for class org.springframework.integration.dsl.AbstractRouterSpec
- AbstractRSocketConnector - Class in org.springframework.integration.rsocket
- 
A base connector container for common RSocket client and server functionality.
- AbstractRSocketConnector(IntegrationRSocketMessageHandler) - Constructor for class org.springframework.integration.rsocket.AbstractRSocketConnector
- AbstractScriptExecutingMessageProcessor<T> - Class in org.springframework.integration.scripting
- 
BaseMessageProcessorfor scripting implementations to extend.
- AbstractScriptExecutingMessageProcessor() - Constructor for class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
- AbstractScriptExecutingMessageProcessor(ScriptVariableGenerator) - Constructor for class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
- AbstractScriptExecutor - Class in org.springframework.integration.scripting.jsr223
- 
Base Class forScriptExecutor.
- AbstractScriptExecutor(String) - Constructor for class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
- AbstractScriptExecutor(ScriptEngine) - Constructor for class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
- AbstractScriptParser - Class in org.springframework.integration.scripting.config
- AbstractScriptParser() - Constructor for class org.springframework.integration.scripting.config.AbstractScriptParser
- AbstractServerConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
- 
Base class for all server connection factories.
- AbstractServerConnectionFactory(int) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
- 
The port on which the factory will listen.
- AbstractSimpleMessageHandlerFactoryBean<H> - Class in org.springframework.integration.config
- 
Factory bean to create and configure aMessageHandler.
- AbstractSimpleMessageHandlerFactoryBean() - Constructor for class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
- AbstractSimplePatternFileListFilter<F> - Class in org.springframework.integration.file.filters
- 
Base class for filters that support ant style path expressions, which are less powerful but more readable than regular expressions.
- AbstractSimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.AbstractSimplePatternFileListFilter
- AbstractStandardMessageHandlerFactoryBean - Class in org.springframework.integration.config
- 
Base class for FactoryBeans that create standard MessageHandler instances.
- AbstractStandardMessageHandlerFactoryBean() - Constructor for class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
- AbstractStompSessionManager - Class in org.springframework.integration.stomp
- 
BaseStompSessionManagerimplementation to manage a singleStompSessionover itsCompletableFuturefrom the target implementation of this class.
- AbstractStompSessionManager(StompClientSupport) - Constructor for class org.springframework.integration.stomp.AbstractStompSessionManager
- AbstractSubscribableChannel - Class in org.springframework.integration.channel
- 
Base implementation ofMessageChannelthat invokes the subscribedhandler(s)by delegating to aMessageDispatcher.
- AbstractSubscribableChannel() - Constructor for class org.springframework.integration.channel.AbstractSubscribableChannel
- AbstractTcpConnectionSupport - Class in org.springframework.integration.ip.tcp.connection
- 
Base class for TCP Connection Support implementations.
- AbstractTcpConnectionSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionSupport
- AbstractTransformer - Class in org.springframework.integration.transformer
- 
A base class forTransformerimplementations.
- AbstractTransformer() - Constructor for class org.springframework.integration.transformer.AbstractTransformer
- AbstractTransformerParser - Class in org.springframework.integration.config.xml
- AbstractTransformerParser() - Constructor for class org.springframework.integration.config.xml.AbstractTransformerParser
- AbstractUdpOutboundChannelAdapterSpec<S> - Class in org.springframework.integration.ip.dsl
- 
AMessageHandlerSpecfor UDPMessageHandlers.
- AbstractUdpOutboundChannelAdapterSpec() - Constructor for class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
- AbstractUdpOutboundChannelAdapterSpec(String) - Constructor for class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
- AbstractUdpOutboundChannelAdapterSpec(String, int) - Constructor for class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
- AbstractUdpOutboundChannelAdapterSpec(Function<Message<?>, ?>) - Constructor for class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
- AbstractWebServiceInboundGateway - Class in org.springframework.integration.ws
- AbstractWebServiceInboundGateway() - Constructor for class org.springframework.integration.ws.AbstractWebServiceInboundGateway
- AbstractWebServiceOutboundGateway - Class in org.springframework.integration.ws
- 
Base class for outbound Web Service-invoking Messaging Gateways.
- AbstractWebServiceOutboundGateway(String, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
- AbstractWebServiceOutboundGateway(DestinationProvider, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
- AbstractWebServiceOutboundGateway.RequestMessageCallback - Class in org.springframework.integration.ws
- AbstractWebServiceOutboundGateway.ResponseMessageExtractor - Class in org.springframework.integration.ws
- AbstractXmlTransformer - Class in org.springframework.integration.xml.transformer
- 
Super class for XML transformers.
- AbstractXmlTransformer() - Constructor for class org.springframework.integration.xml.transformer.AbstractXmlTransformer
- AbstractXmppConnectionAwareEndpoint - Class in org.springframework.integration.xmpp.core
- AbstractXmppConnectionAwareEndpoint() - Constructor for class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
- AbstractXmppConnectionAwareEndpoint(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
- AbstractXmppConnectionAwareMessageHandler - Class in org.springframework.integration.xmpp.core
- AbstractXmppConnectionAwareMessageHandler() - Constructor for class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
- AbstractXmppConnectionAwareMessageHandler(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
- AbstractXmppInboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
- 
Base class for XMPP inbound parsers
- AbstractXmppInboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
- AbstractXmppOutboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
- 
Base class of XMPP outbound parsers
- AbstractXmppOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.AbstractXmppOutboundChannelAdapterParser
- AbstractXPathMessageSelector - Class in org.springframework.integration.xml.selector
- 
Base class for XPathMessageSelectorimplementations.
- AbstractXPathMessageSelector(String) - Constructor for class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
- AbstractXPathMessageSelector(String, String, String) - Constructor for class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
- AbstractXPathMessageSelector(String, Map<String, String>) - Constructor for class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
- AbstractXPathMessageSelector(XPathExpression) - Constructor for class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
- AbstractZipTransformer - Class in org.springframework.integration.zip.transformer
- 
Base class for transformers that provide Zip compression.
- AbstractZipTransformer() - Constructor for class org.springframework.integration.zip.transformer.AbstractZipTransformer
- AbstractZipTransformerParser - Class in org.springframework.integration.zip.config.xml
- 
Base class for Zip transformer parsers.
- AbstractZipTransformerParser() - Constructor for class org.springframework.integration.zip.config.xml.AbstractZipTransformerParser
- accept(F) - Method in class org.springframework.integration.file.filters.AbstractFileListFilter
- 
Subclasses must implement this method.
- accept(F) - Method in class org.springframework.integration.file.filters.AbstractLastModifiedFileListFilter
- accept(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- accept(F) - Method in class org.springframework.integration.file.filters.AbstractRecentFileListFilter
- accept(F) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
- accept(F) - Method in class org.springframework.integration.file.filters.AbstractSimplePatternFileListFilter
- 
Accept the given file if its name matches the pattern.
- accept(F) - Method in class org.springframework.integration.file.filters.AcceptAllFileListFilter
- accept(F) - Method in class org.springframework.integration.file.filters.AcceptOnceFileListFilter
- accept(F) - Method in class org.springframework.integration.file.filters.ChainFileListFilter
- accept(F) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
- accept(F) - Method in class org.springframework.integration.file.filters.ExpressionFileListFilter
- accept(F) - Method in interface org.springframework.integration.file.filters.FileListFilter
- 
Filter a single file; only called externally ifFileListFilter.supportsSingleFileFiltering()returns true.
- accept(File) - Method in class org.springframework.integration.file.filters.IgnoreHiddenFileListFilter
- accept(File) - Method in class org.springframework.integration.file.locking.AbstractFileLockerFilter
- accept(ObjectName, String) - Method in class org.springframework.integration.jmx.DefaultMBeanAttributeFilter
- accept(ObjectName, String) - Method in interface org.springframework.integration.jmx.MBeanAttributeFilter
- accept(ObjectName, String) - Method in class org.springframework.integration.jmx.NamedFieldsMBeanAttributeFilter
- accept(ObjectName, String) - Method in class org.springframework.integration.jmx.NotNamedFieldsMBeanAttributeFilter
- accept(ConsumerRecord<?, ?>, Exception) - Method in class org.springframework.integration.kafka.inbound.KafkaErrorSendingMessageRecoverer
- accept(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
- 
ACCEPT the associated message if the callback is not null.
- accept(Message<?>) - Method in interface org.springframework.integration.core.MessageSelector
- accept(Message<?>) - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
- accept(Message<?>) - Method in class org.springframework.integration.router.RecipientListRouter.Recipient
- accept(Message<?>) - Method in class org.springframework.integration.selector.MessageSelectorChain
- 
Pass the message through the selector chain.
- accept(Message<?>) - Method in class org.springframework.integration.selector.MetadataStoreSelector
- accept(Message<?>) - Method in class org.springframework.integration.selector.PayloadTypeSelector
- accept(Message<?>) - Method in class org.springframework.integration.selector.UnexpiredMessageSelector
- accept(Message<?>) - Method in class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
- 
Return true if theXPathExpressionevaluates totrue
- accept(Message<?>) - Method in class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
- 
Evaluate the payload and return true if the value returned by theXPathExpressionmatches theregex.
- accept(Message<?>) - Method in class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
- 
Evaluate the payload and return true if the value returned by theXPathExpressionis equal to thevalueToTestFor.
- accept(Message<?>) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
- accept(S) - Method in interface org.springframework.integration.core.GenericSelector
- ACCEPT - Enum constant in enum class org.springframework.integration.acks.AcknowledgmentCallback.Status
- 
Mark the message as accepted.
- AcceptAllFileListFilter<F> - Class in org.springframework.integration.file.filters
- 
Simple implementation ofFileListFilterthat always returns true.
- AcceptAllFileListFilter() - Constructor for class org.springframework.integration.file.filters.AcceptAllFileListFilter
- acceptIfCondition(boolean, T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.integration.JavaUtils
- 
InvokeBiConsumer.accept(Object, Object)with the arguments if the condition is true.
- acceptIfCondition(boolean, T, Consumer<T>) - Method in class org.springframework.integration.JavaUtils
- 
InvokeConsumer.accept(Object)with the value if the condition is true.
- acceptIfHasText(String, Consumer<String>) - Method in class org.springframework.integration.JavaUtils
- 
InvokeConsumer.accept(Object)with the value if it is not null or empty.
- acceptIfHasText(T, String, BiConsumer<T, String>) - Method in class org.springframework.integration.JavaUtils
- 
InvokeBiConsumer.accept(Object, Object)with the arguments if the value argument is not null or empty.
- acceptIfNotEmpty(List<T>, Consumer<List<T>>) - Method in class org.springframework.integration.JavaUtils
- 
InvokeConsumer.accept(Object)with the value if it is not null or empty.
- acceptIfNotEmpty(T[], Consumer<T[]>) - Method in class org.springframework.integration.JavaUtils
- 
InvokeConsumer.accept(Object)with the value if it is not null or empty.
- acceptIfNotNull(T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.integration.JavaUtils
- 
InvokeBiConsumer.accept(Object, Object)with the arguments if the t2 argument is not null.
- acceptIfNotNull(T, Consumer<T>) - Method in class org.springframework.integration.JavaUtils
- 
InvokeConsumer.accept(Object)with the value if it is not null.
- acceptMessagesWhileStopping(boolean) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
- acceptMessagesWhileStopping(boolean) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
- AcceptOnceCollectionFilter<T> - Class in org.springframework.integration.util
- 
An implementation ofCollectionFilterthat remembers the elements passed in the previous invocation in order to avoid returning those elements more than once.
- AcceptOnceCollectionFilter() - Constructor for class org.springframework.integration.util.AcceptOnceCollectionFilter
- AcceptOnceFileListFilter<F> - Class in org.springframework.integration.file.filters
- 
FileListFilterthat passes files only one time.
- AcceptOnceFileListFilter() - Constructor for class org.springframework.integration.file.filters.AcceptOnceFileListFilter
- 
Creates an AcceptOnceFileListFilter based on an unbounded queue.
- AcceptOnceFileListFilter(int) - Constructor for class org.springframework.integration.file.filters.AcceptOnceFileListFilter
- 
Creates an AcceptOnceFileListFilter that is based on a bounded queue.
- ACK - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
- ACK_ADDRESS - Static variable in class org.springframework.integration.ip.IpHeaders
- 
The remote ip address to which UDP application-level acks will be sent.
- ACK_ID - Static variable in class org.springframework.integration.ip.IpHeaders
- 
A correlation id for UDP application-level acks.
- ackCount(int) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
- 
Set the number of outstanding record count after which offsets should be committed whenContainerProperties.AckMode.COUNTorContainerProperties.AckMode.COUNT_TIMEis being used.
- ackCounter(int) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
- ackDiscarded(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
- 
Abooleanflag to indicate ifFilteringMessageListenerAdaptershould acknowledge discarded records or not.
- ackMode(ContainerProperties.AckMode) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
- 
Set the ack mode to use when auto ack (in the configuration properties) is false.
- acknowledge() - Method in interface org.springframework.integration.acks.AcknowledgmentCallback
- acknowledge() - Method in interface org.springframework.integration.acks.SimpleAcknowledgment
- 
Acknowledge the message delivery.
- acknowledge() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
- acknowledge(AcknowledgmentCallback.Status) - Method in interface org.springframework.integration.acks.AcknowledgmentCallback
- 
Acknowledge the message.
- acknowledge(AcknowledgmentCallback.Status) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
- acknowledge(AcknowledgmentCallback.Status) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
- acknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- acknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- ACKNOWLEDGMENT_CALLBACK - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
- 
A callback to acknowledge message delivery.
- AcknowledgmentCallback - Interface in org.springframework.integration.acks
- 
A general abstraction over acknowledgments.
- AcknowledgmentCallback.Status - Enum Class in org.springframework.integration.acks
- AcknowledgmentCallbackFactory<T> - Interface in org.springframework.integration.acks
- 
A factory for creatingAcknowledgmentCallbacks.
- ackTime(long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
- 
Set the time (ms) after which outstanding offsets should be committed whenContainerProperties.AckMode.TIMEorContainerProperties.AckMode.COUNT_TIMEis being used.
- ackTimeout(long) - Method in class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
- AckUtils - Class in org.springframework.integration.acks
- 
Utility methods for acting onAcknowledgmentCallbackheaders.
- acquire(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
- acquire(String) - Method in interface org.springframework.integration.jdbc.lock.LockRepository
- 
Acquire a lock for a key.
- activeCount - Variable in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
- ACTUAL_CONNECTION_ID - Static variable in class org.springframework.integration.ip.IpHeaders
- 
For information only - when using a cached or failover client connection factory, contains the actual underlying connection id.
- add(int, Properties) - Method in class org.springframework.integration.history.MessageHistory
- add(int, MessageSelector) - Method in class org.springframework.integration.selector.MessageSelectorChain
- 
Add a selector to the chain at the specified index.
- add(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
- add(String, IndexAccessor) - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
- 
Add the provided namedIndexAccessor.
- add(String, PropertyAccessor) - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
- 
Add the provided named property accessor.
- add(Properties) - Method in class org.springframework.integration.history.MessageHistory
- add(IndexAccessor...) - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
- 
Add the providedIndexAccessorinstances.
- add(PropertyAccessor...) - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
- 
Add the provided property accessors.
- add(MessageSelector) - Method in class org.springframework.integration.selector.MessageSelectorChain
- 
Add a selector to the end of the chain.
- add(Message<?>) - Method in interface org.springframework.integration.store.MessageGroup
- 
Add the message to this group.
- add(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
- add(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
- addAll(int, Collection<? extends Properties>) - Method in class org.springframework.integration.history.MessageHistory
- addAll(Collection<? extends Properties>) - Method in class org.springframework.integration.history.MessageHistory
- addAllowedPatterns(String...) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
- 
Add patterns for packages/classes that are allowed to be deserialized.
- addAllowedPatterns(String...) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- 
Add patterns for packages/classes that are allowed to be deserialized.
- addAllowedPatterns(String...) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
- 
Add patterns for packages/classes that are allowed to be deserialized.
- addAllowedPatterns(String...) - Method in class org.springframework.integration.mongodb.support.BinaryToMessageConverter
- 
Add patterns for packages/classes that are allowed to be deserialized.
- addAllowedPatterns(String...) - Method in class org.springframework.integration.support.converter.AllowListDeserializingConverter
- 
Add package/class patterns to the allowed list.
- addAttribute(String, Object) - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
- 
Add attribute to thisResourceHolderinstance.
- addBean(Object) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
- 
Add an object which will be registered as anIntegrationFlowdependant bean in the application context.
- addBean(Object) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
- 
Add an object which will be registered as anIntegrationFlowdependant bean in the application context.
- addBean(String, Object) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
- 
Add an object which will be registered as anIntegrationFlowdependant bean in the application context.
- addBean(String, Object) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
- 
Add an object which will be registered as anIntegrationFlowdependant bean in the application context.
- addCallback(ClientManager.ConnectCallback) - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
- addCallback(ClientManager.ConnectCallback) - Method in interface org.springframework.integration.mqtt.core.ClientManager
- 
Register a callback for theconnectCompleteevent from the client.
- addComponent(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- addComponent(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- addComponents(Map<Object, String>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- addConnection(TcpConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- addConstructorValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.ip.config.IpAdapterParserUtils
- 
Adds a constructor-arg to the provided bean definition builder with the value of the attribute whose name is provided if that attribute is defined in the given element.
- addCustomHeaders(TcpConnection, MessageHeaders) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
- addDelayProperty(Message<?>, Message) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- addDestination(String...) - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
- 
Add a destination (or destinations) to the subscribed list and subscribe it.
- addDestinationConfigToConstructor(Element, BeanDefinitionBuilder, ParserContext) - Static method in class org.springframework.integration.ip.config.IpAdapterParserUtils
- 
Adds destination configuration to constructor.
- addDiscardCallback(Consumer<F>) - Method in class org.springframework.integration.file.filters.AbstractLastModifiedFileListFilter
- addDiscardCallback(Consumer<F>) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
- addDiscardCallback(Consumer<F>) - Method in interface org.springframework.integration.file.filters.DiscardAwareFileListFilter
- ADDED - Enum constant in enum class org.springframework.integration.hazelcast.CacheEventType
- 
The Hazelcast ADDED event.
- addElementToHeaderMapping(String, String) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
- addElementToHeaderMapping(String, String, String) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
- addEndpoint(IntegrationRSocketEndpoint) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
- 
Add anIntegrationRSocketEndpointfor mapping and handling RSocket requests.
- addEndpoint(IntegrationRSocketEndpoint) - Method in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
- addFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
- addFilters(Collection<? extends FileListFilter<F>>) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
- 
Add the new filters to this CompositeFileListFilter while maintaining the existing filters.
- addFilters(FileListFilter<F>...) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
- addHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
- 
Add the handler to the internal Set.
- addHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
- 
Add a message handler.
- addHeaders(Message<?>, Map<String, Object>) - Method in class org.springframework.integration.file.splitter.FileSplitter
- addHeaders(Message<?>, Map<String, Object>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
- 
Allows subclasses to add extra headers to the output messages.
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
- 
Add a channel interceptor to the specified index of the list.
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractPollableChannel
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
- 
Add a channel interceptor to the end of the list.
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractPollableChannel
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
- addLifecyclesToRole(String, List<String>) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
- 
Add aSmartLifecyclebeans to the role using their names.
- addLifecycleToRole(String, String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
- 
Add aSmartLifecyclebean to the role using its name.
- addLifecycleToRole(String, SmartLifecycle) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
- 
Add aSmartLifecycleto the role.
- addListener(MetadataStoreListener) - Method in class org.springframework.integration.hazelcast.metadata.HazelcastMetadataStore
- addListener(MetadataStoreListener) - Method in interface org.springframework.integration.metadata.ListenableMetadataStore
- 
Register a listener with the metadata store.
- addListener(MetadataStoreListener) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
- addMatchingInterceptors(InterceptableChannel, String) - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
- 
Add any interceptor whose pattern matches against the channel's name.
- addMessage(Message<T>) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- addMessage(Message<T>) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- addMessage(Message<T>) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
- addMessage(Message<T>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- addMessage(Message<T>) - Method in interface org.springframework.integration.store.MessageStore
- 
Put the provided Message into the MessageStore.
- addMessage(Message<T>) - Method in class org.springframework.integration.store.SimpleMessageStore
- addMessageDocument(MessageDocument) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
- addMessagesToGroup(Object, Message<?>...) - Method in interface org.springframework.integration.store.MessageGroupStore
- 
Store messages with an association to a group id.
- addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.store.SimpleMessageStore
- addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
- 
Store a message in the database.
- addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
- addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
- addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
- addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
- addMessageToGroup(Object, Message<?>) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
- 
Store a message with an association to a group id.
- addMessagingAnnotationPostProcessor(Class<A>, MethodAnnotationPostProcessor<A>) - Method in class org.springframework.integration.config.MessagingAnnotationPostProcessor
- addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- addNewConnection(TcpConnection) - Method in interface org.springframework.integration.ip.tcp.connection.TcpSender
- 
When we are using sockets owned by aTcpListener, this method is called each time a new connection is made.
- addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
- addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
- addNotPropagatedHeaders(String...) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
- 
Add header patterns ("xxx*", "*xxx", "*xxx*" or "xxx*yyy") that will NOT be copied from the inbound message ifAbstractMessageProducingHandler.shouldCopyRequestHeaders()is true, instead of overwriting the existing set.
- addNotPropagatedHeaders(String...) - Method in interface org.springframework.integration.handler.HeaderPropagationAware
- 
Add headers that will NOT be copied from the inbound message if the handler is configured to copy headers, instead of overwriting the existing set.
- addNotPropagatedHeaders(String...) - Method in class org.springframework.integration.transformer.MessageTransformingHandler
- addProperties(Map<String, Object>) - Method in class org.springframework.integration.graph.IntegrationNode
- 
Add extra property to the node.
- addProperty(String, Object) - Method in class org.springframework.integration.graph.IntegrationNode
- 
Add extra property to the node.
- addQueueNames(String...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- addQueues(Queue...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- addReadOnlyHeaders(String...) - Method in class org.springframework.integration.support.DefaultMessageBuilderFactory
- 
Add headers to the configured list of read only headers.
- addRecipient(String) - Method in class org.springframework.integration.router.RecipientListRouter
- addRecipient(String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
- 
Add a recipient with channelName.
- addRecipient(String, String) - Method in class org.springframework.integration.router.RecipientListRouter
- addRecipient(String, String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
- 
Add a recipient with channelName and expression.
- addRecipient(String, MessageSelector) - Method in class org.springframework.integration.router.RecipientListRouter
- addRecipient(MessageChannel) - Method in class org.springframework.integration.router.RecipientListRouter
- addRecipient(MessageChannel, MessageSelector) - Method in class org.springframework.integration.router.RecipientListRouter
- addSessionFactory(Object, SessionFactory<F>) - Method in class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
- 
Add a session factory.
- addStandardHeaders(TcpConnection, MessageHeaders) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
- addSupportedProtocols(String...) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
- addTopic(String...) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
- 
Add a topic (or topics) to the subscribed list (qos=1).
- addTopic(String, int) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
- 
Add a topic to the subscribed list.
- addTopic(String, int) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
- addTopic(String, int) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- addTopics(String[], int[]) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
- 
Add topics to the subscribed list.
- adjustLogLevels(String, List<Class<?>>, List<String>, Level) - Static method in class org.springframework.integration.test.util.TestUtils
- advice(Advice...) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- advice(Advice...) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
- 
Configure a list ofAdviceobjects to be applied, in nested order, to the endpoint's handler.
- advice(Advice...) - Method in class org.springframework.integration.dsl.PollerSpec
- 
Specify AOPAdvices for thepollingTask.
- ADVICE_CHAIN_ATTRIBUTE - Static variable in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- adviceChain - Variable in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- adviceChain - Variable in class org.springframework.integration.dsl.ConsumerEndpointSpec
- adviceChain() - Element in annotation interface org.springframework.integration.annotation.Filter
- 
Specify a "chain" ofAdvicebeans that will "wrap" the message handler.
- adviceChain() - Element in annotation interface org.springframework.integration.annotation.ServiceActivator
- 
Specify a "chain" ofAdvicebeans that will "wrap" the message handler.
- adviceChain() - Element in annotation interface org.springframework.integration.annotation.Splitter
- 
Specify a "chain" ofAdvicebeans that will "wrap" the message handler.
- adviceChain() - Element in annotation interface org.springframework.integration.annotation.Transformer
- 
Specify a "chain" ofAdviceobjects that will "wrap" the message handler.
- adviceChain(Advice...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- adviceChain(Advice...) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageListenerContainerSpec
- adviceChain(Advice...) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
- 
Configure a chain ofAdviceobjects for message delivery, applied to the downstream flow.
- AdviceMessage<T> - Class in org.springframework.integration.message
- 
A message implementation that is produced by an advice after successful message handling.
- AdviceMessage(T, Map<String, Object>, Message<?>) - Constructor for class org.springframework.integration.message.AdviceMessage
- AdviceMessage(T, Message<?>) - Constructor for class org.springframework.integration.message.AdviceMessage
- AdviceMessage(T, MessageHeaders, Message<?>) - Constructor for class org.springframework.integration.message.AdviceMessage
- 
A constructor with theMessageHeadersinstance to use.
- AdviceMessageJacksonDeserializer - Class in org.springframework.integration.support.json
- 
TheMessageJacksonDeserializerimplementation for theAdviceMessage.
- AdviceMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.AdviceMessageJacksonDeserializer
- afterAll(ExtensionContext) - Method in class org.springframework.integration.test.condition.LogLevelsCondition
- afterCommit(String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- afterCommit(String, String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- afterCommit(String, MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- afterCommit(MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- afterEach(ExtensionContext) - Method in class org.springframework.integration.test.condition.LogLevelsCondition
- afterPropertiesSet() - Method in class org.springframework.integration.config.ChannelInitializer
- afterPropertiesSet() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
- afterPropertiesSet() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
- afterPropertiesSet() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
- afterPropertiesSet() - Method in class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
- afterPropertiesSet() - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
- afterPropertiesSet() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
- afterPropertiesSet() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
- afterPropertiesSet() - Method in class org.springframework.integration.context.IntegrationObjectSupport
- afterPropertiesSet() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
- afterPropertiesSet() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
- afterPropertiesSet() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
- afterPropertiesSet() - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
- afterPropertiesSet() - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
- afterPropertiesSet() - Method in class org.springframework.integration.handler.support.IntegrationMessageHandlerMethodFactory
- afterPropertiesSet() - Method in class org.springframework.integration.hazelcast.metadata.HazelcastMetadataStore
- afterPropertiesSet() - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
- afterPropertiesSet() - Method in class org.springframework.integration.http.management.ControlBusController
- afterPropertiesSet() - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
- afterPropertiesSet() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
- afterPropertiesSet() - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
- afterPropertiesSet() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
- 
Check mandatory properties (DataSourceandJdbcChannelMessageStore.setChannelMessageStoreQueryProvider(ChannelMessageStoreQueryProvider)).
- afterPropertiesSet() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
- 
Verifies parameters, sets the parameters onSimpleJdbcCallOperationsand ensures the appropriateSqlParameterSourceFactoryis defined whenProcedureParameterare passed in.
- afterPropertiesSet() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
- afterPropertiesSet() - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
- afterPropertiesSet() - Method in class org.springframework.integration.jpa.core.JpaExecutor
- 
Verify and sets the parameters.
- afterPropertiesSet() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
- afterPropertiesSet() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- afterPropertiesSet() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
- afterPropertiesSet() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
- afterPropertiesSet() - Method in class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
- afterPropertiesSet() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
- afterPropertiesSet() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
- afterPropertiesSet() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
- afterPropertiesSet() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
- afterPropertiesSet() - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
- afterPropertiesSet() - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
- afterPropertiesSet() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
- afterPropertiesSet() - Method in class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
- afterPropertiesSet() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
- afterPropertiesSet() - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
- afterPropertiesSet() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
- afterPropertiesSet() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
- afterReceive(boolean, MessageSource<?>) - Method in interface org.springframework.integration.file.remote.aop.RotationPolicy
- 
Invoked after the message source receive() method.
- afterReceive(boolean, MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
- afterReceive(Message<?>, Object) - Method in interface org.springframework.integration.aop.MessageSourceMutator
- afterReceive(Message<?>, Object) - Method in interface org.springframework.integration.aop.ReceiveMessageAdvice
- 
Subclasses can take actions based on the result of theJoinpoint.proceed(); e.g.
- afterReceive(Message<?>, Object) - Method in class org.springframework.integration.aop.SimpleActiveIdleReceiveMessageAdvice
- afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.aop.CompoundTriggerAdvice
- afterReceive(Message<?>, MessageSource<?>) - Method in interface org.springframework.integration.aop.MessageSourceMutator
- 
Subclasses can take actions based on the result of the poll; e.g.
- afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.RotatingServerAdvice
- afterReceiveCompletion(Message<?>, MessageChannel, Exception, Deque<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
- afterReceivePostProcessors(MessagePostProcessor...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- 
SetMessagePostProcessors that will be applied after message reception, before invoking theMessageListener.
- afterRelease(MessageGroup, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- 
Allows you to provide additional logic that needs to be performed after the MessageGroup was released.
- afterRelease(MessageGroup, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.AggregatingMessageHandler
- 
Complete the group and remove all its messages.
- afterRelease(MessageGroup, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
- afterRelease(MessageGroup, Collection<Message<?>>, boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- 
Subclasses may override if special action is needed because the group was released or discarded due to a timeout.
- afterRelease(MessageGroup, Collection<Message<?>>, boolean) - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
- 
Perform group removal if itssizeis equal to thesequenceSize.
- afterRollback(String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- afterRollback(String, String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- afterRollback(String, MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- afterRollback(MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- afterSendCompletion(Message<?>, MessageChannel, boolean, Exception, Deque<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
- afterSessionEnded(WebSocketSession, CloseStatus) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
- afterSessionEnded(WebSocketSession, CloseStatus) - Method in interface org.springframework.integration.websocket.WebSocketListener
- 
Invoked after aWebSocketSessionhas ended.
- afterSessionEnded(WebSocketSession, CloseStatus, MessageChannel) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
- afterSessionStarted(WebSocketSession) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
- afterSessionStarted(WebSocketSession) - Method in interface org.springframework.integration.websocket.WebSocketListener
- 
Invoked after aWebSocketSessionhas started.
- afterSessionStarted(WebSocketSession, MessageChannel) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
- afterShutdown() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- afterShutdown() - Method in interface org.springframework.integration.context.OrderlyShutdownCapable
- 
Called after normal shutdown of schedulers, executors etc, and after the shutdown delay has elapsed, but before any forced shutdown of any remaining active scheduler/executor threads.Can optionally return the number of active messages still in process.
- afterShutdown() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
- afterShutdown() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
- afterShutdown() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- afterShutdown() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
- afterShutdown() - Method in class org.springframework.integration.jms.JmsInboundGateway
- afterShutdown() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
- afterShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
- afterShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
- afterShutdown() - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
- afterSingletonsInstantiated() - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
- afterSingletonsInstantiated() - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
- afterSingletonsInstantiated() - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
- afterSingletonsInstantiated() - Method in class org.springframework.integration.config.MessagingAnnotationBeanPostProcessor
- afterSingletonsInstantiated() - Method in class org.springframework.integration.dsl.context.IntegrationFlowBeanPostProcessor
- afterSingletonsInstantiated() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
- afterSingletonsInstantiated() - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
- afterSingletonsInstantiated() - Method in class org.springframework.integration.hazelcast.HazelcastLocalInstanceRegistrar
- 
Deprecated.
- afterSingletonsInstantiated() - Method in class org.springframework.integration.http.inbound.DynamicRequestMappingBeanPostProcessor
- afterSingletonsInstantiated() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
- afterSingletonsInstantiated() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
- afterSingletonsInstantiated() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
- afterSingletonsInstantiated() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
- afterSingletonsInstantiated() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
- afterSingletonsInstantiated() - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
- afterSingletonsInstantiated() - Method in class org.springframework.integration.support.management.ControlBusCommandRegistry
- afterSingletonsInstantiated() - Method in class org.springframework.integration.test.context.MockIntegrationContext
- aggregate() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theAggregatingMessageHandlerwith default options.
- aggregate(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
A short-cut for theaggregate((aggregator) -> aggregator.processor(aggregatorProcessor)).
- aggregate(Consumer<AggregatorSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theAggregatingMessageHandlerwith provided options fromAggregatorSpec.
- AggregatedXmlMessageValidationException - Exception Class in org.springframework.integration.xml
- 
The validation exception which aggregate all the XML validation errors.
- AggregatedXmlMessageValidationException(List<Throwable>) - Constructor for exception class org.springframework.integration.xml.AggregatedXmlMessageValidationException
- aggregateHeaders(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
- 
This default implementation simply returns all headers that have no conflicts among the group.
- AggregateMessageDeliveryException - Exception Class in org.springframework.integration.dispatcher
- 
An Exception that encapsulates an aggregated group of Exceptions for use by dispatchers that may try multiple handler invocations within a single dispatch operation.
- AggregateMessageDeliveryException(Message<?>, String, List<? extends Exception>) - Constructor for exception class org.springframework.integration.dispatcher.AggregateMessageDeliveryException
- aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
- aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.DefaultAggregatingMessageGroupProcessor
- aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
- 
Evaluate the expression provided on the messages (a collection) in the group, and delegate to theMessagingTemplateto send downstream.
- aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
- aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.file.aggregator.FileAggregatingMessageGroupProcessor
- AggregatingMessageHandler - Class in org.springframework.integration.aggregator
- 
Aggregator specific implementation ofAbstractCorrelatingMessageHandler.
- AggregatingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
- AggregatingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
- AggregatingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
- aggregator - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- Aggregator - Annotation Interface in org.springframework.integration.annotation
- 
Indicates that a method is capable of aggregating messages.
- AggregatorAnnotationPostProcessor - Class in org.springframework.integration.config
- 
Post-processor for the@Aggregatorannotation.
- AggregatorAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.AggregatorAnnotationPostProcessor
- AggregatorFactoryBean - Class in org.springframework.integration.config
- 
FactoryBeanto create anAggregatingMessageHandler.
- AggregatorFactoryBean() - Constructor for class org.springframework.integration.config.AggregatorFactoryBean
- AggregatorParser - Class in org.springframework.integration.config.xml
- 
Parser for the aggregator element of the integration namespace.
- AggregatorParser() - Constructor for class org.springframework.integration.config.xml.AggregatorParser
- Aggregators - Annotation Interface in org.springframework.integration.annotation
- 
The repeatable container forAggregatorannotations.
- AggregatorSpec - Class in org.springframework.integration.dsl
- AggregatorSpec() - Constructor for class org.springframework.integration.dsl.AggregatorSpec
- ALERT - Enum constant in enum class org.springframework.integration.syslog.RFC5424SyslogParser.Severity
- ALL - Enum constant in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
- 
(-a) Include files beginning with., including directories.and..in the results (ls).
- ALL - Enum constant in enum class org.springframework.integration.hazelcast.CacheListeningPolicyType
- 
All subscribed members can accept event.
- ALL - Enum constant in enum class org.springframework.integration.selector.MessageSelectorChain.VotingStrategy
- allEndpointsRunning(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
- 
Return true if all endpoints in the role are running.
- allocate(int) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
- 
Allocate a ByteBuffer of the requested length using normal or direct buffers, depending on the usingDirectBuffers field.
- allowCredentials(Boolean) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
- 
Whether the browser should include any cookies associated with the domain of the request being annotated.
- allowedHeaders(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
- 
List of request headers that can be used during the actual request.
- allowedOrigins() - Element in annotation interface org.springframework.integration.http.config.EnableIntegrationGraphController
- 
Specify allowed origin URLs for cross-origin request handling.
- AllowListDeserializingConverter - Class in org.springframework.integration.support.converter
- 
AConverterthat delegates to aDeserializerto convert data in a byte array to an object.
- AllowListDeserializingConverter() - Constructor for class org.springframework.integration.support.converter.AllowListDeserializingConverter
- 
Create aAllowListDeserializingConverterwith defaultObjectInputStreamconfiguration, using the "latest user-defined ClassLoader".
- AllowListDeserializingConverter(ClassLoader) - Constructor for class org.springframework.integration.support.converter.AllowListDeserializingConverter
- AllowListDeserializingConverter(Deserializer<Object>) - Constructor for class org.springframework.integration.support.converter.AllowListDeserializingConverter
- 
Create aAllowListDeserializingConverterthat delegates to the providedDeserializer.
- alwaysAccept(F) - Method in class org.springframework.integration.file.filters.AbstractDirectoryAwareFileListFilter
- alwaysRequeueWithTxManagerRollback(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- 
Set to true to always requeue on transaction rollback with an external TransactionManager.
- Amqp - Class in org.springframework.integration.amqp.dsl
- 
Factory class for AMQP components.
- AMQP_RAW_MESSAGE - Static variable in class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
- 
Header name/retry context variable for the raw received message.
- AmqpAckCallback(AmqpMessageSource.AmqpAckInfo) - Constructor for class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
- AmqpAckCallbackFactory() - Constructor for class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallbackFactory
- AmqpAckInfo(Connection, Channel, boolean, GetResponse) - Constructor for class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
- AmqpAsyncOutboundGatewaySpec - Class in org.springframework.integration.amqp.dsl
- AmqpAsyncOutboundGatewaySpec(AsyncRabbitTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpAsyncOutboundGatewaySpec
- AmqpBaseInboundChannelAdapterSpec<S> - Class in org.springframework.integration.amqp.dsl
- 
The baseMessageProducerSpecimplementation for aAmqpInboundChannelAdapter.
- AmqpBaseInboundChannelAdapterSpec(AmqpInboundChannelAdapter) - Constructor for class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
- AmqpBaseInboundGatewaySpec<S> - Class in org.springframework.integration.amqp.dsl
- 
A baseMessagingGatewaySpecimplementation forAmqpInboundGatewayendpoint options.
- AmqpBaseInboundGatewaySpec(AmqpInboundGateway) - Constructor for class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
- AmqpBaseOutboundEndpointSpec<S,E> - Class in org.springframework.integration.amqp.dsl
- 
The baseMessageHandlerSpecforAbstractAmqpOutboundEndpoints.
- AmqpBaseOutboundEndpointSpec() - Constructor for class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- amqpChannelFactoryBean - Variable in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- AmqpChannelFactoryBean - Class in org.springframework.integration.amqp.config
- 
If point-to-point, we send to the default exchange with the routing key equal to "[beanName]" and we declare that same Queue and register a listener if message-driven or poll explicitly otherwise.
- AmqpChannelFactoryBean() - Constructor for class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- AmqpChannelFactoryBean(boolean) - Constructor for class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- AmqpChannelParser - Class in org.springframework.integration.amqp.config
- 
Parser for the 'channel' and 'publish-subscribe-channel' elements of the Spring Integration AMQP namespace.
- AmqpChannelParser() - Constructor for class org.springframework.integration.amqp.config.AmqpChannelParser
- AmqpHeaderMapper - Interface in org.springframework.integration.amqp.support
- 
A convenience interface that extendsRequestReplyHeaderMapper, parameterized withMessageProperties.
- AmqpInboundChannelAdapter - Class in org.springframework.integration.amqp.inbound
- 
Adapter that receives Messages from an AMQP Queue, converts them into Spring Integration Messages, and sends the results to a Message Channel.
- AmqpInboundChannelAdapter(MessageListenerContainer) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- 
Construct an instance using the provided container.
- AmqpInboundChannelAdapter.BatchListener - Class in org.springframework.integration.amqp.inbound
- AmqpInboundChannelAdapter.BatchMode - Enum Class in org.springframework.integration.amqp.inbound
- 
Defines the payload type when the listener container is configured with consumerBatchEnabled.
- AmqpInboundChannelAdapter.Listener - Class in org.springframework.integration.amqp.inbound
- AmqpInboundChannelAdapterDMLCSpec - Class in org.springframework.integration.amqp.dsl
- 
Spec for an inbound channel adapter with aDirectMessageListenerContainer.
- AmqpInboundChannelAdapterDMLCSpec(DirectMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterDMLCSpec
- AmqpInboundChannelAdapterParser - Class in org.springframework.integration.amqp.config
- 
Parser for the AMQP 'inbound-channel-adapter' element.
- AmqpInboundChannelAdapterSMLCSpec - Class in org.springframework.integration.amqp.dsl
- 
Spec for an inbound channel adapter with aSimpleMessageListenerContainer.
- AmqpInboundChannelAdapterSMLCSpec(SimpleMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSMLCSpec
- AmqpInboundChannelAdapterSpec<S,C> - Class in org.springframework.integration.amqp.dsl
- AmqpInboundChannelAdapterSpec(MessageListenerContainerSpec<?, C>) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSpec
- AmqpInboundGateway - Class in org.springframework.integration.amqp.inbound
- 
Adapter that receives Messages from an AMQP Queue, converts them into Spring Integration Messages, and sends the results to a Message Channel.
- AmqpInboundGateway(AbstractMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundGateway
- AmqpInboundGateway(MessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundGateway
- 
ConstructAmqpInboundGatewaybased on the providedMessageListenerContainerto receive request messages andAmqpTemplateto send replies.
- AmqpInboundGateway.Listener - Class in org.springframework.integration.amqp.inbound
- AmqpInboundGatewayDMLCSpec - Class in org.springframework.integration.amqp.dsl
- 
Spec for a gateway with aDirectMessageListenerContainer.
- AmqpInboundGatewayDMLCSpec(DirectMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewayDMLCSpec
- AmqpInboundGatewayDMLCSpec(DirectMessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewayDMLCSpec
- AmqpInboundGatewayParser - Class in org.springframework.integration.amqp.config
- 
Parser for the AMQP 'inbound-gateway' element.
- AmqpInboundGatewaySMLCSpec - Class in org.springframework.integration.amqp.dsl
- 
Spec for a gateway with aSimpleMessageListenerContainer.
- AmqpInboundGatewaySMLCSpec(SimpleMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySMLCSpec
- AmqpInboundGatewaySMLCSpec(SimpleMessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySMLCSpec
- AmqpInboundGatewaySpec<S,C> - Class in org.springframework.integration.amqp.dsl
- 
AnAmqpBaseInboundGatewaySpecimplementation for aAmqpInboundGateway.
- AmqpInboundGatewaySpec(AbstractMessageListenerContainerSpec<?, C>) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySpec
- AmqpInboundPolledChannelAdapterSpec - Class in org.springframework.integration.amqp.dsl
- 
Spec for a polled AMQP inbound channel adapter.
- AmqpInboundPolledChannelAdapterSpec(ConnectionFactory, String) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
- AmqpInboundPolledChannelAdapterSpec(ConnectionFactory, AmqpMessageSource.AmqpAckCallbackFactory, String) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
- AmqpMessageChannelSpec<S,T> - Class in org.springframework.integration.amqp.dsl
- 
AnAmqpPollableMessageChannelSpecfor a message-drivenPointToPointSubscribableAmqpChannel.
- AmqpMessageChannelSpec(ConnectionFactory) - Constructor for class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- amqpMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- AmqpMessageHeaderErrorMessageStrategy - Class in org.springframework.integration.amqp.support
- 
AnErrorMessageStrategyextension that adds the raw AMQP message as a header to theErrorMessage.
- AmqpMessageHeaderErrorMessageStrategy() - Constructor for class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
- AmqpMessageSource - Class in org.springframework.integration.amqp.inbound
- 
A pollableMessageSourcefor RabbitMQ.
- AmqpMessageSource(ConnectionFactory, String) - Constructor for class org.springframework.integration.amqp.inbound.AmqpMessageSource
- AmqpMessageSource(ConnectionFactory, AmqpMessageSource.AmqpAckCallbackFactory, String) - Constructor for class org.springframework.integration.amqp.inbound.AmqpMessageSource
- AmqpMessageSource.AmqpAckCallback - Class in org.springframework.integration.amqp.inbound
- AmqpMessageSource.AmqpAckCallbackFactory - Class in org.springframework.integration.amqp.inbound
- AmqpMessageSource.AmqpAckInfo - Class in org.springframework.integration.amqp.inbound
- 
Information for building an AmqpAckCallback.
- AmqpNamespaceHandler - Class in org.springframework.integration.amqp.config
- 
Namespace handler for the AMQP schema.
- AmqpNamespaceHandler() - Constructor for class org.springframework.integration.amqp.config.AmqpNamespaceHandler
- AmqpOutboundChannelAdapterParser - Class in org.springframework.integration.amqp.config
- 
Parser for the AMQP 'outbound-channel-adapter' element.
- AmqpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.amqp.config.AmqpOutboundChannelAdapterParser
- AmqpOutboundChannelAdapterSpec - Class in org.springframework.integration.amqp.dsl
- 
Spec for an outbound AMQP channel adapter.
- AmqpOutboundChannelAdapterSpec(AmqpTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpOutboundChannelAdapterSpec
- AmqpOutboundEndpoint - Class in org.springframework.integration.amqp.outbound
- 
Adapter that converts and sends Messages to an AMQP Exchange.
- AmqpOutboundEndpoint(AmqpTemplate) - Constructor for class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- AmqpOutboundEndpointSpec<S> - Class in org.springframework.integration.amqp.dsl
- 
Base spec for outbound AMQP endpoints.
- AmqpOutboundEndpointSpec(AmqpTemplate, boolean) - Constructor for class org.springframework.integration.amqp.dsl.AmqpOutboundEndpointSpec
- AmqpOutboundGatewayParser - Class in org.springframework.integration.amqp.config
- 
Parser for the AMQP 'outbound-channel-adapter' element.
- AmqpOutboundGatewayParser() - Constructor for class org.springframework.integration.amqp.config.AmqpOutboundGatewayParser
- AmqpOutboundGatewaySpec - Class in org.springframework.integration.amqp.dsl
- 
Spec for an outbound AMQP gateway.
- AmqpOutboundGatewaySpec(AmqpTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpOutboundGatewaySpec
- AmqpPollableMessageChannelSpec<S,T> - Class in org.springframework.integration.amqp.dsl
- 
AMessageChannelSpecfor aAbstractAmqpChannels.
- AmqpPollableMessageChannelSpec(ConnectionFactory) - Constructor for class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- AmqpPublishSubscribeMessageChannelSpec - Class in org.springframework.integration.amqp.dsl
- AmqpPublishSubscribeMessageChannelSpec(ConnectionFactory) - Constructor for class org.springframework.integration.amqp.dsl.AmqpPublishSubscribeMessageChannelSpec
- AnnotatedMethodFilter - Class in org.springframework.integration.util
- 
A MethodFilter implementation that enables the following: matching on method name, if available exclusion of void-returning methods if 'requiresReply' is true limiting to annotated methods if at least one is present .
- AnnotatedMethodFilter(Class<? extends Annotation>, String, boolean) - Constructor for class org.springframework.integration.util.AnnotatedMethodFilter
- annotation() - Method in record class org.springframework.integration.config.MessagingAnnotationBeanPostProcessor.MessagingMetaAnnotation
- 
Returns the value of theannotationrecord component.
- annotationBeanNameGenerator(BeanDefinitionRegistry) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
- AnnotationConfigParser - Class in org.springframework.integration.config.xml
- 
Parser for the<annotation-config>element of the integration namespace.
- AnnotationConfigParser() - Constructor for class org.springframework.integration.config.xml.AnnotationConfigParser
- AnnotationConstants - Class in org.springframework.integration.annotation
- 
Common value constants for annotation attributes.
- AnnotationGatewayProxyFactoryBean<T> - Class in org.springframework.integration.gateway
- 
AGatewayProxyFactoryBeanextension for Java configuration.
- AnnotationGatewayProxyFactoryBean(Class<T>) - Constructor for class org.springframework.integration.gateway.AnnotationGatewayProxyFactoryBean
- AnnotationMetadataAdapter - Class in org.springframework.integration.config.annotation
- 
AnAnnotationMetadataimplementation to expose a metadata by the providedMapof attributes.
- AnnotationMetadataAdapter() - Constructor for class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
- annotations() - Method in record class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor.BeanDefinitionPropertiesMapper
- 
Returns the value of theannotationsrecord component.
- annotationType - Variable in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- annotationType() - Method in record class org.springframework.integration.config.MessagingAnnotationBeanPostProcessor.MessagingMetaAnnotation
- 
Returns the value of theannotationTyperecord component.
- ANY - Enum constant in enum class org.springframework.integration.selector.MessageSelectorChain.VotingStrategy
- ApacheCommonsFileTailingMessageProducer - Class in org.springframework.integration.file.tail
- 
File tailer that delegates to the Apache Commons Tailer.
- ApacheCommonsFileTailingMessageProducer() - Constructor for class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
- ApacheMinaFtpEvent - Class in org.springframework.integration.ftp.server
- 
ApplicationEventgenerated from Apache Mina ftp events.
- ApacheMinaFtpEvent(Object) - Constructor for class org.springframework.integration.ftp.server.ApacheMinaFtpEvent
- ApacheMinaFtpEvent(Object, Throwable) - Constructor for class org.springframework.integration.ftp.server.ApacheMinaFtpEvent
- ApacheMinaFtplet - Class in org.springframework.integration.ftp.server
- 
A listener for FTP events emitted by an Apache Mina ftp server.
- ApacheMinaFtplet() - Constructor for class org.springframework.integration.ftp.server.ApacheMinaFtplet
- ApacheMinaSftpEvent - Class in org.springframework.integration.sftp.server
- 
ApplicationEventgenerated from Apache Mina sftp events.
- ApacheMinaSftpEvent(Object) - Constructor for class org.springframework.integration.sftp.server.ApacheMinaSftpEvent
- ApacheMinaSftpEvent(Object, Throwable) - Constructor for class org.springframework.integration.sftp.server.ApacheMinaSftpEvent
- ApacheMinaSftpEventListener - Class in org.springframework.integration.sftp.server
- 
A listener for SFTP events emitted by an Apache Mina sshd/sftp server.
- ApacheMinaSftpEventListener() - Constructor for class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
- APP_NAME - Static variable in class org.springframework.integration.syslog.SyslogHeaders
- append(InputStream, String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
- append(InputStream, String) - Method in interface org.springframework.integration.file.remote.session.Session
- 
Append to a file.
- append(InputStream, String) - Method in class org.springframework.integration.ftp.session.FtpSession
- append(InputStream, String) - Method in class org.springframework.integration.sftp.session.SftpSession
- append(InputStream, String) - Method in class org.springframework.integration.smb.session.SmbSession
- append(Message<?>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
- 
Send a file to a remote server, based on information in a message, appending.
- append(Message<?>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
- append(Message<?>, String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
- 
Send a file to a remote server, based on information in a message, appending.
- append(Message<?>, String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
- APPEND - Enum constant in enum class org.springframework.integration.file.support.FileExistsMode
- 
Append data to any pre-existing files; close after each append.
- APPEND_NO_FLUSH - Enum constant in enum class org.springframework.integration.file.support.FileExistsMode
- 
Append data to any pre-existing files; do not flush/close after appending.
- appendNewLine(boolean) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- 
Iftruewill append a new-line after each write.
- appendNewLine(boolean) - Method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
- APPLICATION_RUNNING_CONTROLLER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- ApplicationEventListeningMessageProducer - Class in org.springframework.integration.event.inbound
- 
An inbound Channel Adapter that implementsGenericApplicationListenerand passes SpringApplicationEventswithin messages.
- ApplicationEventListeningMessageProducer() - Constructor for class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
- 
Construct an instance.
- ApplicationEventMulticasterParser - Class in org.springframework.integration.config.xml
- 
Parser for the <application-event-multicaster> element of the integration namespace.
- ApplicationEventMulticasterParser() - Constructor for class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
- ApplicationEventPublishingMessageHandler - Class in org.springframework.integration.event.outbound
- ApplicationEventPublishingMessageHandler() - Constructor for class org.springframework.integration.event.outbound.ApplicationEventPublishingMessageHandler
- apply(Statement, Description) - Method in class org.springframework.integration.test.support.LongRunningIntegrationTest
- apply(Statement, FrameworkMethod, Object) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
- apply(MessageGroup) - Method in class org.springframework.integration.aggregator.DefaultAggregateHeadersFunction
- apply(T) - Method in interface org.springframework.integration.util.CheckedFunction
- APPLY_SEQUENCE - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- applyAndBind(String, Iterable<T>, EntityManager) - Static method in class org.springframework.integration.jpa.support.JpaUtils
- 
Creates a where-clause referencing the given entities and appends it to the given query string.
- applyReceiveOnlyAdviceChain(Collection<Advice>) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
- 
Add the advice chain to the component that responds toAbstractPollingEndpoint.receiveMessage()calls.
- applySequence() - Element in annotation interface org.springframework.integration.annotation.Router
- 
Specify whether sequence number and size headers should be added to each Message.
- applySequence() - Element in annotation interface org.springframework.integration.annotation.Splitter
- 
Set this flag tofalseto prevent adding sequence related headers in this splitter.
- applySequence(boolean) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
- applySequence(boolean) - Method in class org.springframework.integration.dsl.PublishSubscribeChannelSpec
- applySequence(boolean) - Method in class org.springframework.integration.dsl.SplitterSpec
- 
Set the applySequence flag to the specified value.
- applySequence(boolean) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
- 
Abooleanflag to indicate ifsequenceDetailsshould be applied for messages based on the lines from file.
- applySystemFileSeparator(String) - Static method in class org.springframework.integration.test.util.TestUtils
- 
Update file path by replacing any '/' with the system's file separator.
- areMutuallyExclusive(String, BeanDefinition, String) - Static method in class org.springframework.integration.cassandra.config.xml.CassandraParserUtils
- ARGUMENT_MAP_VARIABLE_NAME - Static variable in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
- ARGUMENT_MAP_VARIABLE_NAME - Static variable in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
- ARGUMENT_MAP_VARIABLE_NAME - Static variable in class org.springframework.integration.aop.SimplePublisherMetadataSource
- ARGUMENT_RESOLVER_MESSAGE_CONVERTER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- ArgumentsStrategy - Interface in org.springframework.integration.redis.outbound
- ARRAY - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- asFileInfoList(Collection<F>) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
- asFileInfoList(Collection<F>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- asFileInfoList(Collection<SmbFile>) - Method in class org.springframework.integration.smb.inbound.SmbStreamingMessageSource
- asFileInfoList(Collection<SmbFile>) - Method in class org.springframework.integration.smb.outbound.SmbOutboundGateway
- asFileInfoList(Collection<FTPFile>) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- asFileInfoList(Collection<FTPFile>) - Method in class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
- asFileInfoList(Collection<SftpClient.DirEntry>) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
- asFileInfoList(Collection<SftpClient.DirEntry>) - Method in class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
- asMap() - Method in class org.springframework.integration.syslog.DefaultMessageConverter
- assemble(E) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- assemble(MarshallingWebServiceOutboundGateway) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
- assemble(SimpleWebServiceOutboundGateway) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
- assemble(SimpleWebServiceOutboundGateway) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
- assertHandler() - Method in class org.springframework.integration.dsl.EndpointSpec
- assertReceiver() - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
- assertRemoteFileTemplateMutability(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- assigmentDuration(Duration) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec
- 
Set the time to wait for partition assignment, when used as a gateway, to determine the default reply-to topic/partition.
- async() - Element in annotation interface org.springframework.integration.annotation.ServiceActivator
- 
Specify whether the service method is async.
- async(boolean) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
- 
Allow async replies.
- async(boolean) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
- 
Set to true to release the sending thread and receive the reply asynchronously.
- AsyncAmqpOutboundGateway - Class in org.springframework.integration.amqp.outbound
- 
An outbound gateway where the sending thread is released immediately and the reply is sent on the async template's listener container thread.
- AsyncAmqpOutboundGateway(AsyncRabbitTemplate) - Constructor for class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
- asyncConvertAndSend(Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncConvertAndSend(Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncConvertAndSend(String, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncConvertAndSend(String, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncConvertAndSend(MessageChannel, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncConvertAndSend(MessageChannel, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncConvertSendAndReceive(Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncConvertSendAndReceive(Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncConvertSendAndReceive(Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncConvertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncConvertSendAndReceive(String, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncConvertSendAndReceive(String, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncConvertSendAndReceive(String, Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncConvertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncConvertSendAndReceive(MessageChannel, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncConvertSendAndReceive(MessageChannel, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncConvertSendAndReceive(MessageChannel, Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncConvertSendAndReceive(MessageChannel, Object, MessagePostProcessor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncExecutor() - Element in annotation interface org.springframework.integration.annotation.MessagingGateway
- asyncExecutor(Executor) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
- 
Set anExecutorfor async request-reply scenarios.
- asyncExecutor(Executor) - Method in class org.springframework.integration.dsl.GatewayProxySpec
- AsyncMessagingOperations - Interface in org.springframework.integration.core
- AsyncMessagingTemplate - Class in org.springframework.integration.core
- AsyncMessagingTemplate() - Constructor for class org.springframework.integration.core.AsyncMessagingTemplate
- asyncOutboundGateway(AsyncRabbitTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initial AmqpAsyncOutboundGatewaySpec.
- asyncReceive() - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncReceive() - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncReceive(String) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncReceive(String) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncReceive(PollableChannel) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncReceive(PollableChannel) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncReceiveAndConvert() - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncReceiveAndConvert() - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncReceiveAndConvert(String) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncReceiveAndConvert(String) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncReceiveAndConvert(PollableChannel) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncReceiveAndConvert(PollableChannel) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- AsyncRequestReplyExchanger - Interface in org.springframework.integration.gateway
- 
Messaging gateway contract for async request/reply Message exchange.
- asyncSend(String, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncSend(String, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncSend(Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncSend(Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncSend(MessageChannel, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncSend(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncSendAndReceive(String, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncSendAndReceive(String, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncSendAndReceive(Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncSendAndReceive(Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncSendAndReceive(MessageChannel, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
- asyncSendAndReceive(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
- asyncSendMessage(DatagramPacket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
- ATTACHMENT_FILENAME - Static variable in class org.springframework.integration.mail.MailHeaders
- attachmentFilename(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set a filename for the attachment.
- attachmentFilenameExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set an expression that will be evaluated to determine the filename for the attachment.
- attachmentFilenameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set a function that will be invoked to determine the filename for the attachment.
- AttributePollingChannelAdapterParser - Class in org.springframework.integration.jmx.config
- AttributePollingChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.AttributePollingChannelAdapterParser
- AttributePollingMessageSource - Class in org.springframework.integration.jmx
- 
AMessageSourceimplementation that retrieves the current value of a JMX attribute each timeAbstractMessageSource.receive()is invoked.
- AttributePollingMessageSource() - Constructor for class org.springframework.integration.jmx.AttributePollingMessageSource
- ATTRIBUTES_HOLDER - Static variable in interface org.springframework.integration.kafka.inbound.KafkaInboundEndpoint
- authPacketArrived(int, MqttProperties) - Method in class org.springframework.integration.mqtt.core.Mqttv5ClientManager
- authPacketArrived(int, MqttProperties) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- authPacketArrived(int, MqttProperties) - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- AUTO_ACKNOWLEDGE - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
- AUTO_ACKNOWLEDGE_STRING - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
- AUTO_CREATE_CHANNEL_CANDIDATES_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- AUTO_STARTUP - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- autoAck(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
- 
ACCEPT anAcknowledgmentCallbackif it's not null, supports auto ack and is not already ack'd.
- autoCloseFolder(boolean) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
- 
When configured tofalse, the folder is not closed automatically after a fetch.
- autoCloseFolder(boolean) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
- 
When configured tofalse, the folder is not closed automatically after a fetch.
- AutoCreateCandidatesCollector(Collection<String>) - Constructor for record class org.springframework.integration.config.ChannelInitializer.AutoCreateCandidatesCollector
- 
Creates an instance of aAutoCreateCandidatesCollectorrecord class.
- autoCreateDirectChannel(String, BeanDefinitionRegistry) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
- autoCreateDirectory(boolean) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
- 
Specify whether to create the source directory automatically if it does not yet exist upon initialization.
- autoCreateDirectory(boolean) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- 
Abooleanflag to indicate automatically create the directory or not.
- autoCreateDirectory(boolean) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- 
Specify whether to create the destination directory automatically if it does not yet exist upon initialization.
- autoCreateDirectory(boolean) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Determine whether the remote directory should automatically be created when sending files to the remote system.
- autoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
- 
Configure whether the local directory should be created by the adapter.
- autoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Abooleanflag to identify if local directory should be created automatically.
- autoDeclare(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- 
Set to true to automatically declare elements (queues, exchanges, bindings) in the application context during container start().
- autoNack(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
- 
REJECT anAcknowledgmentCallbackif it's not null, supports auto ack and is not already ack'd.
- autoStartup() - Element in annotation interface org.springframework.integration.annotation.Aggregator
- 
TheSmartLifecycleautoStartupoption.
- autoStartup() - Element in annotation interface org.springframework.integration.annotation.BridgeFrom
- autoStartup() - Element in annotation interface org.springframework.integration.annotation.BridgeTo
- autoStartup() - Element in annotation interface org.springframework.integration.annotation.Filter
- 
TheSmartLifecycleautoStartupoption.
- autoStartup() - Element in annotation interface org.springframework.integration.annotation.InboundChannelAdapter
- 
SmartLifecycleoptions.
- autoStartup() - Element in annotation interface org.springframework.integration.annotation.Router
- 
TheSmartLifecycleautoStartupoption.
- autoStartup() - Element in annotation interface org.springframework.integration.annotation.ServiceActivator
- 
TheSmartLifecycleautoStartupoption.
- autoStartup() - Element in annotation interface org.springframework.integration.annotation.Splitter
- 
TheSmartLifecycleautoStartupoption.
- autoStartup() - Element in annotation interface org.springframework.integration.annotation.Transformer
- 
TheSmartLifecycleautoStartupoption.
- autoStartup(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- autoStartup(boolean) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
- autoStartup(boolean) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
- 
Thebooleanflag to indication if anIntegrationFlowmust be started automatically after registration.
- autoStartup(boolean) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
- 
Thebooleanflag to indication if anIntegrationFlowmust be started automatically after registration.
- autoStartup(boolean) - Method in class org.springframework.integration.dsl.EndpointSpec
- autoStartup(boolean) - Method in class org.springframework.integration.dsl.MessageProducerSpec
- autoStartup(boolean) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
- 
An auto-startup flag.
- autoStartup(boolean) - Method in class org.springframework.integration.dsl.SourcePollingChannelAdapterSpec
- autoStartup(boolean) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
- autoStartup(boolean) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
- availablePermits() - Method in class org.springframework.integration.util.UpperBound
- AvroHeaders - Class in org.springframework.integration.transformer.support
- 
Pre-defined names and prefixes for Apache Avro related headers.
- await() - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form