- 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
-
- AbstractAmqpOutboundEndpoint - Class in org.springframework.integration.amqp.outbound
-
- 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
-
- 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
-
- AbstractChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
-
- AbstractChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
-
- 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
-
Constructs a factory that will established connections to the host and port.
- AbstractConfigurableMongoDbMessageStore - Class in org.springframework.integration.mongodb.store
-
The abstract MongoDB
AbstractMessageGroupStore
implementation 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 extends AbstractConnectionFactorySpec<S,C>,C extends AbstractConnectionFactory> - 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 a
MessageStore
.
- AbstractCorrelatingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- AbstractCorrelatingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- AbstractCorrelatingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- AbstractCorrelatingMessageHandler.SequenceAwareMessageGroup - Class in org.springframework.integration.aggregator
-
- AbstractCorrelatingMessageHandlerParser - Class in org.springframework.integration.config.xml
-
- 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
-
- 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
-
- 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 of
FileInfo
; 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 any
FileListFilter
whose 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 extends org.apache.commons.net.ftp.FTPClient> - 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
-
- AbstractHandleMessageAdvice() - Constructor for class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
-
- AbstractHeaderMapper<T> - Class in org.springframework.integration.mapping
-
- 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
-
- AbstractHeaderMapper.ContentBasedHeaderMatcher - Class in org.springframework.integration.mapping
-
- 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
-
- AbstractHeaderMapper.PrefixBasedMatcher - Class in org.springframework.integration.mapping
-
- AbstractHeaderMapper.SinglePatternBasedHeaderMatcher - Class in org.springframework.integration.mapping
-
- 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
-
- 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,J> - Class in org.springframework.integration.support.json
-
- AbstractJacksonJsonObjectMapper() - Constructor for class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
-
- AbstractJmsChannel - Class in org.springframework.integration.jms
-
- 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
-
- AbstractJsonInboundMessageMapper(Type) - Constructor for class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
-
- AbstractKafkaChannel - Class in org.springframework.integration.kafka.channel
-
Abstract MessageChannel backed by a Kafka topic.
- AbstractKafkaChannel(KafkaOperations<?, ?>, String) - Constructor for class org.springframework.integration.kafka.channel.AbstractKafkaChannel
-
Construct an instance with the provided paramters.
- AbstractKafkaChannelSpec<S extends AbstractKafkaChannelSpec<S,C>,C extends AbstractKafkaChannel> - Class in org.springframework.integration.kafka.dsl
-
Spec for a message channel backed by a Kafka topic.
- AbstractKafkaChannelSpec() - Constructor for class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
-
- AbstractKeyValueMessageStore - Class in org.springframework.integration.store
-
- 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 data base.
- AbstractKryoCodec - Class in org.springframework.integration.codec.kryo
-
Base class for
Codec
s using
Kryo
.
- AbstractKryoCodec() - Constructor for class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
- AbstractKryoRegistrar - Class in org.springframework.integration.codec.kryo
-
- AbstractKryoRegistrar() - Constructor for class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
-
- AbstractLeaderEvent - Class in org.springframework.integration.leader.event
-
- 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
-
- 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 more
FileListFilter
if a corresponding marker file is also present to indicate a file transfer is complete.
- AbstractMarkerFilePresentFileListFilter(FileListFilter<F>) - Constructor for class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
-
Construct an instance with a single
FileListFilter
and ".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 single
FileListFilter
and 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 single
FileListFilter
and a function
that will be applied to the name of a matched file when looking for the marker
file.
- AbstractMarkerFilePresentFileListFilter(Map<FileListFilter<F>, Function<String, String>>) - Constructor for class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
-
Construct an instance with a map of
FileListFilter
and functions be
applied to the name of a matched file when looking for the marker file.
- AbstractMessageChannel - Class in org.springframework.integration.channel
-
Base class for
MessageChannel
implementations 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
-
- AbstractMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractMessageHandler
-
- AbstractMessageListenerContainerSpec<S extends AbstractMessageListenerContainerSpec<S,C>,C extends AbstractMessageListenerContainer> - Class in org.springframework.integration.amqp.dsl
-
Base class for container specs.
- AbstractMessageListenerContainerSpec(C) - Constructor for class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
- AbstractMessageProcessingSelector - Class in org.springframework.integration.filter
-
- AbstractMessageProcessingSelector(MessageProcessor<Boolean>) - Constructor for class org.springframework.integration.filter.AbstractMessageProcessingSelector
-
- AbstractMessageProcessingTransformer - Class in org.springframework.integration.transformer
-
- 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
-
- 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
-
- AbstractMessageSourceAdvice - Class in org.springframework.integration.aop
-
- AbstractMessageSourceAdvice() - Constructor for class org.springframework.integration.aop.AbstractMessageSourceAdvice
-
Deprecated.
- 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 extends Annotation> - Class in org.springframework.integration.config.annotation
-
Base class for Method-level annotation post-processors.
- AbstractMethodAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- AbstractMqttMessageDrivenChannelAdapter - 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
-
- AbstractMqttMessageHandler - 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
-
- 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
-
- 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
-
- 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
-
- AbstractReactiveMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractReactiveMessageHandler
-
- AbstractRegexPatternFileListFilter<F> - Class in org.springframework.integration.file.filters
-
Filters a listing of files by qualifying their 'name'
against a regular expression (an instance of
Pattern
)
- 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(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(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 filename.
- 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 filename.
- 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 filename.
- 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 filename.
- AbstractRemoteFileOutboundGateway.Command - Enum in org.springframework.integration.file.remote.gateway
-
Enumeration of commands supported by the gateways.
- AbstractRemoteFileOutboundGateway.Option - Enum 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 an
InputStream
payload
referencing a remote file.
- AbstractRemoteFileStreamingMessageSource(RemoteFileTemplate<F>, Comparator<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
-
- AbstractReplyProducingPostProcessingMessageHandler - Class in org.springframework.integration.handler
-
- AbstractReplyProducingPostProcessingMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
-
- AbstractRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
-
- 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 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
-
- 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 extends AbstractRouterSpec<S,R>,R extends AbstractMessageRouter> - 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
-
- 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
-
- 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 extends MessageHandler> - Class in org.springframework.integration.config
-
- 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
-
- AbstractStompSessionManager(StompClientSupport) - Constructor for class org.springframework.integration.stomp.AbstractStompSessionManager
-
- AbstractSubscribableChannel - Class in org.springframework.integration.channel
-
- 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
-
- 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 extends AbstractUdpOutboundChannelAdapterSpec<S>> - Class in org.springframework.integration.ip.dsl
-
- AbstractUdpOutboundChannelAdapterSpec() - Constructor for class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
-
- AbstractUdpOutboundChannelAdapterSpec(String, int) - Constructor for class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
-
- AbstractUdpOutboundChannelAdapterSpec(String) - 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 XmlTransformer
- 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
-
- 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
-
- accept(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
-
ACCEPT the associated message if the callback is not null.
- accept(S) - Method in interface org.springframework.integration.core.GenericSelector
-
- accept(Message<?>) - Method in interface org.springframework.integration.core.MessageSelector
-
- 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.AbstractPersistentAcceptOnceFileListFilter
-
- accept(F) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
-
- accept(F) - Method in class org.springframework.integration.file.filters.AbstractSimplePatternFileListFilter
-
Accepts 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
-
- accept(File) - Method in class org.springframework.integration.file.filters.IgnoreHiddenFileListFilter
-
- accept(File) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
-
- accept(File) - Method in class org.springframework.integration.file.locking.AbstractFileLockerFilter
-
- accept(Message<?>) - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
-
- 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(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
-
- accept(Message<?>) - Method in class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
-
Evaluate the payload and return true if the value returned by the
XPathExpression
matches the
regex
.
- accept(Message<?>) - Method in class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
-
Evaluate the payload and return true if the value returned by the
XPathExpression
is equal to the
valueToTestFor
.
- accept(Message<?>) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
-
- AcceptAllFileListFilter<F> - Class in org.springframework.integration.file.filters
-
- AcceptAllFileListFilter() - Constructor for class org.springframework.integration.file.filters.AcceptAllFileListFilter
-
- acceptIfCondition(boolean, T, Consumer<T>) - Method in class org.springframework.integration.util.JavaUtils
-
Invoke Consumer.accept(Object)
with the value if the condition is true.
- acceptIfCondition(boolean, T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.integration.util.JavaUtils
-
Invoke BiConsumer.accept(Object, Object)
with the arguments if the
condition is true.
- acceptIfHasText(String, Consumer<String>) - Method in class org.springframework.integration.util.JavaUtils
-
Invoke Consumer.accept(Object)
with the value if it is not null or empty.
- acceptIfHasText(T, String, BiConsumer<T, String>) - Method in class org.springframework.integration.util.JavaUtils
-
Invoke BiConsumer.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.util.JavaUtils
-
Invoke Consumer.accept(Object)
with the value if it is not null or empty.
- acceptIfNotEmpty(T[], Consumer<T[]>) - Method in class org.springframework.integration.util.JavaUtils
-
Invoke Consumer.accept(Object)
with the value if it is not null or empty.
- acceptIfNotNull(T, Consumer<T>) - Method in class org.springframework.integration.util.JavaUtils
-
Invoke Consumer.accept(Object)
with the value if it is not null.
- acceptIfNotNull(T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.integration.util.JavaUtils
-
Invoke BiConsumer.accept(Object, Object)
with the arguments if the t2
argument 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 of
CollectionFilter
that 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
-
- AcceptOnceFileListFilter(int) - Constructor for class org.springframework.integration.file.filters.AcceptOnceFileListFilter
-
Creates an AcceptOnceFileListFilter that is based on a bounded queue.
- AcceptOnceFileListFilter() - Constructor for class org.springframework.integration.file.filters.AcceptOnceFileListFilter
-
Creates an AcceptOnceFileListFilter based on an unbounded 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 when ContainerProperties.AckMode#COUNT
or ContainerProperties.AckMode#COUNT_TIME
is being used.
- ackCounter(int) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
-
- ackDiscarded(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
-
A boolean
flag to indicate if
FilteringMessageListenerAdapter
should 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(AcknowledgmentCallback.Status) - Method in interface org.springframework.integration.acks.AcknowledgmentCallback
-
Acknowledge the message.
- acknowledge() - Method in interface org.springframework.integration.acks.AcknowledgmentCallback
-
- acknowledge() - Method in interface org.springframework.integration.acks.SimpleAcknowledgment
-
Acknowledge the message delivery.
- 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
-
- acknowledge() - 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 in org.springframework.integration.acks
-
- AcknowledgmentCallbackFactory<T> - Interface in org.springframework.integration.acks
-
- ackOnError(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
-
- ackTime(long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
-
Set the time (ms) after which outstanding offsets should be committed when
ContainerProperties.AckMode#TIME
or
ContainerProperties.AckMode#COUNT_TIME
is being used.
- ackTimeout(long) - Method in class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
-
- AckUtils - Class in org.springframework.integration.acks
-
- acquire(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
- acquire(String) - Method in interface org.springframework.integration.jdbc.lock.LockRepository
-
- 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(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
-
- add(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
-
- add(String, PropertyAccessor) - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
-
Add the provided named property accessor.
- add(PropertyAccessor...) - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
-
Add the provided property accessors.
- add(Properties) - Method in class org.springframework.integration.history.MessageHistory
-
- add(int, Properties) - Method in class org.springframework.integration.history.MessageHistory
-
- add(MessageSelector) - Method in class org.springframework.integration.selector.MessageSelectorChain
-
Add a selector to the end of the chain.
- add(int, MessageSelector) - Method in class org.springframework.integration.selector.MessageSelectorChain
-
Add a selector to the chain at the specified index.
- 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
-
- addAll(Collection<? extends Properties>) - Method in class org.springframework.integration.history.MessageHistory
-
- addAll(int, 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 allow list.
- addAttribute(String, Object) - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
-
- addBean(Object) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
-
Add an object which will be registered as an
IntegrationFlow
dependant 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 an
IntegrationFlow
dependant 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 an
IntegrationFlow
dependant 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 an
IntegrationFlow
dependant bean in the
application context.
- 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.CompositeFileListFilter
-
- addDiscardCallback(Consumer<F>) - Method in interface org.springframework.integration.file.filters.DiscardAwareFileListFilter
-
- addDiscardCallback(Consumer<File>) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
-
- 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
-
- addFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
-
- addFilters(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
-
Not thread safe.
- 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(ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
-
- addInterceptor(int, 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(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Add a channel interceptor to the specified index of the list.
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
-
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
-
- addLifecyclesToRole(String, List<String>) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
- addLifecycleToRole(String, SmartLifecycle) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
- addLifecycleToRole(String, String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
- addListener(MetadataStoreListener) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
-
- addListener(MetadataStoreListener) - Method in interface org.springframework.integration.metadata.ListenableMetadataStore
-
Registers 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.jdbc.store.JdbcMessageStore
-
- addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- 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.annotation.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 a
TcpListener
, 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
-
- 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
-
- addPatternMapping(Pattern, ChannelAccessPolicy) - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
-
- 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, String) - Method in class org.springframework.integration.router.RecipientListRouter
-
- addRecipient(String) - Method in class org.springframework.integration.router.RecipientListRouter
-
- 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
-
- addRecipient(String, String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
-
Add a recipient with channelName and expression.
- addRecipient(String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
-
Add a recipient with channelName.
- addSessionFactory(String, SessionFactory<F>) - Method in class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
-
- 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, int) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
-
Add a topic to the subscribed list.
- 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.MqttPahoMessageDrivenChannelAdapter
-
- 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 of
Advice
objects to be applied, in nested order, to the
endpoint's handler.
- advice(Advice...) - Method in class org.springframework.integration.dsl.PollerSpec
-
Specify AOP
Advice
s for the
pollingTask
.
- adviceChain(Advice...) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
- adviceChain - Variable in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
- adviceChain - Variable in class org.springframework.integration.dsl.ConsumerEndpointSpec
-
- adviceChain(Advice...) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
Configure a chain of
Advice
objects 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, Message<?>) - Constructor for class org.springframework.integration.message.AdviceMessage
-
- AdviceMessage(T, Map<String, Object>, Message<?>) - Constructor for class org.springframework.integration.message.AdviceMessage
-
- AdviceMessage(T, MessageHeaders, Message<?>) - Constructor for class org.springframework.integration.message.AdviceMessage
-
- AdviceMessageJacksonDeserializer - Class in org.springframework.integration.support.json
-
- AdviceMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.AdviceMessageJacksonDeserializer
-
- afterAll(ExtensionContext) - Method in class org.springframework.integration.test.condition.LogLevelsCondition
-
- afterCommit(Object) - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
- afterCommit(String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterCommit(String, String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterCommit(MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterCommit(String, MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterEach(ExtensionContext) - Method in class org.springframework.integration.test.condition.LogLevelsCondition
-
- afterMessageHandled(Message<?>, MessageChannel, MessageHandler, Exception) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
-
- afterMessageHandled(Message<?>, MessageChannel, MessageHandler, Exception) - Method in class org.springframework.integration.security.channel.SecurityContextPropagationChannelInterceptor
-
- afterPropertiesSet() - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
-
- afterPropertiesSet() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
-
- 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.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.http.inbound.IntegrationRequestMappingHandlerMapping
-
- 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
-
- afterPropertiesSet() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- afterPropertiesSet() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- 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.MongoDbChannelMessageStore
-
- afterPropertiesSet() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- 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(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.aop.CompoundTriggerAdvice
-
- afterReceive(Message<?>, Object) - Method in class org.springframework.integration.aop.CompoundTriggerAdvice
-
- afterReceive(Message<?>, Object) - Method in interface org.springframework.integration.aop.MessageSourceMutator
-
- 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<?>, Object) - Method in interface org.springframework.integration.aop.ReceiveMessageAdvice
-
- afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
-
Deprecated.
- afterReceive(Message<?>, Object) - Method in class org.springframework.integration.aop.SimpleActiveIdleReceiveMessageAdvice
-
- afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.RotatingServerAdvice
-
- 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
-
- 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
-
- 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<?>>, 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<?>>) - 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.ResequencingMessageHandler
-
Perform group removal if its size
is equal to the sequenceSize
.
- afterRollback(Object) - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
- afterRollback(String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterRollback(String, String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterRollback(MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterRollback(String, 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, MessageChannel) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
-
- afterSessionEnded(WebSocketSession, CloseStatus) - Method in interface org.springframework.integration.websocket.WebSocketListener
-
- afterSessionStarted(WebSocketSession) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
- afterSessionStarted(WebSocketSession, MessageChannel) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
-
- afterSessionStarted(WebSocketSession) - Method in interface org.springframework.integration.websocket.WebSocketListener
-
- 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.config.annotation.MessagingAnnotationPostProcessor
-
- 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.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.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
-
- aggregate() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- aggregate(Consumer<AggregatorSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- AggregatedXmlMessageValidationException - Exception in org.springframework.integration.xml
-
- AggregatedXmlMessageValidationException(List<Throwable>) - Constructor for exception 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 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 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 the
MessagingTemplate
to send downstream.
- aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
-
- AggregatingMessageHandler - Class in org.springframework.integration.aggregator
-
- AggregatingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
-
- AggregatingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
-
- AggregatingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
-
- Aggregator - Annotation Type in org.springframework.integration.annotation
-
Indicates that a method is capable of aggregating messages.
- AggregatorAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
-
- AggregatorAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
-
- AggregatorFactoryBean - Class in org.springframework.integration.config
-
- 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
-
- AggregatorSpec - Class in org.springframework.integration.dsl
-
- AggregatorSpec() - Constructor for class org.springframework.integration.dsl.AggregatorSpec
-
- 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
-
Allocates 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.
- AllowListDeserializingConverter - Class in org.springframework.integration.support.converter
-
- AllowListDeserializingConverter() - Constructor for class org.springframework.integration.support.converter.AllowListDeserializingConverter
-
- AllowListDeserializingConverter(ClassLoader) - Constructor for class org.springframework.integration.support.converter.AllowListDeserializingConverter
-
- AllowListDeserializingConverter(Deserializer<Object>) - Constructor for class org.springframework.integration.support.converter.AllowListDeserializingConverter
-
- 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 extends AmqpBaseInboundChannelAdapterSpec<S>> - Class in org.springframework.integration.amqp.dsl
-
- AmqpBaseInboundChannelAdapterSpec(AmqpInboundChannelAdapter) - Constructor for class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
- AmqpBaseInboundGatewaySpec<S extends AmqpBaseInboundGatewaySpec<S>> - Class in org.springframework.integration.amqp.dsl
-
- AmqpBaseInboundGatewaySpec(AmqpInboundGateway) - Constructor for class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
- AmqpBaseOutboundEndpointSpec<S extends AmqpBaseOutboundEndpointSpec<S,E>,E extends AbstractAmqpOutboundEndpoint> - Class in org.springframework.integration.amqp.dsl
-
- AmqpBaseOutboundEndpointSpec() - Constructor for class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
- 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
-
- amqpChannelFactoryBean - Variable in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
- 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
-
- 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(AbstractMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- AmqpInboundChannelAdapter.BatchListener - Class in org.springframework.integration.amqp.inbound
-
- AmqpInboundChannelAdapter.BatchMode - Enum 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
-
- 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
-
- AmqpInboundChannelAdapterSMLCSpec(SimpleMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSMLCSpec
-
- AmqpInboundChannelAdapterSpec<S extends AmqpInboundChannelAdapterSpec<S,C>,C extends AbstractMessageListenerContainer> - Class in org.springframework.integration.amqp.dsl
-
- AmqpInboundChannelAdapterSpec(AbstractMessageListenerContainerSpec<?, 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(AbstractMessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
- AmqpInboundGateway.Listener - Class in org.springframework.integration.amqp.inbound
-
- AmqpInboundGatewayDMLCSpec - Class in org.springframework.integration.amqp.dsl
-
- AmqpInboundGatewayDMLCSpec(DirectMessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewayDMLCSpec
-
- AmqpInboundGatewayDMLCSpec(DirectMessageListenerContainer) - 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
-
- AmqpInboundGatewaySMLCSpec(SimpleMessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySMLCSpec
-
- AmqpInboundGatewaySMLCSpec(SimpleMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySMLCSpec
-
- AmqpInboundGatewaySpec<S extends AmqpInboundGatewaySpec<S,C>,C extends AbstractMessageListenerContainer> - Class in org.springframework.integration.amqp.dsl
-
- 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 extends AmqpMessageChannelSpec<S,T>,T extends AbstractAmqpChannel> - Class in org.springframework.integration.amqp.dsl
-
- 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
-
- AmqpMessageHeaderErrorMessageStrategy() - Constructor for class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
-
- AmqpMessageSource - Class in org.springframework.integration.amqp.inbound
-
- 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 extends 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 extends AmqpPollableMessageChannelSpec<S,T>,T extends AbstractAmqpChannel> - Class in org.springframework.integration.amqp.dsl
-
- 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
-
- 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 - Class in org.springframework.integration.gateway
-
- AnnotationGatewayProxyFactoryBean(Class<?>) - Constructor for class org.springframework.integration.gateway.AnnotationGatewayProxyFactoryBean
-
- AnnotationMetadataAdapter - Class in org.springframework.integration.config.annotation
-
- AnnotationMetadataAdapter() - Constructor for class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
-
- annotationType - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- 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
-
ApplicationEvent
generated 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
-
ApplicationEvent
generated 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(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<?>, 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<?>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- append(Message<?>, String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- 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
-
- appendNewLine(boolean) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
-
If true
will append a new-line after each write.
- appendNewLine(boolean) - Method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
-
- ApplicationEventListeningMessageProducer - Class in org.springframework.integration.event.inbound
-
- ApplicationEventListeningMessageProducer() - Constructor for class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- 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(MessageGroup) - Method in class org.springframework.integration.aggregator.DefaultAggregateHeadersFunction
-
- apply(Statement, FrameworkMethod, Object) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
-
- apply(Statement, Description) - Method in class org.springframework.integration.test.support.LongRunningIntegrationTest
-
- 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
-
- 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.SplitterEndpointSpec
-
Set the applySequence flag to the specified value.
- applySequence(boolean) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
-
A boolean
flag to indicate if sequenceDetails
should 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.
- ARGUMENT_RESOLVER_MESSAGE_CONVERTER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
-
- ArgumentsStrategy - Interface in org.springframework.integration.redis.outbound
-
- 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<FTPFile>) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
-
- asFileInfoList(Collection<FTPFile>) - Method in class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
-
- asFileInfoList(Collection<ChannelSftp.LsEntry>) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
-
- asFileInfoList(Collection<ChannelSftp.LsEntry>) - 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.BaseWsInboundGatewaySpec
-
- 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
-
- assertions - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer
-
- assertReceived(String) - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
-
- assertReceiver() - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
-
- assertRemoteFileTemplateMutability(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- async(boolean) - Method in class org.springframework.integration.dsl.BarrierSpec
-
- 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(MessageChannel, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertAndSend(String, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertAndSend(Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertAndSend(MessageChannel, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertAndSend(String, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertSendAndReceive(Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertSendAndReceive(MessageChannel, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertSendAndReceive(String, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertSendAndReceive(Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertSendAndReceive(MessageChannel, Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertSendAndReceive(String, Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertSendAndReceive(Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertSendAndReceive(MessageChannel, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertSendAndReceive(String, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertSendAndReceive(MessageChannel, Object, MessagePostProcessor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncExecutor(Executor) - Method in class org.springframework.integration.dsl.GatewayProxySpec
-
Provide a reference to an implementation of
Executor
to use for any of the interface methods that have a
Future
return type.
- 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(PollableChannel) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncReceive(String) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncReceive() - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncReceive(PollableChannel) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncReceive(String) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncReceiveAndConvert() - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncReceiveAndConvert(PollableChannel) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncReceiveAndConvert(String) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncReceiveAndConvert() - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncReceiveAndConvert(PollableChannel) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncReceiveAndConvert(String) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSend(Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncSend(MessageChannel, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncSend(String, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncSend(Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSend(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSend(String, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSendAndReceive(Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncSendAndReceive(MessageChannel, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncSendAndReceive(String, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncSendAndReceive(Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSendAndReceive(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSendAndReceive(String, 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
-
- AttributePollingMessageSource() - Constructor for class org.springframework.integration.jmx.AttributePollingMessageSource
-
- 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
-
- autoCloseFolder(boolean) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
When configured to false
, the folder is not closed automatically after a fetch.
- autoCloseFolder(boolean) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
-
When configured to false
, the folder is not closed automatically after a fetch.
- 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
-
A boolean
flag 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
-
A boolean
flag 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
-
- 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
-
The
boolean
flag to indication if an
IntegrationFlow
must be started
automatically after registration.
- autoStartup(boolean) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
-
The
boolean
flag to indication if an
IntegrationFlow
must 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
-
- BACKLOG - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- backlog(int) - Method in class org.springframework.integration.ip.dsl.TcpServerConnectionFactorySpec
-
- backOff(BackOff) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
- barrier(long) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- barrier(long, Consumer<BarrierSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- BarrierMessageHandler - Class in org.springframework.integration.aggregator
-
A message handler that suspends the thread until a message with corresponding
correlation is passed into the
trigger
method or
the timeout occurs.
- BarrierMessageHandler(long) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and default correlation and
output strategies.
- BarrierMessageHandler(long, MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and output processor, and default
correlation strategy.
- BarrierMessageHandler(long, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and correlation strategy, and default
output processor.
- BarrierMessageHandler(long, MessageGroupProcessor, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and output processor, and default
correlation strategy.
- BarrierMessageHandler(long, long) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeouts and default correlation and
output strategies.
- BarrierMessageHandler(long, long, MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and output processor, and default
correlation strategy.
- BarrierMessageHandler(long, long, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and correlation strategy, and default
output processor.
- BarrierMessageHandler(long, long, MessageGroupProcessor, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and output processor, and default
correlation strategy.
- BarrierParser - Class in org.springframework.integration.config.xml
-
Parser for <int:barrier/>
.
- BarrierParser() - Constructor for class org.springframework.integration.config.xml.BarrierParser
-
- BarrierSpec - Class in org.springframework.integration.dsl
-
- BarrierSpec(long) - Constructor for class org.springframework.integration.dsl.BarrierSpec
-
- BASE_PACKAGE - Static variable in class org.springframework.integration.config.IntegrationConfigUtils
-
- BaseHttpInboundEndpoint - Class in org.springframework.integration.http.inbound
-
- BaseHttpInboundEndpoint(boolean) - Constructor for class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
- BaseHttpInboundEndpointSpec<S extends BaseHttpInboundEndpointSpec<S,E>,E extends HttpRequestHandlingEndpointSupport> - Class in org.springframework.integration.http.dsl
-
- BaseHttpInboundEndpointSpec(E, String...) - Constructor for class org.springframework.integration.http.dsl.BaseHttpInboundEndpointSpec
-
- BaseHttpMessageHandlerSpec<S extends BaseHttpMessageHandlerSpec<S,E>,E extends AbstractHttpRequestExecutingMessageHandler> - Class in org.springframework.integration.http.dsl
-
- BaseHttpMessageHandlerSpec(E) - Constructor for class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
-
- BaseIntegrationFlowDefinition<B extends BaseIntegrationFlowDefinition<B>> - Class in org.springframework.integration.dsl
-
The Builder
pattern implementation for the EIP-method chain.
- BaseIntegrationFlowDefinition() - Constructor for class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- BaseIntegrationFlowDefinition.ReplyProducerCleaner - Class in org.springframework.integration.dsl
-
- BaseWsInboundGatewaySpec<S extends BaseWsInboundGatewaySpec<S,E>,E extends AbstractWebServiceInboundGateway> - Class in org.springframework.integration.ws.dsl
-
- BaseWsInboundGatewaySpec() - Constructor for class org.springframework.integration.ws.dsl.BaseWsInboundGatewaySpec
-
Construct an instance.
- BaseWsOutboundGatewaySpec<S extends BaseWsOutboundGatewaySpec<S,E>,E extends AbstractWebServiceOutboundGateway> - Class in org.springframework.integration.ws.dsl
-
- BaseWsOutboundGatewaySpec() - Constructor for class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
-
- BasicMessageGroupStore - Interface in org.springframework.integration.store
-
Defines a minimal message group store with basic capabilities.
- batchingStrategy(BatchingStrategy) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Set a batching strategy to use when de-batching messages.
- BatchListener() - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchListener
-
- batchMessageConverter(BatchMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
-
Set the message converter to use with a batch-based consumer.
- batchMode(AmqpInboundChannelAdapter.BatchMode) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSMLCSpec
-
- batchSize(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
Configure the batch size.
- batchSize(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-
The batch size to use.
- bcc(String...) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the bcc: addresses.
- BCC - Static variable in class org.springframework.integration.mail.MailHeaders
-
- bccExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the expression that will be evaluated to determine the bcc: addresses.
- bccFunction(Function<Message<P>, String[]>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set a function that will be invoked to determine the bcc: addresses based on the
message.
- BEAN_NAME - Static variable in class org.springframework.integration.scripting.config.ScriptExecutingProcessorFactory
-
- beanAnnotationAware() - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- beanAnnotationAware() - Method in class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
-
- BeanDefinitionRegisteringParser - Interface in org.springframework.integration.config.xml
-
Simple strategy interface for parsers that are responsible
for parsing an element, creating a bean definition, and then
registering the bean.
- beanFactory - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- BeanFactoryChannelResolver - Class in org.springframework.integration.support.channel
-
- BeanFactoryChannelResolver() - Constructor for class org.springframework.integration.support.channel.BeanFactoryChannelResolver
-
- BeanFactoryChannelResolver(BeanFactory) - Constructor for class org.springframework.integration.support.channel.BeanFactoryChannelResolver
-
- BeanFactoryTypeConverter - Class in org.springframework.integration.util
-
- BeanFactoryTypeConverter() - Constructor for class org.springframework.integration.util.BeanFactoryTypeConverter
-
- BeanFactoryTypeConverter(ConversionService) - Constructor for class org.springframework.integration.util.BeanFactoryTypeConverter
-
- beanName(String) - Method in class org.springframework.integration.dsl.GatewayProxySpec
-
- BeanNameMessageProcessor<T> - Class in org.springframework.integration.handler
-
- BeanNameMessageProcessor(String, String) - Constructor for class org.springframework.integration.handler.BeanNameMessageProcessor
-
- BeanPropertyParameterSource - Class in org.springframework.integration.jpa.support.parametersource
-
- BeanPropertyParameterSource(Object) - Constructor for class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSource
-
Create a new BeanPropertySqlParameterSource for the given bean.
- BeanPropertyParameterSourceFactory - Class in org.springframework.integration.jpa.support.parametersource
-
- BeanPropertyParameterSourceFactory() - Constructor for class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSourceFactory
-
- BeanPropertySqlParameterSourceFactory - Class in org.springframework.integration.jdbc
-
- BeanPropertySqlParameterSourceFactory() - Constructor for class org.springframework.integration.jdbc.BeanPropertySqlParameterSourceFactory
-
- beforeCommit(String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- beforeCommit(String, String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- beforeCommit(MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- beforeCommit(String, MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- beforeEach(ExtensionContext) - Method in class org.springframework.integration.test.condition.LogLevelsCondition
-
- beforeHandle(Message<?>, MessageChannel, MessageHandler) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
-
- beforeReceive(Object) - Method in interface org.springframework.integration.aop.MessageSourceMutator
-
- beforeReceive(MessageSource<?>) - Method in interface org.springframework.integration.aop.MessageSourceMutator
-
Subclasses can decide whether to proceed with this poll.
- beforeReceive(Object) - Method in interface org.springframework.integration.aop.ReceiveMessageAdvice
-
- beforeReceive(MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.RotatingServerAdvice
-
- beforeReceive(MessageSource<?>) - Method in interface org.springframework.integration.file.remote.aop.RotationPolicy
-
Invoked before the message source receive() method.
- beforeReceive(MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
-
- beforeShutdown() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- beforeShutdown() - Method in interface org.springframework.integration.context.OrderlyShutdownCapable
-
Called before shutdown begins.
- beforeShutdown() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
- beforeShutdown() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
- beforeShutdown() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- beforeShutdown() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- beforeShutdown() - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- beforeShutdown() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- beforeShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
-
- beforeShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
- beforeShutdown() - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
-
- BinaryToMessageConverter - Class in org.springframework.integration.mongodb.support
-
- BinaryToMessageConverter() - Constructor for class org.springframework.integration.mongodb.support.BinaryToMessageConverter
-
- bindFunction(BiFunction<DatabaseClient.GenericExecuteSpec, ?, DatabaseClient.GenericExecuteSpec>) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
-
Set a
BiFunction
which is used to bind parameters into the update query.
- bindPort(int) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
-
Configure a port for TCP protocol binding via ZMQ.Socket.bind(String)
.
- bindSourceMessage(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Set to true to bind the source message in the headers.
- BODY - Static variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
-
- bodyExtractor(BodyExtractor<?, ClientHttpResponse>) - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
-
- BOOLEAN - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
-
- BooleanTestXPathMessageSelector - Class in org.springframework.integration.xml.selector
-
- BooleanTestXPathMessageSelector(String, Map<String, String>) - Constructor for class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
-
Create a boolean testing XPath
MessageSelector
supporting multiple namespaces.
- BooleanTestXPathMessageSelector(String, String, String) - Constructor for class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
-
Create a boolean testing XPath
MessageSelector
supporting a single
namespace.
- BooleanTestXPathMessageSelector(String) - Constructor for class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
-
- BooleanTestXPathMessageSelector(XPathExpression) - Constructor for class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
-
- bounded() - Method in interface org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry.KeyToPathStrategy
-
- BoundRabbitChannelAdvice - Class in org.springframework.integration.amqp.support
-
An advice that causes all downstream
RabbitOperations
operations to be executed
on the same channel, as long as there are no thread handoffs, since the channel is
bound to the thread.
- BoundRabbitChannelAdvice(RabbitOperations) - Constructor for class org.springframework.integration.amqp.support.BoundRabbitChannelAdvice
-
Construct an instance that doesn't wait for confirms.
- BoundRabbitChannelAdvice(RabbitOperations, Duration) - Constructor for class org.springframework.integration.amqp.support.BoundRabbitChannelAdvice
-
Construct an instance that waits for publisher confirms (if
configured and waitForConfirmsTimeout is not null).
- bridge() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
BridgeHandler
to the current integration flow position.
- bridge(Consumer<GenericEndpointSpec<BridgeHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
BridgeHandler
to the current integration flow position.
- BridgeFrom - Annotation Type in org.springframework.integration.annotation
-
- BridgeFromAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
-
- BridgeFromAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
-
- BridgeHandler - Class in org.springframework.integration.handler
-
A simple MessageHandler implementation that passes the request Message
directly to the output channel without modifying it.
- BridgeHandler() - Constructor for class org.springframework.integration.handler.BridgeHandler
-
- BridgeParser - Class in org.springframework.integration.config.xml
-
Parser for the <bridge> element.
- BridgeParser() - Constructor for class org.springframework.integration.config.xml.BridgeParser
-
- BridgeTo - Annotation Type in org.springframework.integration.annotation
-
- BridgeToAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
-
- BridgeToAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.BridgeToAnnotationPostProcessor
-
- BroadcastCapableChannel - Interface in org.springframework.integration.channel
-
- BroadcastingDispatcher - Class in org.springframework.integration.dispatcher
-
A broadcasting dispatcher implementation.
- BroadcastingDispatcher() - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
- BroadcastingDispatcher(Executor) - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
- BroadcastingDispatcher(boolean) - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
- BroadcastingDispatcher(Executor, boolean) - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
- BroadcastPublishSubscribeSpec - Class in org.springframework.integration.dsl
-
- BroadcastPublishSubscribeSpec(BroadcastCapableChannel) - Constructor for class org.springframework.integration.dsl.BroadcastPublishSubscribeSpec
-
- bufferSize(int) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
-
Set the buffer size to use while writing to files; default 8192.
- build() - Method in interface org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapFinalBuilder
-
- build() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
- build() - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.CounterBuilder
-
Build the counter.
- build() - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.GaugeBuilder
-
Build the gauge.
- build() - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.TimerBuilder
-
Build the timer.
- build() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounterBuilder
-
- build() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGaugeBuilder
-
- build() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimerBuilder
-
- build() - Method in class org.springframework.integration.support.MessageBuilder
-
- build() - Method in class org.springframework.integration.support.MutableMessageBuilder
-
- build() - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
-
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpChannelParser
-
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
-
Subclasses must implement this method to create the bean definition.
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PointToPointChannelParser
-
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PublishSubscribeChannelParser
-
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.jms.config.JmsChannelParser
-
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.kafka.config.xml.KafkaChannelParser
-
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.redis.config.RedisChannelParser
-
- buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
-
- buildErrorMessage(Message<?>, Exception) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- buildErrorMessage(Message<?>, Throwable) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.kafka.support.RawRecordHeaderErrorMessageStrategy
-
- buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.support.DefaultErrorMessageStrategy
-
- buildErrorMessage(Throwable, AttributeAccessor) - Method in interface org.springframework.integration.support.ErrorMessageStrategy
-
Build the error message.
- buildFlow() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
-
- buildKey(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
-
- buildLambdaMessageProcessorForBeanMethod(Method, Object) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- buildMessage(Object) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
-
- buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.AdviceMessageJacksonDeserializer
-
- buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.ErrorMessageJacksonDeserializer
-
- buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.GenericMessageJacksonDeserializer
-
- buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
-
- buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.MutableMessageJacksonDeserializer
-
- buildNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
- buildNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
-
- buildNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
- buildReply(MessageConverter, Message) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- buildResolvableType(ClassLoader, Object, Object, Object) - Static method in class org.springframework.integration.mapping.support.JsonHeaders
-
- buildResolvableType(Class<?>, Class<?>, Class<?>) - Static method in class org.springframework.integration.mapping.support.JsonHeaders
-
- buildResult(Object, Message<?>, Message<?>) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
-
Override to change the default mechanism by which the inbound and release messages
are returned as a result.
- buildReturnedMessage(Message, int, String, String, String, MessageConverter) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- buildReturnedMessage(ReturnedMessage, MessageConverter) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- buildSendTimer(boolean, String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- buildSendTimer(boolean, String) - Method in class org.springframework.integration.handler.MessageHandlerSupport
-
- ByteArrayCrLfSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
Reads data in an InputStream to a byte[]; data must be terminated by \r\n
(not included in resulting byte[]).
- ByteArrayCrLfSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
-
- ByteArrayElasticRawDeserializer - Class in org.springframework.integration.ip.tcp.serializer
-
A deserializer that uses a
ByteArrayOutputStream
instead of a fixed buffer,
allowing the buffer to grow as needed.
- ByteArrayElasticRawDeserializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayElasticRawDeserializer
-
- ByteArrayElasticRawDeserializer(int) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayElasticRawDeserializer
-
- ByteArrayLengthHeaderSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
Reads data in an InputStream to a byte[]; data must be preceded by
a binary length (network byte order, not included in resulting byte[]).
- ByteArrayLengthHeaderSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
- ByteArrayLengthHeaderSerializer(int) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
Construct the serializer using the supplied header size.
- ByteArrayLfSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
- ByteArrayLfSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayLfSerializer
-
- ByteArrayRawSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
A byte array (de)serializer that does nothing with the payload; sends it raw.
- ByteArrayRawSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
-
- ByteArrayRawSerializer(boolean) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
-
Treat socket timeouts as a normal EOF and emit the (possibly partial)
message.
- ByteArraySingleTerminatorSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
Reads data in an InputStream to a byte[]; data must be terminated by a single
byte (not included in resulting byte[]).
- ByteArraySingleTerminatorSerializer(byte) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArraySingleTerminatorSerializer
-
- ByteArrayStxEtxSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
Reads data in an InputStream to a byte[]; data must be prefixed by <stx> and
terminated by <etx> (not included in resulting byte[]).
- ByteArrayStxEtxSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
-
- BytesMessageMapper - Interface in org.springframework.integration.mapping
-
- bytesToString(byte[], String) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
-
Utility method for null-safe conversion from byte[] to String
- ByteStreamReadingMessageSource - Class in org.springframework.integration.stream
-
A pollable source for receiving bytes from an
InputStream
.
- ByteStreamReadingMessageSource(InputStream) - Constructor for class org.springframework.integration.stream.ByteStreamReadingMessageSource
-
- ByteStreamReadingMessageSource(InputStream, int) - Constructor for class org.springframework.integration.stream.ByteStreamReadingMessageSource
-
- ByteStreamWritingMessageHandler - Class in org.springframework.integration.stream
-
- ByteStreamWritingMessageHandler(OutputStream) - Constructor for class org.springframework.integration.stream.ByteStreamWritingMessageHandler
-
- ByteStreamWritingMessageHandler(OutputStream, int) - Constructor for class org.springframework.integration.stream.ByteStreamWritingMessageHandler
-
- cacheLevel(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
Specify the level of caching that this listener container is allowed to apply.
- cacheLevel(Integer) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
-
- cacheLevel(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
-
- cacheLevelName(String) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
Specify the level of caching that this listener container is allowed to apply,
in the form of the name of the corresponding constant: e.g.
- CacheListeningMessageProducer - Class in org.springframework.integration.gemfire.inbound
-
An inbound endpoint that listens to a GemFire region for events and then publishes Messages to
a channel.
- CacheListeningMessageProducer(Region<?, ?>) - Constructor for class org.springframework.integration.gemfire.inbound.CacheListeningMessageProducer
-
- CacheRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
-
The
AbstractRequestHandlerAdvice
implementation for caching
AbstractReplyProducingMessageHandler.RequestHandler#handleRequestMessage(Message)
results.
- CacheRequestHandlerAdvice(String...) - Constructor for class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
-
- CacheWritingMessageHandler - Class in org.springframework.integration.gemfire.outbound
-
- CacheWritingMessageHandler(Region) - Constructor for class org.springframework.integration.gemfire.outbound.CacheWritingMessageHandler
-
- CachingClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
-
Connection factory that caches connections from the underlying target factory.
- CachingClientConnectionFactory(AbstractClientConnectionFactory, int) - Constructor for class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
Construct a caching connection factory that delegates to the provided factory, with
the provided pool size.
- CachingSessionFactory<F> - Class in org.springframework.integration.file.remote.session
-
A
SessionFactory
implementation that caches Sessions for reuse without
requiring reconnection each time the Session is retrieved from the factory.
- CachingSessionFactory(SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.session.CachingSessionFactory
-
Create a CachingSessionFactory with an unlimited number of sessions.
- CachingSessionFactory(SessionFactory<F>, int) - Constructor for class org.springframework.integration.file.remote.session.CachingSessionFactory
-
Create a CachingSessionFactory with the specified session limit.
- CachingSessionFactory.CachedSession - Class in org.springframework.integration.file.remote.session
-
- call() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator.LeaderSelector
-
- CallerBlocksPolicy - Class in org.springframework.integration.util
-
- CallerBlocksPolicy(long) - Constructor for class org.springframework.integration.util.CallerBlocksPolicy
-
Construct instance based on the provided maximum wait time.
- canAdd(Message<?>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler.SequenceAwareMessageGroup
-
This method determines whether messages have been added to this group that
supersede the given message based on its sequence id.
- canAdd(Message<?>) - Method in interface org.springframework.integration.store.MessageGroup
-
Query if the message can be added.
- canAdd(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.FilterFactoryBean
-
MessageFilter is an ARPMH.
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.TransformerFactoryBean
-
- cancelIdleInterval(long) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
How often to recycle the idle task (in case of a silently dropped connection).
- cancelPing() - Method in class org.springframework.integration.mail.ImapMailReceiver
-
The hook to be called when we need to cancel the current ping task and close the mail folder.
- canConvert(Class<?>, Class<?>) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
-
- canConvert(TypeDescriptor, TypeDescriptor) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
-
- Candidate - Interface in org.springframework.integration.leader
-
Interface that defines the contract for candidates to participate
in a leader election.
- canRead(Class<?>, MediaType) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
-
- canRead(EvaluationContext, Object, String) - Method in class org.springframework.integration.json.JsonPropertyAccessor
-
- canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingReleaseStrategy
-
Evaluate the expression provided on the
MessageGroup
and return the result (must be boolean).
- canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.MessageCountReleaseStrategy
-
Release the group if it has more messages than the threshold and has not previously been released.
- canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
-
- canRelease(MessageGroup) - Method in interface org.springframework.integration.aggregator.ReleaseStrategy
-
- canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
-
- canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.SimpleSequenceSizeReleaseStrategy
-
- canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
-
- canWrite(Class<?>, MediaType) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
-
- canWrite(Class<?>, MediaType) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
-
- canWrite(EvaluationContext, Object, String) - Method in class org.springframework.integration.json.JsonPropertyAccessor
-
- capacity(int) - Method in class org.springframework.integration.dsl.PriorityChannelSpec
-
- capacity - Variable in class org.springframework.integration.dsl.QueueChannelSpec
-
- capacity(Integer) - Method in class org.springframework.integration.dsl.QueueChannelSpec.MessageStoreSpec
-
- categories(String...) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
-
Specify the categories for logging level adjusting configured before.
- categories(boolean, String...) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
-
Specify the categories for logging level adjusting configured before.
- cause - Variable in class org.springframework.integration.events.IntegrationEvent
-
- cc(String...) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the cc: addresses.
- CC - Static variable in class org.springframework.integration.mail.MailHeaders
-
- ccExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the expression that will be evaluated to determine the cc: addresses.
- ccFunction(Function<Message<P>, String[]>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set a function that will be invoked to determine the cc: addresses based on the
message.
- ChainFileListFilter<F> - Class in org.springframework.integration.file.filters
-
- ChainFileListFilter() - Constructor for class org.springframework.integration.file.filters.ChainFileListFilter
-
- ChainFileListFilter(Collection<? extends FileListFilter<F>>) - Constructor for class org.springframework.integration.file.filters.ChainFileListFilter
-
- ChainParser - Class in org.springframework.integration.config.xml
-
Parser for the <chain> element.
- ChainParser() - Constructor for class org.springframework.integration.config.xml.ChainParser
-
- CHANGE_STREAM_OPERATION_TYPE - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
-
The header for change stream event type.
- CHANGE_STREAM_RESUME_TOKEN - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
-
The header for change stream event resume token.
- CHANGE_STREAM_TIMESTAMP - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
-
The header for change stream event timestamp.
- changeStreamInboundChannelAdapter(ReactiveMongoOperations) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
-
- channel(ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpMessageChannelSpec.
- channel(String, ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpMessageChannelSpec.
- channel(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- channel(MessageChannelSpec<?, ?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- channel(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- channel(Function<Channels, MessageChannelSpec<?, ?>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- channel - Variable in class org.springframework.integration.dsl.MessageChannelSpec
-
- channel(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
-
- channel(String, ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
-
- channel(KafkaTemplate<?, ?>, KafkaListenerContainerFactory<?>, String) - Static method in class org.springframework.integration.kafka.dsl.Kafka
-
Create a spec for a subscribable channel with the provided parameters.
- CHANNEL_INITIALIZER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
-
- CHANNEL_RESOLVER_BEAN_NAME - Static variable in class org.springframework.integration.support.channel.ChannelResolverUtils
-
- ChannelAccessPolicy - Interface in org.springframework.integration.security.channel
-
Interface to encapsulate ConfigAttribute
s for secured channel
send and receive operations.
- ChannelInterceptorList(LogAccessor) - Constructor for class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
-
- ChannelInterceptorParser - Class in org.springframework.integration.config.xml
-
A helper class for parsing the sub-elements of a channel's
interceptors element.
- ChannelInterceptorParser() - Constructor for class org.springframework.integration.config.xml.ChannelInterceptorParser
-
- ChannelInvocation - Class in org.springframework.integration.security.channel
-
- ChannelInvocation(MethodInvocation) - Constructor for class org.springframework.integration.security.channel.ChannelInvocation
-
- channelMapping(K, String) - Method in class org.springframework.integration.dsl.RouterSpec
-
- channelMapping(K, MessageChannel) - Method in class org.springframework.integration.dsl.RouterSpec
-
The router mapping configuration based on the provided generic key
and
MessageChannel
bean.
- ChannelMessageStore - Interface in org.springframework.integration.store
-
A marker interface that indicates this message store has optimizations for
use in a
QueueChannel
.
- ChannelMessageStorePreparedStatementSetter - Class in org.springframework.integration.jdbc.store.channel
-
- ChannelMessageStorePreparedStatementSetter(SerializingConverter, LobHandler) - Constructor for class org.springframework.integration.jdbc.store.channel.ChannelMessageStorePreparedStatementSetter
-
- ChannelMessageStorePreparedStatementSetter() - Constructor for class org.springframework.integration.jdbc.store.channel.ChannelMessageStorePreparedStatementSetter
-
The default constructor for inheritors who are not interested in the message
serialization to byte[]
.
- ChannelMessageStoreQueryProvider - Interface in org.springframework.integration.jdbc.store.channel
-
- channelNameToChannel(String) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- channelNameToChannel(String) - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
-
Converts the channel name back to a
MessageChannel
(if it is
registered).
- ChannelPublishingJmsMessageListener - Class in org.springframework.integration.jms
-
JMS MessageListener that converts a JMS Message into a Spring Integration
Message and sends that Message to a channel.
- ChannelPublishingJmsMessageListener() - Constructor for class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- ChannelPurger - Class in org.springframework.integration.channel
-
- ChannelPurger(QueueChannel...) - Constructor for class org.springframework.integration.channel.ChannelPurger
-
- ChannelPurger(MessageSelector, QueueChannel...) - Constructor for class org.springframework.integration.channel.ChannelPurger
-
- channelResolver - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- channelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- ChannelResolverUtils - Class in org.springframework.integration.support.channel
-
Channel resolution utilities.
- channels - Variable in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- Channels - Class in org.springframework.integration.dsl
-
- CHANNELS_AUTOCREATE - Static variable in class org.springframework.integration.context.IntegrationProperties
-
Specifies whether to allow create automatically
DirectChannel
beans for non-declared channels or not.
- CHANNELS_MAX_BROADCAST_SUBSCRIBERS - Static variable in class org.springframework.integration.context.IntegrationProperties
-
- CHANNELS_MAX_UNICAST_SUBSCRIBERS - Static variable in class org.springframework.integration.context.IntegrationProperties
-
- ChannelSecurityInterceptor - Class in org.springframework.integration.security.channel
-
An AOP interceptor that enforces authorization for MessageChannel send and/or receive calls.
- ChannelSecurityInterceptor() - Constructor for class org.springframework.integration.security.channel.ChannelSecurityInterceptor
-
- ChannelSecurityInterceptor(ChannelSecurityMetadataSource) - Constructor for class org.springframework.integration.security.channel.ChannelSecurityInterceptor
-
- ChannelSecurityInterceptorBeanPostProcessor - Class in org.springframework.integration.security.config
-
- ChannelSecurityInterceptorBeanPostProcessor(Map<String, Set<Pattern>>) - Constructor for class org.springframework.integration.security.config.ChannelSecurityInterceptorBeanPostProcessor
-
- ChannelSecurityInterceptorBeanPostProcessor(Map<String, Set<Pattern>>, Map<String, Map<Pattern, ChannelAccessPolicy>>) - Constructor for class org.springframework.integration.security.config.ChannelSecurityInterceptorBeanPostProcessor
-
- ChannelSecurityMetadataSource - Class in org.springframework.integration.security.channel
-
The
SecurityMetadataSource
implementation for secured
MessageChannel
s.
- ChannelSecurityMetadataSource() - Constructor for class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
-
- ChannelSecurityMetadataSource(Map<Pattern, ChannelAccessPolicy>) - Constructor for class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
-
- channelToChannelName(Object) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- channelToChannelName(Object, long) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- channelToChannelName(Object) - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
-
Converts the channel to a name (String).
- channelToChannelName(Object, long) - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
-
Converts the channel to a name (String).
- channelTransacted(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
- channelTransacted(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
- ChannelUtils - Class in org.springframework.integration.channel
-
Channel utilities.
- CharacterStreamReadingMessageSource - Class in org.springframework.integration.stream
-
- CharacterStreamReadingMessageSource(Reader) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
Construct an instance with the provider reader.
- CharacterStreamReadingMessageSource(Reader, int) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
Construct an instance with the provider reader and buffer size.
- CharacterStreamReadingMessageSource(Reader, int, boolean) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
Construct an instance with the provided reader and buffer size.
- CharacterStreamWritingMessageHandler - Class in org.springframework.integration.stream
-
- CharacterStreamWritingMessageHandler(Writer) - Constructor for class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
-
- CharacterStreamWritingMessageHandler(Writer, int) - Constructor for class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
-
- charset(String) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
-
Set the charset to be used when reading the file, when something other than the default
charset is required.
- charset(Charset) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
-
Set the charset to be used when reading the file, when something other than the default
charset is required.
- charset(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
-
Set the charset to use when converting String payloads to bytes as the content of the
remote file.
- charset(Charset) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
-
Set the charset to use when converting String payloads to bytes as the content of the
remote file.
- charset(String) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
-
Set the charset to use when converting String payloads to bytes as the content of the file.
- charset(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Set the charset to use when converting String payloads to bytes as the content of the
remote file.
- charset(String) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
-
Specify the charset name to use for converting String-typed payloads to bytes.
- CHAT - Static variable in class org.springframework.integration.xmpp.XmppHeaders
-
- ChatMessageInboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
-
Parser for the XMPP 'inbound-channel-adapter' element.
- ChatMessageInboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.ChatMessageInboundChannelAdapterParser
-
- ChatMessageListeningEndpoint - Class in org.springframework.integration.xmpp.inbound
-
This component logs in as a user and forwards any messages to that
user on to downstream components.
- ChatMessageListeningEndpoint() - Constructor for class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
-
- ChatMessageListeningEndpoint(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
-
- ChatMessageOutboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
-
Parser for the XMPP 'outbound-channel-adapter' element
- ChatMessageOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.ChatMessageOutboundChannelAdapterParser
-
- ChatMessageSendingMessageHandler - Class in org.springframework.integration.xmpp.outbound
-
MessageHandler that sends an XMPP Chat Message.
- ChatMessageSendingMessageHandler() - Constructor for class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
-
- ChatMessageSendingMessageHandler(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
-
- checkActive() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- checkActive() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
- checkAllowList(Class<?>) - Method in class org.springframework.integration.support.converter.AllowListDeserializingConverter
-
- checkAndConfigureFixedSubscriberChannel(Element, ParserContext, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- checkClosure(int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
-
- checkDeliveryMode(Message<?>, MessageProperties, MessageDeliveryMode) - Static method in class org.springframework.integration.amqp.support.MappingUtils
-
Check the delivery mode and update with the default if not already present.
- checkForIllegalTarget(Object, String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
- checkForIllegalTarget(Object, String) - Method in class org.springframework.integration.config.FilterFactoryBean
-
- checkMessageHandlerAttributes(String, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- checkReuse(MessageProducer) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- checkTaskExecutor(String) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
Creates a default task executor if none was supplied.
- chmod(int) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
-
Set the file permissions after uploading, e.g.
- chmod(int) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
-
Set the file permissions after uploading, e.g.
- chmod(int) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Set the file permissions after uploading, e.g.
- CircuitBreakerOpenException(Message<?>, String) - Constructor for exception org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice.CircuitBreakerOpenException
-
- claimCheckIn(MessageStore) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- claimCheckIn(MessageStore, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- ClaimCheckInParser - Class in org.springframework.integration.config.xml
-
Parser for the <claim-check-in/> element.
- ClaimCheckInParser() - Constructor for class org.springframework.integration.config.xml.ClaimCheckInParser
-
- ClaimCheckInTransformer - Class in org.springframework.integration.transformer
-
Transformer that stores a Message and returns a new Message whose payload
is the id of the stored Message.
- ClaimCheckInTransformer(MessageStore) - Constructor for class org.springframework.integration.transformer.ClaimCheckInTransformer
-
Create a claim check-in transformer that will delegate to the provided MessageStore.
- claimCheckOut(MessageStore) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- claimCheckOut(MessageStore, boolean) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- claimCheckOut(MessageStore, boolean, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- ClaimCheckOutParser - Class in org.springframework.integration.config.xml
-
Parser for the <claim-check-out/> element.
- ClaimCheckOutParser() - Constructor for class org.springframework.integration.config.xml.ClaimCheckOutParser
-
- ClaimCheckOutTransformer - Class in org.springframework.integration.transformer
-
Transformer that accepts a Message whose payload is a UUID and retrieves the Message associated
with that id from a MessageStore if available.
- ClaimCheckOutTransformer(MessageStore) - Constructor for class org.springframework.integration.transformer.ClaimCheckOutTransformer
-
Create a claim check-out transformer that will delegate to the provided MessageStore.
- classes(Class<?>...) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
-
Specify the classes for logging level adjusting configured before.
- classes(boolean, Class<?>...) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
-
Specify the classes for logging level adjusting configured before.
- ClassUtils - Class in org.springframework.integration.util
-
- ClassUtils() - Constructor for class org.springframework.integration.util.ClassUtils
-
- clear() - Method in class org.springframework.integration.channel.QueueChannel
-
- clear() - Method in interface org.springframework.integration.channel.QueueChannelOperations
-
- clear() - Method in class org.springframework.integration.expression.ExpressionEvalMap
-
- clear() - Method in class org.springframework.integration.history.MessageHistory
-
- clear() - Method in interface org.springframework.integration.store.MessageGroup
-
- clear() - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- clear() - Method in class org.springframework.integration.support.MutableMessageHeaders
-
- clearCache() - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Clear the resource bundle cache.
- clearMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- clearOnFlush(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaUpdatingOutboundEndpointSpec
-
- clearQueue() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- clearQueue() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- clearThreadKey() - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
-
Clear the key for this thread.
- clearThreadKey(Message<?>) - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
-
- CLIENT_ACKNOWLEDGE - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
-
- CLIENT_ACKNOWLEDGE_STRING - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
-
- CLIENT_MODE - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- ClientCallback<C,T> - Interface in org.springframework.integration.file.remote
-
RemoteFileTemplate
callback with the underlying client instance providing
access to lower level methods.
- ClientCallbackWithoutResult<C> - Interface in org.springframework.integration.file.remote
-
RemoteFileTemplate
callback with the underlying client instance providing
access to lower level methods where no result is returned.
- ClientHttpResponseBodyExtractor - Class in org.springframework.integration.webflux.support
-
- ClientHttpResponseBodyExtractor() - Constructor for class org.springframework.integration.webflux.support.ClientHttpResponseBodyExtractor
-
- clientId(String) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
-
- clientId(String) - Method in class org.springframework.integration.jms.dsl.JmsPublishSubscribeMessageChannelSpec
-
- clientMode(boolean) - Method in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
-
- clientMode(boolean) - Method in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
-
- clientMode(boolean) - Method in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
-
- ClientModeCapable - Interface in org.springframework.integration.ip.tcp.connection
-
Edpoints implementing this interface are capable
of running in client-mode.
- ClientModeConnectionManager - Class in org.springframework.integration.ip.tcp.connection
-
Intended to be run on a schedule, simply gets the connection
from a client connection factory each time it is run.
- ClientModeConnectionManager(AbstractConnectionFactory) - Constructor for class org.springframework.integration.ip.tcp.connection.ClientModeConnectionManager
-
- ClientRSocketConnector - Class in org.springframework.integration.rsocket
-
- ClientRSocketConnector(String, int) - Constructor for class org.springframework.integration.rsocket.ClientRSocketConnector
-
Instantiate a connector based on the TcpClientTransport
.
- ClientRSocketConnector(URI) - Constructor for class org.springframework.integration.rsocket.ClientRSocketConnector
-
Instantiate a connector based on the WebsocketClientTransport
.
- ClientRSocketConnector(ClientTransport) - Constructor for class org.springframework.integration.rsocket.ClientRSocketConnector
-
Instantiate a connector based on the provided ClientTransport
.
- clientRSocketConnector(ClientRSocketConnector) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
-
- ClientStompEncoder - Class in org.springframework.integration.websocket.support
-
A
StompEncoder
extension to prepare a message for sending/receiving
before/after encoding/decoding when used from WebSockets client side.
- ClientStompEncoder() - Constructor for class org.springframework.integration.websocket.support.ClientStompEncoder
-
- ClientWebSocketContainer - Class in org.springframework.integration.websocket
-
- ClientWebSocketContainer(WebSocketClient, String, Object...) - Constructor for class org.springframework.integration.websocket.ClientWebSocketContainer
-
- ClientWebSocketContainerParser - Class in org.springframework.integration.websocket.config
-
- ClientWebSocketContainerParser() - Constructor for class org.springframework.integration.websocket.config.ClientWebSocketContainerParser
-
- cloneAndExecute() - Method in interface org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice.ExecutionCallback
-
Call this when it is necessary to clone the invocation before
calling proceed() - such as when the invocation might be called
multiple times - for example in a retry advice.
- cloneConnectOptions(MqttConnectOptions) - Static method in class org.springframework.integration.mqtt.support.MqttUtils
-
Clone the MqttConnectOptions
, except the serverUris.
- close() - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
-
- close() - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
-
- close() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- close() - Method in interface org.springframework.integration.file.remote.session.Session
-
- close() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- close() - Method in class org.springframework.integration.ftp.session.FtpSession
-
- close(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- close() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
Closes the connection.
- close() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- close() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
Closes this connection.
- close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
-
Closes this connection.
- close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
-
- close() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
- close() - Method in interface org.springframework.integration.jdbc.lock.LockRepository
-
- close() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
-
- close() - Method in class org.springframework.integration.sftp.session.SftpSession
-
- close() - Method in interface org.springframework.integration.util.CloseableIterator
-
- close() - Method in class org.springframework.integration.util.FunctionIterator
-
- close() - Method in interface org.springframework.integration.util.Pool
-
Close the pool; returned items will be destroyed.
- close() - Method in class org.springframework.integration.util.SimplePool
-
- CLOSEABLE_RESOURCE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
-
- CloseableIterator<E> - Interface in org.springframework.integration.util
-
A
CloseableIterator
is intended to be used when it may hold resources (such as file or socket handles).
- closeConnection(String) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Close a connection with the specified connection id.
- closeConnection(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
If we have been intercepted, propagate the close from the outermost interceptor;
otherwise, just call close().
- closeConnection(String) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- closeFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- closeFolder(Folder, boolean) - Static method in class org.springframework.integration.mail.MailTransportUtils
-
Close the given JavaMail Folder and ignore any thrown exception.
- closeService(Service) - Static method in class org.springframework.integration.mail.MailTransportUtils
-
Close the given JavaMail Service and ignore any thrown exception.
- closeSession(WebSocketSession, CloseStatus) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
-
- closeStreamAfterSend(boolean) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
-
Set to true to close the connection output stream after sending without
closing the connection.
- Codec - Interface in org.springframework.integration.codec
-
Interface for classes that perform both encode (serialize) and decode (deserialize) on multiple classes.
- codecConfigurer(ServerCodecConfigurer) - Method in class org.springframework.integration.webflux.dsl.WebFluxInboundEndpointSpec
-
- CodecMessageConverter - Class in org.springframework.integration.codec
-
- CodecMessageConverter(Codec) - Constructor for class org.springframework.integration.codec.CodecMessageConverter
-
- collection(String) - Method in class org.springframework.integration.mongodb.dsl.MongoDbChangeStreamMessageProducerSpec
-
Configure a collection to subscribe for change events.
- COLLECTION_NAME - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
-
The header for MongoDb collection name.
- CollectionArgumentResolver - Class in org.springframework.integration.handler.support
-
- CollectionArgumentResolver(boolean) - Constructor for class org.springframework.integration.handler.support.CollectionArgumentResolver
-
- collectionCallback(MessageCollectionCallback<P>) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
-
Reference to an instance of
MessageCollectionCallback
which specifies the database operation to execute in the request message context.
- CollectionFilter<T> - Interface in org.springframework.integration.util
-
Base strategy for filtering out a subset of a Collection of elements.
- collectionName(String) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
-
Identify the name of the MongoDb collection to use.
- collectionName(String) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
-
Configure a collection name to store data.
- collectionName(String) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
-
Configure a collection name to query against.
- collectionName - Variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- collectionNameExpression(String) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
-
A SpEL expression which should resolve to a
String
value
identifying the name of the MongoDb collection to use.
- collectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
-
Configure a SpEL expression to evaluate a collection name against a request message.
- collectionNameExpression(String) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
-
Configure a SpEL expression to evaluation a collection name on each receive()
call.
- collectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
-
Configure a SpEL expression to evaluation a collection name on each receive()
call.
- collectionNameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
-
A
Function
which should resolve to a
String
(e.q.,
collectionNameFunction(Message::getPayload)
).
- collectionNameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
-
Configure a
Function
for evaluation a collection against request message.
- collectionNameSupplier(Supplier<String>) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
-
Configure a
Supplier
to obtain a collection name on each
receive()
call.
- COMMAND - Static variable in class org.springframework.integration.redis.support.RedisHeaders
-
- commitCallback(OffsetCommitCallback) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
-
Set the commit callback; by default a simple logging callback is used to log
success at DEBUG level and failures at ERROR level.
- commonOutboundProperties(Element, ParserContext, BeanDefinitionBuilder) - Static method in class org.springframework.integration.kafka.config.xml.KafkaParsingUtils
-
- CommonSocketOptions - Interface in org.springframework.integration.ip
-
- comparator(Comparator<Message<?>>) - Method in class org.springframework.integration.dsl.PriorityChannelSpec
-
- compare(Message<?>, Message<?>) - Method in class org.springframework.integration.aggregator.MessageSequenceComparator
-
- compareTo(FileInfo<F>) - Method in class org.springframework.integration.file.remote.AbstractFileInfo
-
- compareTo(KafkaMessageSource.KafkaAckInfo<K, V>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
-
- compareValues(BiPredicate<String, String>) - Method in class org.springframework.integration.selector.MetadataStoreSelector
-
- COMPLETE - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
-
- complete() - Method in interface org.springframework.integration.store.MessageGroup
-
Complete the group.
- complete() - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- completeGroup(Object, MessageGroup, Lock) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- completeGroup(Message<?>, Object, MessageGroup, Lock) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- completeGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
- completeGroup(Object) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- completeGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- completeGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- completeGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- completeGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
-
Completes this MessageGroup.
- completeGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- ComponentsEvaluationCallback(EvaluationContext, Object, boolean, Class<?>) - Constructor for class org.springframework.integration.expression.ExpressionEvalMap.ComponentsEvaluationCallback
-
- ComponentsRegistration - Interface in org.springframework.integration.dsl
-
The marker interface for the
IntegrationComponentSpec
implementation,
when there is need to register as beans not only the target spec's components,
but some additional components, e.g.
- componentsToRegister - Variable in class org.springframework.integration.dsl.EndpointSpec
-
- componentsToRegister - Variable in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
- CompositeCodec - Class in org.springframework.integration.codec
-
A Codec that can delegate to one out of many Codecs, each mapped to a class.
- CompositeCodec(Map<Class<?>, Codec>, Codec) - Constructor for class org.springframework.integration.codec.CompositeCodec
-
- CompositeCodec(Codec) - Constructor for class org.springframework.integration.codec.CompositeCodec
-
- CompositeExecutor - Class in org.springframework.integration.util
-
An
Executor
that encapsulates two underlying executors.
- CompositeExecutor(Executor, Executor) - Constructor for class org.springframework.integration.util.CompositeExecutor
-
- CompositeFileListFilter<F> - Class in org.springframework.integration.file.filters
-
- CompositeFileListFilter() - Constructor for class org.springframework.integration.file.filters.CompositeFileListFilter
-
- CompositeFileListFilter(Collection<? extends FileListFilter<F>>) - Constructor for class org.springframework.integration.file.filters.CompositeFileListFilter
-
- CompositeKryoRegistrar - Class in org.springframework.integration.codec.kryo
-
A
KryoRegistrar
that delegates and validates registrations across all components.
- CompositeKryoRegistrar(List<KryoRegistrar>) - Constructor for class org.springframework.integration.codec.kryo.CompositeKryoRegistrar
-
- CompositeMessageHandler - Interface in org.springframework.integration.handler
-
Classes implementing this interface delegate to a list of handlers.
- CompositeMessageHandlerNode - Class in org.springframework.integration.graph
-
Represents a composite message handler.
- CompositeMessageHandlerNode(int, String, MessageHandler, String, String, List<CompositeMessageHandlerNode.InnerHandler>) - Constructor for class org.springframework.integration.graph.CompositeMessageHandlerNode
-
- CompositeMessageHandlerNode.InnerHandler - Class in org.springframework.integration.graph
-
- CompoundTrigger - Class in org.springframework.integration.util
-
- CompoundTrigger(Trigger) - Constructor for class org.springframework.integration.util.CompoundTrigger
-
Construct a compound trigger with the supplied primary trigger.
- CompoundTriggerAdvice - Class in org.springframework.integration.aop
-
A
MessageSourceMutator
that uses a
CompoundTrigger
to adjust
the poller - when a message is present, the compound trigger's primary trigger is
used to determine the next poll.
- CompoundTriggerAdvice(CompoundTrigger, Trigger) - Constructor for class org.springframework.integration.aop.CompoundTriggerAdvice
-
- concurrency(String) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
The concurrency to use.
- concurrency(int) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
-
Specify a concurrency maximum number for the
AbstractMessageListenerContainer
.
- concurrentConsumers(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
- concurrentConsumers(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-
- concurrentConsumers(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
The concurrent consumers number to use.
- concurrentConsumers(int) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
-
- concurrentConsumers(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
-
- ConcurrentMetadataStore - Interface in org.springframework.integration.metadata
-
Supports atomic updates to values in the store.
- ConfigurableCompositeMessageConverter - Class in org.springframework.integration.support.converter
-
- ConfigurableCompositeMessageConverter() - Constructor for class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
-
Create an instance with the default converters.
- ConfigurableCompositeMessageConverter(Collection<MessageConverter>) - Constructor for class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
-
Create an instance with the given converters and without defaults.
- ConfigurableCompositeMessageConverter(Collection<MessageConverter>, boolean) - Constructor for class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
-
Create an instance with the given converters and with defaults in the end.
- ConfigurableMongoDbMessageStore - Class in org.springframework.integration.mongodb.store
-
- ConfigurableMongoDbMessageStore(MongoTemplate) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- ConfigurableMongoDbMessageStore(MongoTemplate, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- ConfigurableMongoDbMessageStore(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- ConfigurableMongoDbMessageStore(MongoDatabaseFactory, MappingMongoConverter) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- ConfigurableMongoDbMessageStore(MongoDatabaseFactory, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- ConfigurableMongoDbMessageStore(MongoDatabaseFactory, MappingMongoConverter, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- configure(IntegrationFlowDefinition<?>) - Method in interface org.springframework.integration.dsl.IntegrationFlow
-
The callback-based function to declare the chain of EIP-methods to
configure an integration flow with the provided
IntegrationFlowDefinition
.
- configure(IntegrationFlowDefinition<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
-
- configure(IntegrationFlowDefinition<?>) - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
-
- configure(DatagramSocket) - Method in interface org.springframework.integration.ip.udp.SocketCustomizer
-
Configure the socket ({code setTrafficClass()}, etc).
- configure(RmiProxyFactoryBean) - Method in interface org.springframework.integration.rmi.RmiOutboundGateway.RmiProxyFactoryBeanConfigurer
-
Deprecated.
Perform additional configuration of the factory bean before the
RequestReplyExchanger
is created.
- configureAdviceChain(Element, Element, BeanDefinition, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- configureAdviceChain(Element, Element, boolean, BeanDefinition, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- configureAndSetAdviceChainIfPresent(Element, Element, BeanDefinition, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- configureAndSetAdviceChainIfPresent(Element, Element, boolean, BeanDefinition, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- configureAndSetAdviceChainIfPresent(Element, Element, BeanDefinition, ParserContext, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- configureAndSetAdviceChainIfPresent(Element, Element, boolean, BeanDefinition, ParserContext, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- configureChannels(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
-
- configureChannels(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.amqp.config.AmqpInboundGatewayParser
-
- configureContainer(Consumer<DirectMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterDMLCSpec
-
- configureContainer(Consumer<SimpleMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSMLCSpec
-
- configureContainer(Consumer<DirectMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundGatewayDMLCSpec
-
- configureContainer(Consumer<SimpleMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySMLCSpec
-
- configureFilter(BeanDefinitionBuilder, Element, ParserContext, String, String, String) - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
-
- configureHandler(ServiceActivatingHandler) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- configureHeaderMapper(Element, BeanDefinitionBuilder, ParserContext, Class<?>, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Utility method to configure a HeaderMapper for Inbound and Outbound channel adapters/gateway.
- configureHeaderMapper(Element, BeanDefinitionBuilder, ParserContext, BeanDefinitionBuilder, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Utility method to configure a HeaderMapper for Inbound and Outbound channel adapters/gateway.
- configureJmsTemplate(Consumer<JmsTemplateSpec>) - Method in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec.JmsInboundChannelSpecTemplateAware
-
Configure the channel adapter to use the template specification created by invoking the
Consumer
callback, passing in a
JmsTemplateSpec
.
- configureJmsTemplate(Consumer<JmsTemplateSpec>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec.JmsOutboundChannelSpecTemplateAware
-
- configureKafkaTemplate(Consumer<KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec<K, V, R>>) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.KafkaGatewayMessageHandlerTemplateSpec
-
- configureKafkaTemplate(Consumer<KafkaTemplateSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
-
- configureKryoInstance(Kryo) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
Subclasses implement this to configure the kryo instance.
- configureKryoInstance(Kryo) - Method in class org.springframework.integration.codec.kryo.PojoCodec
-
- configureListenerContainer(Consumer<S>) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec
-
- configureListenerContainer(Consumer<S>) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
-
- configureListenerContainer(Consumer<KafkaMessageListenerContainerSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
-
- configureListenerContainer(Consumer<KafkaMessageListenerContainerSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
-
- configureMappingRouter(AbstractMappingMessageRouter) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- configurePollerMetadata(Element, BeanDefinitionBuilder, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Parse a "poller" element to provide a reference for the target BeanDefinitionBuilder.
- configurePollingEndpoint(AbstractPollingEndpoint, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- configureRouter(AbstractMessageRouter) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- configureSocket(SocketCustomizer) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
-
Configure the socket.
- configureSocket(SocketCustomizer) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
-
Configure the socket.
- configureSource(MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
-
- configureSplitter(AbstractMessageSplitter) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- configureTemplate(Consumer<KafkaTemplateSpec<K, R>>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
-
- configureTransactionAttributes(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Parse a "transactional" element and configure a
TransactionInterceptor
with "transactionManager" and other "transactionDefinition" properties.
- configureTransactionAttributes(Element, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- configureTransactionDefinition(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Parse attributes of "transactional" element and configure a
DefaultTransactionAttribute
with provided "transactionDefinition" properties.
- confirm(CorrelationData, boolean, String) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- confirmAckChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the channel to which acks are send (publisher confirms).
- confirmCorrelationExpression(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set a SpEL expression to evaluate confirm correlation at runtime.
- confirmCorrelationExpression(Expression) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set a SpEL expression to evaluate confirm correlation at runtime.
- confirmCorrelationFunction(Function<Message<?>, Object>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set a
Function
to evaluate confirm correlation at runtime.
- confirmNackChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the channel to which nacks are send (publisher confirms).
- confirmTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set a timeout after which a nack will be synthesized if no publisher confirm has
been received within that time.
- connect() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
-
Perform subscription into the RSocket server for incoming requests.
- connect(StompSessionHandler) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- connect(StompSessionHandler) - Method in interface org.springframework.integration.stomp.StompSessionManager
-
- CONNECT_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- CONNECTION_ID - Static variable in class org.springframework.integration.ip.IpHeaders
-
A unique identifier for a TCP connection; set by the framework for
inbound messages; when sending to a server-side inbound
channel adapter, or replying to an inbound gateway, this header is
required so the endpoint can determine which connection to send
the message to.
- connectionFactory - Variable in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
-
- connectionFactory - Variable in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
-
- connectionFactory - Variable in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
-
- connectionFactory - Variable in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
-
- ConnectionFactory - Interface in org.springframework.integration.ip.tcp.connection
-
A factory used to create TcpConnection objects.
- connectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
-
- connectionLost(Throwable) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
- connectionLost(Throwable) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
- connectTimeout(int) - Method in class org.springframework.integration.ip.dsl.TcpClientConnectionFactorySpec
-
Set the connection timeout in seconds.
- connectUrl(String) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
-
Configure a connection to the ZeroMQ proxy with the pair of ports over colon
for proxy frontend and backend sockets.
- connectUrl(String) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
-
Configure an URL for ZMQ.Socket.connect(String)
.
- consecutiveActiveTrigger(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-
- consecutiveIdleTrigger(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-
- ConsoleInboundChannelAdapterParser - Class in org.springframework.integration.stream.config
-
Parser for the <stdin-channel-adapter> element.
- ConsoleInboundChannelAdapterParser() - Constructor for class org.springframework.integration.stream.config.ConsoleInboundChannelAdapterParser
-
- ConsoleOutboundChannelAdapterParser - Class in org.springframework.integration.stream.config
-
Parser for the "stdout-" and "stderr-channel-adapter" elements.
- ConsoleOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.stream.config.ConsoleOutboundChannelAdapterParser
-
- CONSOLIDATED_HEADERS - Static variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- constructType(Type) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
-
- constructType(Type) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
-
- consumeDelay(Duration) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
-
Specify a Duration
to delay consumption when no data received.
- consumeDelay(Duration) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
-
Specify a Duration
to delay consumption when no data received.
- CONSUMER - Static variable in class org.springframework.integration.redis.support.RedisHeaders
-
- CONSUMER_GROUP - Static variable in class org.springframework.integration.redis.support.RedisHeaders
-
- consumerArguments(Map<String, Object>) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set consumer arguments.
- consumerBatchEnabled(boolean) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-
Set to true to enable batching of consumed messages.
- ConsumerEndpointFactoryBean - Class in org.springframework.integration.config
-
- ConsumerEndpointFactoryBean() - Constructor for class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- ConsumerEndpointSpec<S extends ConsumerEndpointSpec<S,H>,H extends MessageHandler> - Class in org.springframework.integration.dsl
-
- ConsumerEndpointSpec(H) - Constructor for class org.springframework.integration.dsl.ConsumerEndpointSpec
-
- consumerRebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
-
Set the user defined ConsumerRebalanceListener
implementation.
- consumersPerQueue(int) - Method in class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
-
- ConsumerStopAction - Enum in org.springframework.integration.mqtt.core
-
Action to take regarding subscrptions when consumer stops.
- consumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
- consumerTaskExecutor(AsyncListenableTaskExecutor) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
-
Set the executor for threads that poll the consumer.
- consumes(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.RequestMappingSpec
-
The consumable media types of the mapped request, narrowing the primary mapping.
- container(ConnectionFactory, Destination) - Static method in class org.springframework.integration.jms.dsl.Jms
-
- container(ConnectionFactory, String) - Static method in class org.springframework.integration.jms.dsl.Jms
-
- containerType(Class<? extends AbstractMessageListenerContainer>) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
-
Configure the type of the container.
- contains(Object) - Method in class org.springframework.integration.history.MessageHistory
-
- containsAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
-
- containsElementIgnoreCase(String[], String) - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- containsKey(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
-
- containsSequence(Integer) - Method in class org.springframework.integration.store.SimpleMessageGroup
-
Return true if a message with this sequence number header exists in
the group.
- containsValue(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
-
- CONTENT_MD5 - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- CONTENT_TYPE - Static variable in class org.springframework.integration.mail.MailHeaders
-
- CONTENT_TYPE_ID - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
-
- CONTENT_TYPE_PROPERTY - Static variable in class org.springframework.integration.jms.JmsHeaderMapper
-
- ContentBasedHeaderMatcher(boolean, Collection<String>) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.ContentBasedHeaderMatcher
-
- ContentEnricher - Class in org.springframework.integration.transformer
-
Content Enricher is a Message Transformer that can augment a message's payload with
either static values or by optionally invoking a downstream message flow via its
request channel and then applying values from the reply Message to the original
payload.
- ContentEnricher() - Constructor for class org.springframework.integration.transformer.ContentEnricher
-
- contentType(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the content type.
- contentTypeExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set an expression that will be evaluated to determine the content type.
- contentTypeFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set a function that will be invoked to determine the content type.
- Context - Interface in org.springframework.integration.leader
-
Interface that defines the context for candidate leadership.
- ContinuousQueryMessageProducer - Class in org.springframework.integration.gemfire.inbound
-
Responds to a Gemfire continuous query (set using the #query field) that is
constantly evaluated against a cache
Region
.
- ContinuousQueryMessageProducer(ContinuousQueryListenerContainer, String) - Constructor for class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
-
- controlBus() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- controlBus(Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- ControlBusMethodFilter - Class in org.springframework.integration.expression
-
- ControlBusMethodFilter() - Constructor for class org.springframework.integration.expression.ControlBusMethodFilter
-
- ControlBusParser - Class in org.springframework.integration.config.xml
-
- ControlBusParser() - Constructor for class org.springframework.integration.config.xml.ControlBusParser
-
- conversionService - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- convert(Class<P>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- convert(Class<P>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- convert(MBeanServerConnection, ObjectInstance) - Method in class org.springframework.integration.jmx.DefaultMBeanObjectConverter
-
- convert(MBeanServerConnection, ObjectInstance) - Method in interface org.springframework.integration.jmx.MBeanObjectConverter
-
- convert(Binary) - Method in class org.springframework.integration.mongodb.support.BinaryToMessageConverter
-
- convert(Message<?>) - Method in class org.springframework.integration.mongodb.support.MessageToBinaryConverter
-
- convert(byte[]) - Method in class org.springframework.integration.support.converter.AllowListDeserializingConverter
-
- convert(JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
-
- convert(Object) - Method in class org.springframework.integration.util.UUIDConverter
-
- convertAndSend(Message<?>) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
- convertAndSend(Message<?>) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- convertAndSend(Message<?>) - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
-
- converter - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
-
- converter(Converter<T, U>) - Static method in class org.springframework.integration.dsl.Transformers
-
- CONVERTER_REGISTRAR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
-
- ConverterParser - Class in org.springframework.integration.config.xml
-
- ConverterParser() - Constructor for class org.springframework.integration.config.xml.ConverterParser
-
- convertExceptions(boolean) - Method in class org.springframework.integration.http.dsl.HttpRequestHandlerEndpointSpec
-
Flag to determine if conversion and writing out of message handling exceptions should be attempted.
- convertExpressions(Collection<ProcedureParameter>) - Static method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
Utility method that converts a Collection of
ProcedureParameter
to
a Map containing only expression parameters.
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.integration.support.converter.ObjectStringMessageConverter
-
- ConvertingBytesMessageMapper - Class in org.springframework.integration.mapping
-
- ConvertingBytesMessageMapper(MessageConverter) - Constructor for class org.springframework.integration.mapping.ConvertingBytesMessageMapper
-
- convertPayload(Message) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
-
- convertRequestMappingToAnnotation(RequestMapping) - Static method in class org.springframework.integration.http.config.HttpContextUtils
-
- convertStaticParameters(Collection<ProcedureParameter>) - Static method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
Utility method that converts a Collection of
ProcedureParameter
to
a Map containing only static parameters.
- convertToDocument(Object) - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
-
- convertToDocument(Object) - Method in interface org.springframework.integration.xml.XmlPayloadConverter
-
- convertToJdbcTypesEnum(String) - Static method in enum org.springframework.integration.jdbc.config.JdbcTypesEnum
-
Retrieves the matching enum constant for a provided String representation
of the SQL Types.
- convertToNode(Object) - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
-
- convertToNode(Object) - Method in interface org.springframework.integration.xml.XmlPayloadConverter
-
- convertToSource(Object) - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
-
- convertToSource(Object) - Method in interface org.springframework.integration.xml.XmlPayloadConverter
-
- convertToString(Object) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- convertValue(Object, TypeDescriptor, TypeDescriptor) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
-
- copy(MessageGroup) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
Used by expireMessageGroups.
- copy(MessageGroup) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- copyFileToLocalDirectory(String, F, File, Session<F>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- copyHeaders(Map<String, ?>) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
Copy the name-value pairs from the provided Map.
- copyHeaders(Map<String, ?>) - Method in class org.springframework.integration.support.MessageBuilder
-
Copy the name-value pairs from the provided Map.
- copyHeaders(Map<String, ?>) - Method in class org.springframework.integration.support.MutableMessageBuilder
-
- copyHeadersIfAbsent(Map<String, ?>) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
Copy the name-value pairs from the provided Map.
- copyHeadersIfAbsent(Map<String, ?>) - Method in class org.springframework.integration.support.MessageBuilder
-
Copy the name-value pairs from the provided Map.
- copyHeadersIfAbsent(Map<String, ?>) - Method in class org.springframework.integration.support.MutableMessageBuilder
-
- copyToSizedArray(byte[], int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
-
Copy size bytes to a new buffer exactly size bytes long.
- CorrelatingMessageBarrier - Class in org.springframework.integration.aggregator
-
This Endpoint serves as a barrier for messages that should not be processed yet.
- CorrelatingMessageBarrier() - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageBarrier
-
- CorrelatingMessageBarrier(MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageBarrier
-
- CORRELATION_ID - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
-
- correlationExpression(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
-
- CorrelationHandlerSpec<S extends CorrelationHandlerSpec<S,H>,H extends AbstractCorrelatingMessageHandler> - Class in org.springframework.integration.dsl
-
- CorrelationHandlerSpec(H) - Constructor for class org.springframework.integration.dsl.CorrelationHandlerSpec
-
- correlationId(Object) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- correlationId(Object, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- correlationIdExpression(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- correlationIdExpression(String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- correlationIdFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- correlationIdFunction(Function<Message<P>, ?>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- correlationKey(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
-
- correlationKey(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
- CorrelationStrategy - Interface in org.springframework.integration.aggregator
-
Strategy for determining how messages can be correlated.
- CorrelationStrategy - Annotation Type in org.springframework.integration.annotation
-
Indicates that a given method is capable of determining the correlation key
of a message sent as parameter.
- correlationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.dsl.BarrierSpec
-
- correlationStrategy(Object, String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
-
- correlationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
-
- CorrelationStrategyFactoryBean - Class in org.springframework.integration.config
-
- CorrelationStrategyFactoryBean() - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
-
- counterBuilder(String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor
-
Create a counter builder for a counter with the provided name.
- counterBuilder(String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
-
- CounterFacade - Interface in org.springframework.integration.support.management.metrics
-
- CqEventType - Enum in org.springframework.integration.gemfire.inbound
-
Enumeration of GemFire Continuous Query Event Types
- create(Message<?>, String, Integer, Long, K, V, Headers) - Method in interface org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler.ProducerRecordCreator
-
Create a record.
- create(Object) - Method in interface org.springframework.integration.store.MessageGroupFactory
-
Create a
MessageGroup
instance based on the provided
groupId
.
- create(Collection<? extends Message<?>>, Object) - Method in interface org.springframework.integration.store.MessageGroupFactory
-
Create a
MessageGroup
instance based on the provided
groupId
and with the
messages
for the group.
- create(Collection<? extends Message<?>>, Object, long, boolean) - Method in interface org.springframework.integration.store.MessageGroupFactory
-
Create a
MessageGroup
instance based on the provided
groupId
and with the
messages
for the group.
- create(MessageGroupStore, Object) - Method in interface org.springframework.integration.store.MessageGroupFactory
-
Create a
MessageGroup
instance based on the provided
groupId
.
- create(MessageGroupStore, Object, long, boolean) - Method in interface org.springframework.integration.store.MessageGroupFactory
-
Create a
MessageGroup
instance based on the provided
groupId
.
- create(Object) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
-
- create(Collection<? extends Message<?>>, Object) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
-
- create(Collection<? extends Message<?>>, Object, long, boolean) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
-
- create(MessageGroupStore, Object) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
-
- create(MessageGroupStore, Object, long, boolean) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
-
- create(Object) - Method in class org.springframework.integration.transaction.DefaultTransactionSynchronizationFactory
-
- create(Object) - Method in class org.springframework.integration.transaction.PassThroughTransactionSynchronizationFactory
-
- create(Object) - Method in interface org.springframework.integration.transaction.TransactionSynchronizationFactory
-
- create() - Method in class org.springframework.integration.ws.dsl.BaseWsInboundGatewaySpec
-
- create() - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
-
- create() - Method in class org.springframework.integration.ws.dsl.MarshallingWsInboundGatewaySpec
-
- create() - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec
-
- create() - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
-
- create() - Method in class org.springframework.integration.ws.dsl.SimpleWsInboundGatewaySpec
-
- create() - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
-
- create() - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
-
- createCallback(T) - Method in interface org.springframework.integration.acks.AcknowledgmentCallbackFactory
-
Create the callback.
- createCallback(AmqpMessageSource.AmqpAckInfo) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallbackFactory
-
- createCallback(KafkaMessageSource.KafkaAckInfo<K, V>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
-
- createClientInstance() - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- createClientInstance() - Method in class org.springframework.integration.ftp.session.DefaultFtpSessionFactory
-
- createClientInstance() - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- createConnection() - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Create a new JMS Connection for this JMS gateway.
- createConsumer() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
-
- created(ServerSession, Path, Map<String, ?>, Throwable) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
-
- createDefaultHandler() - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
- createDefaultHandler() - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- createDefaultHeaderMatcher(String, Collection<String>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
- createDirectChannel(Element, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- createDirectHandlerIfPossible(Object, String) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- createDispatcher() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
-
- createDispatcher() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
-
- createDispatcher() - Method in class org.springframework.integration.kafka.channel.PublishSubscribeKafkaChannel
-
- createDispatcher() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
-
- createElementDescription(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Provides a user friendly description of an element based on its node name and, if available, its "id" attribute
value.
- createEndpoint(MessageHandler, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- createEndpoint(MessageHandler, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeToAnnotationPostProcessor
-
- createEvaluationContext() - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
- createEvaluationContext() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
- createEvaluationContext() - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- createExpressionDefIfAttributeDefined(String, Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- createExpressionDefinitionFromValueOrExpression(String, String, ParserContext, Element, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
- createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.FilterFactoryBean
-
- createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.TransformerFactoryBean
-
- createFilter(MessageSelector) - Method in class org.springframework.integration.config.FilterFactoryBean
-
- createForPool() - Method in interface org.springframework.integration.util.SimplePool.PoolItemCallback
-
Called by the pool when a new instance is required to populate the pool.
- createHandler() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- createHandler() - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
- createHandler() - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
Subclasses must implement this method to create the MessageHandler.
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeToAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.FilterAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.InboundChannelAdapterAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.RouterAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.ServiceActivatorAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.SplitterAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.TransformerAnnotationPostProcessor
-
- createHandler() - Method in class org.springframework.integration.config.ExpressionControlBusFactoryBean
-
- createHandler(Transformer) - Method in class org.springframework.integration.config.TransformerFactoryBean
-
- createHandler() - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- createHandler() - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
-
- createHandler() - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- createHandlerInternal() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- createHeaderMatcher(Collection<String>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
- createInstance() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- createInstance() - Method in class org.springframework.integration.config.ExpressionFactoryBean
-
- createInstance() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
-
- createInstance() - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- createInstance() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- createInstance() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- createInstance() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- createInstance() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- createInstance() - Method in class org.springframework.integration.sftp.session.JschProxyFactoryBean
-
- createInstance() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- createInstance() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- createJavaType(Map<String, Object>, String) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
-
- createJsonParser(String) - Method in class org.springframework.integration.support.json.Jackson2JsonMessageParser
-
- createMessageFromAmqp(Message, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
-
- createMessageFromPayload(Object, Channel, Map<String, Object>, long, List<Map<String, Object>>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
-
- createMessageProcessingHandler(MessageProcessor<T>) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
- createMessageProcessingHandler(MessageProcessor<T>) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- createMessageProcessor(String, ScriptSource, ScriptVariableGenerator) - Method in class org.springframework.integration.groovy.config.GroovyAwareScriptExecutingProcessorFactory
-
- createMessageProcessor(String, ScriptSource, ScriptVariableGenerator) - Method in class org.springframework.integration.scripting.config.ScriptExecutingProcessorFactory
-
- createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
Subclasses must implement this method to create the MessageHandler.
- createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.FilterFactoryBean
-
- createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.TransformerFactoryBean
-
- createMethodInvokingRouter(Object, String) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- createMethodInvokingSplitter(Object, String) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- createNewConnection(Socket, boolean, boolean, ApplicationEventPublisher, String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNetConnectionSupport
-
- createNewConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNioConnectionSupport
-
- createNewConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNioSSLConnectionSupport
-
- createNewConnection(Socket, boolean, boolean, ApplicationEventPublisher, String) - Method in interface org.springframework.integration.ip.tcp.connection.TcpNetConnectionSupport
-
- createNewConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String) - Method in interface org.springframework.integration.ip.tcp.connection.TcpNioConnectionSupport
-
- createOutputMessage(Object, MessageHeaders) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
- createOutputStream(File, boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Create a buffered output stream for the file.
- createParameterSource(Object) - Method in class org.springframework.integration.jdbc.BeanPropertySqlParameterSourceFactory
-
- createParameterSource(Object) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
-
- createParameterSource(Object) - Method in interface org.springframework.integration.jdbc.SqlParameterSourceFactory
-
- createParameterSource(Object) - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSourceFactory
-
- createParameterSource(Object) - Method in class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
-
- createParameterSource(Object) - Method in interface org.springframework.integration.jpa.support.parametersource.ParameterSourceFactory
-
- createParameterSourceNoCache(Object) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
-
- createResult(Object) - Method in class org.springframework.integration.xml.result.DomResultFactory
-
- createResult(Object) - Method in interface org.springframework.integration.xml.result.ResultFactory
-
- createResult(Object) - Method in class org.springframework.integration.xml.result.StringResultFactory
-
- createSelect(String) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource.SelectCreator
-
- createSelect(SqlIdentifier) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource.SelectCreator
-
- createServerSocket(int, int, InetAddress) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
- createSession(Connection) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Create a new JMS Session using the provided Connection.
- createSimpleEvaluationContext() - Static method in class org.springframework.integration.expression.ExpressionUtils
-
Used to create a context with no BeanFactory, usually in tests.
- createSimpleEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.expression.ExpressionUtils
-
Obtains the context from the beanFactory if not null; emits a warning if the beanFactory
is null.
- createSocket(String, int) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
-
- createSource(Object) - Method in class org.springframework.integration.xml.source.DomSourceFactory
-
- createSource(Object) - Method in interface org.springframework.integration.xml.source.SourceFactory
-
Create appropriate
Source
instance for
payload
- createSource(Object) - Method in class org.springframework.integration.xml.source.StringSourceFactory
-
- createStandardEvaluationContext() - Static method in class org.springframework.integration.expression.ExpressionUtils
-
Used to create a context with no BeanFactory, usually in tests.
- createStandardEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.expression.ExpressionUtils
-
Obtains the context from the beanFactory if not null; emits a warning if the beanFactory
is null.
- createTargetPropertyName(String, boolean) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
Alter the specified propertyName
if necessary.
- createTaskScheduler(int) - Static method in class org.springframework.integration.test.util.TestUtils
-
- createTestApplicationContext() - Static method in class org.springframework.integration.test.util.TestUtils
-
- createWriter(File, boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Create a buffered writer for the file, for String payloads.
- credentials(String, String) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
-
Set the credentials.
- criteria(Function<Message<P>, Criteria>) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
-
Set a
Function
to evaluate a
Criteria
for query to execute.
- criteria(String) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
-
Set a SpEL expression to evaluate a Criteria
for query to execute.
- criteria(Expression) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
-
Set a SpEL expression to evaluate a Criteria
for query to execute.
- crlf() - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
-
Return a serializer with the default max message size for deserialization.
- crlf(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
-
Return a serializer with the provided max message size for deserialization.
- cron(String) - Method in class org.springframework.integration.dsl.PollerFactory
-
- cron(String, TimeZone) - Method in class org.springframework.integration.dsl.PollerFactory
-
- cron(String) - Static method in class org.springframework.integration.dsl.Pollers
-
- cron(String, TimeZone) - Static method in class org.springframework.integration.dsl.Pollers
-
- crossOrigin(Consumer<HttpInboundEndpointSupportSpec.CrossOriginSpec>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
-
- CrossOrigin - Class in org.springframework.integration.http.inbound
-
- CrossOrigin() - Constructor for class org.springframework.integration.http.inbound.CrossOrigin
-
- CuratorFrameworkFactoryBean - Class in org.springframework.integration.zookeeper.config
-
A Spring-friendly way to build a
CuratorFramework
and implementing
SmartLifecycle
.
- CuratorFrameworkFactoryBean(String) - Constructor for class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
-
Construct an instance using the supplied connection string and using a default
retry policy new ExponentialBackoffRetry(1000, 3)
.
- CuratorFrameworkFactoryBean(String, RetryPolicy) - Constructor for class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
-
Construct an instance using the supplied connection string and retry policy.
- current() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
-
- currentComponent(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- currentInterceptableChannel() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- currentMessageChannel(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- customizeMonoReply(BiFunction<Message<?>, Mono<?>, Publisher<?>>) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
-
- DatagramPacketMessageMapper - Class in org.springframework.integration.ip.udp
-
Message Mapper for converting to and from UDP DatagramPackets.
- DatagramPacketMessageMapper() - Constructor for class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
-
- datatype(Class<?>...) - Method in class org.springframework.integration.dsl.MessageChannelSpec
-
- DATE_FORMATS - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- deBatchingEnabled(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Determine whether or not the container should de-batch batched
messages (true) or call the listener with the batch (false).
- debug() - Static method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
-
The factory to produce Log4j2LevelAdjuster instances for Level.DEBUG
logging
with the org.springframework.integration
as default category.
- decode(InputStream, Class<T>) - Method in interface org.springframework.integration.codec.Codec
-
Decode an object of a given type
- decode(byte[], Class<T>) - Method in interface org.springframework.integration.codec.Codec
-
Decode an object of a given type
- decode(InputStream, Class<T>) - Method in class org.springframework.integration.codec.CompositeCodec
-
- decode(byte[], Class<T>) - Method in class org.springframework.integration.codec.CompositeCodec
-
- decode(byte[], Class<T>) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
- decode(InputStream, Class<T>) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
- DECODE_ERRORS - Static variable in class org.springframework.integration.syslog.SyslogHeaders
-
- decodeFluxAsUnit(boolean) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
-
Configure an option to decode an incoming Flux
as a single unit or each its event separately.
- decoding(Codec, Class<T>) - Static method in class org.springframework.integration.dsl.Transformers
-
- decoding(Codec, String) - Static method in class org.springframework.integration.dsl.Transformers
-
- decoding(Codec, Function<Message<?>, Class<T>>) - Static method in class org.springframework.integration.dsl.Transformers
-
- decoding(Codec, Expression) - Static method in class org.springframework.integration.dsl.Transformers
-
- DecodingTransformer<T> - Class in org.springframework.integration.transformer
-
- DecodingTransformer(Codec, Class<T>) - Constructor for class org.springframework.integration.transformer.DecodingTransformer
-
Construct an instance to use the supplied codec to decode to the supplied type.
- DecodingTransformer(Codec, Expression) - Constructor for class org.springframework.integration.transformer.DecodingTransformer
-
Construct an instance to use the supplied codec to decode to the supplied type.
- decorate(MessageHandlingRunnable) - Method in interface org.springframework.integration.dispatcher.MessageHandlingTaskDecorator
-
- decorateMessage(Message<?>) - Method in interface org.springframework.integration.support.MessageDecorator
-
- Default - Annotation Type in org.springframework.integration.annotation
-
Indicates that the class member has some default meaning.
- DEFAULT_ADVICE_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
-
- DEFAULT_BUSY_WAIT_TIME - Static variable in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- DEFAULT_CHARSET - Static variable in class org.springframework.integration.util.UUIDConverter
-
- DEFAULT_COLLECTION_NAME - Static variable in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- DEFAULT_COLLECTION_NAME - Static variable in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
-
The default conventional collection name.
- DEFAULT_COMPLETION_TIMEOUT - Static variable in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
The default completion timeout in milliseconds.
- DEFAULT_COMPLETION_TIMEOUT - Static variable in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
The default completion timeout in milliseconds.
- DEFAULT_CONFIGURING_POSTPROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
-
- DEFAULT_CONSUME_DELAY - Static variable in class org.springframework.integration.zeromq.channel.ZeroMqChannel
-
- DEFAULT_CONSUME_DELAY - Static variable in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
-
- DEFAULT_DELAY_WHEN_EMPTY - Static variable in class org.springframework.integration.util.IntegrationReactiveUtils
-
A default delay before repeating an empty source Mono
as 1 second Duration
.
- DEFAULT_DOMAIN - Static variable in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- DEFAULT_ERROR_CODE - Static variable in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
The View model key for the error code.
- DEFAULT_ERROR_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
-
- DEFAULT_ERRORS_KEY - Static variable in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
The View model key for errors.
- DEFAULT_FILE_REGISTRATION_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
-
- DEFAULT_GENERIC_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
-
- DEFAULT_HALF_OPEN_AFTER - Static variable in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
-
A half-open duration as 1000 .
- DEFAULT_HASH_MAP_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
-
- DEFAULT_HEADER_TYPES - Static variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
-
- DEFAULT_HEART_BEAT_TIME - Static variable in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- DEFAULT_MAX_ATTEMPTS - Static variable in class org.springframework.integration.handler.DelayHandler
-
- DEFAULT_MAX_MESSAGE_SIZE - Static variable in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
-
The default maximum message size when deserializing.
- DEFAULT_MESSAGEHEADERS_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
-
- DEFAULT_MUTABLE_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
-
- DEFAULT_MUTABLE_MESSAGEHEADERS_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
-
- DEFAULT_NAME - Static variable in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
-
- DEFAULT_POLLER - Static variable in class org.springframework.integration.scheduling.PollerMetadata
-
A convenient short alias for the global default poller bean name.
- DEFAULT_POLLER_METADATA_BEAN_NAME - Static variable in class org.springframework.integration.scheduling.PollerMetadata
-
- DEFAULT_POLLING_PERIOD - Static variable in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- DEFAULT_PORT - Static variable in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
-
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.endpoint.PollingConsumer
-
A default receive timeout as 1000L milliseconds.
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.jms.JmsOutboundGateway
-
A default receive timeout in milliseconds.
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- DEFAULT_REGION - Static variable in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Default region property, used to partition the message store.
- DEFAULT_REPLY_KEY - Static variable in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
The View model key for reply.
- DEFAULT_REPLY_TIMEOUT - Static variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- DEFAULT_RETRY_DELAY - Static variable in class org.springframework.integration.handler.DelayHandler
-
- DEFAULT_RETRY_INTERVAL - Static variable in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
A default retry interval in milliseconds - 60000L.
- DEFAULT_RETRY_INTERVAL - Static variable in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- DEFAULT_SEND_BUFFER_SIZE - Static variable in class org.springframework.integration.websocket.IntegrationWebSocketContainer
-
- DEFAULT_SEND_TIME_LIMIT - Static variable in class org.springframework.integration.websocket.IntegrationWebSocketContainer
-
- DEFAULT_SI_USER_FLAG - Static variable in class org.springframework.integration.mail.AbstractMailReceiver
-
Default user flag for marking messages as seen by this receiver:
"spring-integration-mail-adapter".
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Default value for the table prefix property.
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
-
Default value for the table prefix property.
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Default value for the table prefix property.
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
Default value for the table prefix property.
- DEFAULT_TAIL_ATTEMPTS_DELAY - Static variable in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
The default delay between tail attempts in milliseconds.
- DEFAULT_THRESHOLD - Static variable in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
-
Default threshold is effectively infinite.
- DEFAULT_THRESHOLD - Static variable in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
-
A default failures threshold as 5.
- DEFAULT_TIMEOUT - Static variable in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
-
Default timeout is one minute.
- DEFAULT_TTL - Static variable in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Default value for the time-to-live property.
- DEFAULT_UUID_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
-
- DefaultAggregateHeadersFunction - Class in org.springframework.integration.aggregator
-
The
Function
implementation for a default headers merging in the aggregator
component.
- DefaultAggregateHeadersFunction() - Constructor for class org.springframework.integration.aggregator.DefaultAggregateHeadersFunction
-
- DefaultAggregatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
-
This implementation of MessageGroupProcessor will take the messages from the
MessageGroup and pass them on in a single message with a Collection as a payload.
- DefaultAggregatingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.DefaultAggregatingMessageGroupProcessor
-
- DefaultAmqpHeaderMapper - Class in org.springframework.integration.amqp.support
-
- DefaultAmqpHeaderMapper(String[], String[]) - Constructor for class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
- DefaultCandidate - Class in org.springframework.integration.leader
-
- DefaultCandidate() - Constructor for class org.springframework.integration.leader.DefaultCandidate
-
Instantiate a default candidate.
- DefaultCandidate(String, String) - Constructor for class org.springframework.integration.leader.DefaultCandidate
-
Instantiate a default candidate.
- DefaultChannelAccessPolicy - Class in org.springframework.integration.security.channel
-
Creates the ConfigAttribute
s for secured channel
send and receive operations based on simple String values.
- DefaultChannelAccessPolicy(String, String) - Constructor for class org.springframework.integration.security.channel.DefaultChannelAccessPolicy
-
Create an access policy instance.
- DefaultChannelAccessPolicy(String[], String[]) - Constructor for class org.springframework.integration.security.channel.DefaultChannelAccessPolicy
-
Create an access policy instance.
- DefaultDatatypeChannelMessageConverter - Class in org.springframework.integration.support.converter
-
Default message converter for datatype channels.
- DefaultDatatypeChannelMessageConverter() - Constructor for class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
-
- defaultDelay(long) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
-
- defaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the default delivery mode.
- defaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
- DefaultDirectoryScanner - Class in org.springframework.integration.file
-
Default directory scanner and base class for other directory scanners.
- DefaultDirectoryScanner() - Constructor for class org.springframework.integration.file.DefaultDirectoryScanner
-
- defaultEncoding(String) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
-
Set the default encoding.
- DefaultErrorMessageStrategy - Class in org.springframework.integration.support
-
- DefaultErrorMessageStrategy() - Constructor for class org.springframework.integration.support.DefaultErrorMessageStrategy
-
- defaultFileNameFunction(String) - Static method in class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
-
The default function used to create the file name for the corresponding marker file.
- DefaultFileNameGenerator - Class in org.springframework.integration.file
-
Default implementation of the filename generator strategy.
- DefaultFileNameGenerator() - Constructor for class org.springframework.integration.file.DefaultFileNameGenerator
-
- defaultFileTypeMap(FileTypeMap) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
-
Set the default type map.
- DefaultFtpSessionFactory - Class in org.springframework.integration.ftp.session
-
Default implementation of FTP SessionFactory.
- DefaultFtpSessionFactory() - Constructor for class org.springframework.integration.ftp.session.DefaultFtpSessionFactory
-
- DefaultFtpsSessionFactory - Class in org.springframework.integration.ftp.session
-
SessionFactory for FTPS.
- DefaultFtpsSessionFactory() - Constructor for class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- DefaultHeaderChannelRegistry - Class in org.springframework.integration.channel
-
Converts a channel to a name, retaining a reference to the channel keyed by the name.
- DefaultHeaderChannelRegistry() - Constructor for class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
Constructs a registry with the default delay for channel expiry.
- DefaultHeaderChannelRegistry(long) - Constructor for class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
Constructs a registry with the provided delay (milliseconds) for
channel expiry.
- DefaultHttpHeaderMapper - Class in org.springframework.integration.http.support
-
- DefaultHttpHeaderMapper() - Constructor for class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- DefaultInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
-
Parser for the <inbound-channel-adapter/> element.
- DefaultInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.DefaultInboundChannelAdapterParser
-
- DefaultJmsHeaderMapper - Class in org.springframework.integration.jms
-
- DefaultJmsHeaderMapper() - Constructor for class org.springframework.integration.jms.DefaultJmsHeaderMapper
-
- DefaultJpaOperations - Class in org.springframework.integration.jpa.core
-
Class similar to JPA template limited to the operations required for the JPA adapters/gateway
not using JpaTemplate as the class is deprecated since Spring 3.1.
- DefaultJpaOperations() - Constructor for class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- DefaultLeaderEventPublisher - Class in org.springframework.integration.leader.event
-
- DefaultLeaderEventPublisher() - Constructor for class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
-
Instantiates a new leader event publisher.
- DefaultLeaderEventPublisher(ApplicationEventPublisher) - Constructor for class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
-
Instantiates a new leader event publisher.
- DefaultLockRegistry - Class in org.springframework.integration.support.locks
-
Default implementation of
LockRegistry
which uses Masked Hashcode algorithm to obtain locks.
- DefaultLockRegistry() - Constructor for class org.springframework.integration.support.locks.DefaultLockRegistry
-
Constructs a DefaultLockRegistry with the default
mask 0xFF with 256 locks.
- DefaultLockRegistry(int) - Constructor for class org.springframework.integration.support.locks.DefaultLockRegistry
-
Constructs a DefaultLockRegistry with the supplied
mask - the mask must have a value Math.pow(2, n) - 1 where n
is 1 to 31, creating a hash of Math.pow(2, n) locks.
- DefaultLockRepository - Class in org.springframework.integration.jdbc.lock
-
The default implementation of the
LockRepository
based on the
table from the script presented in the
org/springframework/integration/jdbc/schema-*.sql
.
- DefaultLockRepository(DataSource) - Constructor for class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Constructor that initializes the client id that will be associated for
all the locks persisted by the store instance to a random
UUID
.
- DefaultLockRepository(DataSource, String) - Constructor for class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Constructor that allows the user to specify a client id that will
be associated for all the locks persisted by the store instance.
- DefaultMailHeaderMapper - Class in org.springframework.integration.mail.support
-
- DefaultMailHeaderMapper() - Constructor for class org.springframework.integration.mail.support.DefaultMailHeaderMapper
-
- DefaultMBeanAttributeFilter - Class in org.springframework.integration.jmx
-
- DefaultMBeanAttributeFilter() - Constructor for class org.springframework.integration.jmx.DefaultMBeanAttributeFilter
-
- DefaultMBeanObjectConverter - Class in org.springframework.integration.jmx
-
- DefaultMBeanObjectConverter() - Constructor for class org.springframework.integration.jmx.DefaultMBeanObjectConverter
-
- DefaultMBeanObjectConverter(MBeanAttributeFilter) - Constructor for class org.springframework.integration.jmx.DefaultMBeanObjectConverter
-
- DefaultMessageBuilderFactory - Class in org.springframework.integration.support
-
- DefaultMessageBuilderFactory() - Constructor for class org.springframework.integration.support.DefaultMessageBuilderFactory
-
- DefaultMessageConverter - Class in org.springframework.integration.syslog
-
- DefaultMessageConverter() - Constructor for class org.springframework.integration.syslog.DefaultMessageConverter
-
- DefaultMessageSplitter - Class in org.springframework.integration.splitter
-
The default Message Splitter implementation.
- DefaultMessageSplitter() - Constructor for class org.springframework.integration.splitter.DefaultMessageSplitter
-
- DefaultMqttPahoClientFactory - Class in org.springframework.integration.mqtt.core
-
Creates a default MqttClient
and a set of options as configured.
- DefaultMqttPahoClientFactory() - Constructor for class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
-
- DefaultMqttPahoClientFactory.Will - Class in org.springframework.integration.mqtt.core
-
- DefaultMultipartFileReader - Class in org.springframework.integration.http.multipart
-
- DefaultMultipartFileReader() - Constructor for class org.springframework.integration.http.multipart.DefaultMultipartFileReader
-
- DefaultOutboundChannelAdapterParser - Class in org.springframework.integration.config.xml
-
Parser for the <outbound-channel-adapter/> element.
- DefaultOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.DefaultOutboundChannelAdapterParser
-
- defaultOutputChannel(String) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
-
Specify a
MessageChannel
bean name as a default output from the router.
- defaultOutputChannel(MessageChannel) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
-
- defaultOutputToParentFlow() - Method in class org.springframework.integration.dsl.AbstractRouterSpec
-
Make a default output mapping of the router to the parent flow.
- defaultOverwrite(boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
Determine the default action to take when setting individual header specifications
without an explicit 'overwrite' argument.
- DefaultPahoMessageConverter - Class in org.springframework.integration.mqtt.support
-
Default implementation for mapping to/from Messages.
- DefaultPahoMessageConverter() - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter with default options (qos=0, retain=false, charset=UTF-8).
- DefaultPahoMessageConverter(int, boolean) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter to create outbound messages with the supplied default qos and
retain settings and a UTF-8 charset for converting outbound String payloads to
byte[]
and inbound
byte[]
to String (unless
payloadAdBytes
is true).
- DefaultPahoMessageConverter(String) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter with default options (qos=0, retain=false) and
the supplied charset.
- DefaultPahoMessageConverter(int, boolean, String) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter to create outbound messages with the supplied default qos and
retain settings and the supplied charset.
- DefaultPahoMessageConverter(int, MessageProcessor<Integer>, boolean, MessageProcessor<Boolean>) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter to create outbound messages with the supplied default qos and
retained message processors and a UTF-8 charset for converting outbound String payloads to
byte[]
and inbound
byte[]
to String (unless
payloadAdBytes
is true).
- DefaultPahoMessageConverter(int, MessageProcessor<Integer>, boolean, MessageProcessor<Boolean>, String) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter to create outbound messages with the supplied default qos and
retain settings and the supplied charset.
- defaultQosProcessor() - Static method in interface org.springframework.integration.mqtt.support.MqttMessageConverter
-
- defaultReplyDestination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
-
- defaultReplyQueueName(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
-
- defaultReplyTimeout(Duration) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec
-
Default reply timeout.
- defaultReplyTo(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
The
defaultReplyTo
address with the form
(exchange)/(routingKey)
- defaultReplyTopicName(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
-
- defaultRequeueRejected(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-