- 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 org.springframework.amqp.rabbit.listener.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
-
Set MessagePostProcessor
s that will be applied after message reception, before
invoking the MessageListener
.
- 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(MessageListenerContainer) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
Construct an instance using the provided container.
- AmqpInboundChannelAdapter.BatchListener - Class in org.springframework.integration.amqp.inbound
-
- AmqpInboundChannelAdapter.BatchMode - Enum in org.springframework.integration.amqp.inbound
-
Defines the payload type when the listener container is configured with consumerBatchEnabled.
- AmqpInboundChannelAdapter.Listener - Class in org.springframework.integration.amqp.inbound
-
- AmqpInboundChannelAdapterDMLCSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for an inbound channel adapter with a DirectMessageListenerContainer
.
- AmqpInboundChannelAdapterDMLCSpec(DirectMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterDMLCSpec
-
- AmqpInboundChannelAdapterParser - Class in org.springframework.integration.amqp.config
-
Parser for the AMQP 'inbound-channel-adapter' element.
- AmqpInboundChannelAdapterSMLCSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for an inbound channel adapter with a SimpleMessageListenerContainer
.
- AmqpInboundChannelAdapterSMLCSpec(SimpleMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSMLCSpec
-
- AmqpInboundChannelAdapterSpec<S extends AmqpInboundChannelAdapterSpec<S,C>,C extends org.springframework.amqp.rabbit.listener.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
-
Construct
AmqpInboundGateway
based on the provided
AbstractMessageListenerContainer
to receive request messages and
AmqpTemplate
to send replies.
- AmqpInboundGateway(MessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Construct
AmqpInboundGateway
based on the provided
MessageListenerContainer
to receive request messages and
AmqpTemplate
to send replies.
- AmqpInboundGateway.Listener - Class in org.springframework.integration.amqp.inbound
-
- AmqpInboundGatewayDMLCSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for a gateway with a DirectMessageListenerContainer
.
- 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
-
Spec for a gateway with a SimpleMessageListenerContainer
.
- 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 org.springframework.amqp.rabbit.listener.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
-
- OBJECT_NAME - Static variable in class org.springframework.integration.jmx.JmxHeaders
-
- ObjectStringMapBuilder - Class in org.springframework.integration.support
-
A map builder creating a map with Object keys and String values.
- ObjectStringMapBuilder() - Constructor for class org.springframework.integration.support.ObjectStringMapBuilder
-
- ObjectStringMessageConverter - Class in org.springframework.integration.support.converter
-
- ObjectStringMessageConverter() - Constructor for class org.springframework.integration.support.converter.ObjectStringMessageConverter
-
- ObjectToJsonTransformer - Class in org.springframework.integration.json
-
Transformer implementation that converts a payload instance into a JSON string
representation.
- ObjectToJsonTransformer() - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
-
- ObjectToJsonTransformer(JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
-
- ObjectToJsonTransformer(ObjectToJsonTransformer.ResultType) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
-
- ObjectToJsonTransformer(JsonObjectMapper<?, ?>, ObjectToJsonTransformer.ResultType) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
-
- ObjectToJsonTransformer.ResultType - Enum in org.springframework.integration.json
-
- ObjectToJsonTransformerParser - Class in org.springframework.integration.config.xml
-
- ObjectToJsonTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
-
- ObjectToMapTransformer - Class in org.springframework.integration.transformer
-
Transforms an object graph into a Map.
- ObjectToMapTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToMapTransformer
-
- ObjectToMapTransformer(JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.transformer.ObjectToMapTransformer
-
- ObjectToMapTransformerParser - Class in org.springframework.integration.config.xml
-
- ObjectToMapTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToMapTransformerParser
-
- objectToString() - Static method in class org.springframework.integration.dsl.Transformers
-
- objectToString(String) - Static method in class org.springframework.integration.dsl.Transformers
-
- ObjectToStringTransformer - Class in org.springframework.integration.transformer
-
A simple transformer that creates an outbound payload by invoking the
inbound payload Object's toString()
method.
- ObjectToStringTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToStringTransformer
-
- ObjectToStringTransformer(String) - Constructor for class org.springframework.integration.transformer.ObjectToStringTransformer
-
- ObjectToStringTransformerParser - Class in org.springframework.integration.config.xml
-
Parser for the 'object-to-string-transformer' element.
- ObjectToStringTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToStringTransformerParser
-
- obtain(Object) - Method in class org.springframework.integration.gemfire.util.GemfireLockRegistry
-
- obtain(Object) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
-
- obtain(Object) - Method in class org.springframework.integration.redis.util.RedisLockRegistry
-
- obtain(Object) - Method in class org.springframework.integration.support.locks.DefaultLockRegistry
-
Obtains a lock by masking the lockKey's hashCode() with
the mask and using the result as an index to the lock table.
- obtain(Object) - Method in interface org.springframework.integration.support.locks.LockRegistry
-
Obtains the lock associated with the parameter object.
- obtain(Object) - Method in class org.springframework.integration.support.locks.PassThruLockRegistry
-
- obtain(Object) - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
-
- obtainComponentName(NamedComponent) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
-
- obtainConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
- obtainConnection() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- obtainConnection() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
- obtainConnection(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- obtainGroupTimeout(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- obtainInputChannelFromFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- obtainInputChannelFromFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.EndpointSpec
-
- obtainInputChannelFromFlow(IntegrationFlow, boolean) - Method in class org.springframework.integration.dsl.EndpointSpec
-
- obtainNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
- obtainPropagatingContext(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
-
- obtainPropagatingContext(Message<?>, MessageChannel) - Method in class org.springframework.integration.security.channel.SecurityContextPropagationChannelInterceptor
-
- obtainQueueName(String) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
-
- obtainQueueName(String) - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
-
- obtainSecurityMetadataSource() - Method in class org.springframework.integration.security.channel.ChannelSecurityInterceptor
-
- obtainSharedConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
- obtainSizeIfPossible(Iterable<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
-
- obtainSizeIfPossible(Iterator<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
-
- obtainSizeIfPossible(Iterator<?>) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
-
- offer(Message<?>) - Method in class org.springframework.integration.store.MessageGroupQueue
-
- offer(Message<?>, long, TimeUnit) - Method in class org.springframework.integration.store.MessageGroupQueue
-
- onAdd(String, String) - Method in interface org.springframework.integration.metadata.MetadataStoreListener
-
Invoked when a key is added to the store
- onAdd(String, String) - Method in class org.springframework.integration.metadata.MetadataStoreListenerAdapter
-
- onAppendEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
-
- onApplicationEvent(ApplicationContextEvent) - Method in class org.springframework.integration.config.IdGeneratorConfigurer
-
- onApplicationEvent(ContextClosedEvent) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
-
- onApplicationEvent(ApplicationEvent) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.graph.IntegrationGraphServer
-
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.handler.DelayHandler
-
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
-
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
- onApplicationEvent(AbstractLeaderEvent) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
-
- onClose(Connection) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
- onComplete() - Method in class org.springframework.integration.handler.AbstractMessageHandler
-
- onConnect(FtpSession) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
-
- onCreate(Connection) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
- onDeleteEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
-
- onDisconnect(FtpSession) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
-
- onError(Throwable) - Method in class org.springframework.integration.handler.AbstractMessageHandler
-
- onError(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- onEvent(CqEvent) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
-
- OnFailedToAcquireMutexEvent - Class in org.springframework.integration.leader.event
-
Generic event representing that a mutex could not be acquired during leader election.
- OnFailedToAcquireMutexEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.OnFailedToAcquireMutexEvent
-
Instantiate a new OnFailedToAcquireMutexEvent.
- onFailure(Message<File>) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
Adds the failed message back to the 'toBeReceived' queue if there is room.
- onGranted(Context) - Method in class org.springframework.integration.leader.AbstractCandidate
-
- onGranted(Context) - Method in interface org.springframework.integration.leader.Candidate
-
Callback method invoked when this candidate is elected leader.
- onGranted(Context) - Method in class org.springframework.integration.leader.DefaultCandidate
-
- OnGrantedEvent - Class in org.springframework.integration.leader.event
-
Generic event representing that leader has been granted.
- OnGrantedEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.OnGrantedEvent
-
Instantiates a new granted event.
- onInit() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- onInit() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
- onInit() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- onInit() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- onInit() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
- onInit() - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
- onInit() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- onInit() - Method in class org.springframework.integration.channel.DirectChannel
-
- onInit() - Method in class org.springframework.integration.channel.ExecutorChannel
-
- onInit() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
-
Callback method for initialization.
- onInit() - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
Subclasses may implement this for initialization logic.
- onInit() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
- onInit() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- onInit() - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
-
- onInit() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- onInit() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
-
- onInit() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
-
- onInit() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- onInit() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- onInit() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
-
- onInit() - Method in class org.springframework.integration.file.FileReadingMessageSource
-
- onInit() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
- onInit() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
- onInit() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- onInit() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
-
- onInit() - Method in class org.springframework.integration.gateway.AnnotationGatewayProxyFactoryBean
-
- onInit() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- onInit() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- onInit() - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
-
- onInit() - Method in class org.springframework.integration.gemfire.outbound.CacheWritingMessageHandler
-
- onInit() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
- onInit() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
- onInit() - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
-
- onInit() - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
- onInit() - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- onInit() - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
-
- onInit() - Method in class org.springframework.integration.handler.LoggingHandler
-
- onInit() - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- onInit() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
- onInit() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
- onInit() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
- onInit() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- onInit() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
- onInit() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- onInit() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- onInit() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- onInit() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- onInit() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- onInit() - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
-
- onInit() - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
-
- onInit() - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
- onInit() - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
-
- onInit() - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- onInit() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- onInit() - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
- onInit() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
- onInit() - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
-
- onInit() - Method in class org.springframework.integration.jpa.inbound.JpaPollingChannelAdapter
-
Check for mandatory attributes
- onInit() - Method in class org.springframework.integration.json.JsonToObjectTransformer
-
- onInit() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
-
- onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
-
- onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
- onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
-
- onInit() - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- onInit() - Method in class org.springframework.integration.mail.ImapMailReceiver
-
- onInit() - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
- onInit() - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
-
- onInit() - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
-
- onInit() - Method in class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
-
- onInit() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
-
- onInit() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
- onInit() - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
- onInit() - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
-
- onInit() - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
-
- onInit() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- onInit() - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
- onInit() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- onInit() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- onInit() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- onInit() - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
- onInit() - Method in class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
-
- onInit() - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- onInit() - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
- onInit() - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
- onInit() - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
-
- onInit() - Method in class org.springframework.integration.rmi.RmiInboundGateway
-
Deprecated.
- onInit() - Method in class org.springframework.integration.router.AbstractMessageRouter
-
- onInit() - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
-
- onInit() - Method in class org.springframework.integration.router.RecipientListRouter
-
- onInit() - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
-
- onInit() - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
-
- onInit() - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
-
- onInit() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
-
- onInit() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
-
- onInit() - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- onInit() - Method in class org.springframework.integration.transformer.DecodingTransformer
-
- onInit() - Method in class org.springframework.integration.transformer.HeaderEnricher
-
- onInit() - Method in class org.springframework.integration.transformer.HeaderFilter
-
- onInit() - Method in class org.springframework.integration.transformer.MapToObjectTransformer
-
- onInit() - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
-
- onInit() - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
-
- onInit() - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
-
- onInit() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- onInit() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
- onInit() - Method in class org.springframework.integration.websocket.outbound.WebSocketOutboundMessageHandler
-
- onInit() - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
-
- onInit() - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
-
- onInit() - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
- onInit() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
-
- onInit() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
-
- onInit() - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
-
- onInit() - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
-
- onInit() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
-
- onInit() - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
-
- OnlyOnceTrigger - Class in org.springframework.integration.test.util
-
- OnlyOnceTrigger() - Constructor for class org.springframework.integration.test.util.OnlyOnceTrigger
-
- onMessage(Message, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
-
- onMessage(Message, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway.Listener
-
- onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- onMessage(Message<?>) - Method in interface org.springframework.integration.ip.tcp.connection.TcpListener
-
Called by a TCPConnection when a new message arrives.
- onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- onMessage(Message, Session) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- onMessage(Message) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- onMessage(Message<?>) - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
-
- onMessage(WebSocketSession, WebSocketMessage<?>) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
- onMessage(WebSocketSession, WebSocketMessage<?>) - Method in interface org.springframework.integration.websocket.WebSocketListener
-
- onMessageBatch(List<Message>, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchListener
-
- onMkdirEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
-
- onNext(Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageHandler
-
- onPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
-
Specify a
BiConsumer
for seeks management during
ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)
call from the
KafkaMessageListenerContainer
.
- onPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
-
Specify a
BiConsumer
for seeks management during
ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)
call from the
KafkaMessageListenerContainer
.
- onRemove(String, String) - Method in interface org.springframework.integration.metadata.MetadataStoreListener
-
Invoked when a key is removed from the store
- onRemove(String, String) - Method in class org.springframework.integration.metadata.MetadataStoreListenerAdapter
-
- onRenameEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
-
- onRevoked(Context) - Method in class org.springframework.integration.leader.AbstractCandidate
-
- onRevoked(Context) - Method in interface org.springframework.integration.leader.Candidate
-
Callback method invoked when this candidate is no longer leader.
- onRevoked(Context) - Method in class org.springframework.integration.leader.DefaultCandidate
-
- OnRevokedEvent - Class in org.springframework.integration.leader.event
-
Generic event representing that leader has been revoked.
- OnRevokedEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.OnRevokedEvent
-
Instantiates a new revoked event.
- onRmdirEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
-
- onRotation(MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
-
Update the state of the
MessageSource
after the server is rotated, if necessary.
- onSubscribe(Subscription) - Method in class org.springframework.integration.handler.AbstractMessageHandler
-
- onUpdate(String, String) - Method in interface org.springframework.integration.metadata.MetadataStoreListener
-
Invoked when a key is updated into the store
- onUpdate(String, String) - Method in class org.springframework.integration.metadata.MetadataStoreListenerAdapter
-
- onUploadEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
-
- open(RetryContext, RetryCallback<T, E>) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- openFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- OPERATION_NAME - Static variable in class org.springframework.integration.jmx.JmxHeaders
-
- OperationInvokingChannelAdapterParser - Class in org.springframework.integration.jmx.config
-
- OperationInvokingChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.OperationInvokingChannelAdapterParser
-
- OperationInvokingMessageHandler - Class in org.springframework.integration.jmx
-
- OperationInvokingMessageHandler(MBeanServerConnection) - Constructor for class org.springframework.integration.jmx.OperationInvokingMessageHandler
-
- OperationInvokingOutboundGatewayParser - Class in org.springframework.integration.jmx.config
-
- OperationInvokingOutboundGatewayParser() - Constructor for class org.springframework.integration.jmx.config.OperationInvokingOutboundGatewayParser
-
- options(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Specify the array of options for various gateway commands.
- options(AbstractRemoteFileOutboundGateway.Option...) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Specify the array of AbstractRemoteFileOutboundGateway.Option
for various gateway commands.
- options(ChangeStreamOptions) - Method in class org.springframework.integration.mongodb.dsl.MongoDbChangeStreamMessageProducerSpec
-
- OracleChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
-
- OracleChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
-
- ORDER - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- order(int) - Method in class org.springframework.integration.dsl.BarrierSpec
-
- order(int) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
-
- Orderable - Interface in org.springframework.integration.context
-
- OrderlyShutdownCapable - Interface in org.springframework.integration.context
-
Interface for components that wish to be considered for
an orderly shutdown using management interfaces.
- orderlyShutdownCapableComponentsAfter() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- orderlyShutdownCapableComponentsBefore() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- org.springframework.integration - package org.springframework.integration
-
Base package for Spring Integration Core.
- org.springframework.integration.acks - package org.springframework.integration.acks
-
Provides classes related to message acknowledgment.
- org.springframework.integration.aggregator - package org.springframework.integration.aggregator
-
Provides classes related to message aggregation.
- org.springframework.integration.amqp.channel - package org.springframework.integration.amqp.channel
-
Provides classes related to AMQP-backed channels.
- org.springframework.integration.amqp.config - package org.springframework.integration.amqp.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.amqp.dsl - package org.springframework.integration.amqp.dsl
-
Provides AMQP Component support for the Java DSL.
- org.springframework.integration.amqp.inbound - package org.springframework.integration.amqp.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.amqp.outbound - package org.springframework.integration.amqp.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.integration.amqp.support - package org.springframework.integration.amqp.support
-
Provides AMQP support classes.
- org.springframework.integration.annotation - package org.springframework.integration.annotation
-
Provides annotations for annotation-based configuration.
- org.springframework.integration.aop - package org.springframework.integration.aop
-
Provides classes to support message publication using AOP.
- org.springframework.integration.channel - package org.springframework.integration.channel
-
Provides classes representing various channel types.
- org.springframework.integration.channel.interceptor - package org.springframework.integration.channel.interceptor
-
Provides classes related to channel interception.
- org.springframework.integration.codec - package org.springframework.integration.codec
-
Provides base classes for the Codec
abstraction.
- org.springframework.integration.codec.kryo - package org.springframework.integration.codec.kryo
-
The
Kryo specific
Codec
classes.
- org.springframework.integration.config - package org.springframework.integration.config
-
Base package for configuration.
- org.springframework.integration.config.annotation - package org.springframework.integration.config.annotation
-
Provides classes supporting annotation-based configuration.
- org.springframework.integration.config.xml - package org.springframework.integration.config.xml
-
Provides supporting XML-based configuration - parsers, namespace handlers.
- org.springframework.integration.context - package org.springframework.integration.context
-
Provides classes relating to application context configuration.
- org.springframework.integration.core - package org.springframework.integration.core
-
Provides core classes.
- org.springframework.integration.dispatcher - package org.springframework.integration.dispatcher
-
Provides classes related to dispatching messages.
- org.springframework.integration.dsl - package org.springframework.integration.dsl
-
Root package of the Spring Integration Java DSL.
- org.springframework.integration.dsl.context - package org.springframework.integration.dsl.context
-
The context support classes for Spring Integration Java DSL.
- org.springframework.integration.dsl.support - package org.springframework.integration.dsl.support
-
Provides various support classes used across Spring Integration Java DSL Components.
- org.springframework.integration.endpoint - package org.springframework.integration.endpoint
-
Provides core classes related to Endpoints.
- org.springframework.integration.event.config - package org.springframework.integration.event.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.event.core - package org.springframework.integration.event.core
-
Provides Event core classes.
- org.springframework.integration.event.inbound - package org.springframework.integration.event.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.event.outbound - package org.springframework.integration.event.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.integration.events - package org.springframework.integration.events
-
ApplicationEvents generated by the Spring Integration framework.
- org.springframework.integration.expression - package org.springframework.integration.expression
-
Provides classes supporting SpEL expressions.
- org.springframework.integration.feed.config - package org.springframework.integration.feed.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.feed.dsl - package org.springframework.integration.feed.dsl
-
Provides Feed Components support for Spring Integration Java DSL.
- org.springframework.integration.feed.inbound - package org.springframework.integration.feed.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.file - package org.springframework.integration.file
-
Base package for File support.
- org.springframework.integration.file.config - package org.springframework.integration.file.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.file.dsl - package org.springframework.integration.file.dsl
-
Provides File Components support for Spring Integration Java DSL.
- org.springframework.integration.file.event - package org.springframework.integration.file.event
-
ApplicationEvents generated by the file module.
- org.springframework.integration.file.filters - package org.springframework.integration.file.filters
-
Provides classes supporting file filtering.
- org.springframework.integration.file.locking - package org.springframework.integration.file.locking
-
Provides classes supporting file locking.
- org.springframework.integration.file.remote - package org.springframework.integration.file.remote
-
Base package for supporting remote files.
- org.springframework.integration.file.remote.aop - package org.springframework.integration.file.remote.aop
-
Provides classes related to AOP.
- org.springframework.integration.file.remote.gateway - package org.springframework.integration.file.remote.gateway
-
Provides classes supporting remote file gateways.
- org.springframework.integration.file.remote.handler - package org.springframework.integration.file.remote.handler
-
Provides classes supporting remote file message handlers.
- org.springframework.integration.file.remote.server - package org.springframework.integration.file.remote.server
-
Provides classes related to file servers.
- org.springframework.integration.file.remote.session - package org.springframework.integration.file.remote.session
-
Provides classes supporting remote file sessions.
- org.springframework.integration.file.remote.synchronizer - package org.springframework.integration.file.remote.synchronizer
-
Provides classes supporting the synchronization of remote and
local file directories.
- org.springframework.integration.file.splitter - package org.springframework.integration.file.splitter
-
- org.springframework.integration.file.support - package org.springframework.integration.file.support
-
Provides various support classes used across Spring Integration File Components.
- org.springframework.integration.file.tail - package org.springframework.integration.file.tail
-
Classes used for tailing file system files.
- org.springframework.integration.file.transformer - package org.springframework.integration.file.transformer
-
Provides classes supporting the transformation of file contents
to messages.
- org.springframework.integration.filter - package org.springframework.integration.filter
-
Provides classes supporting the filter pattern.
- org.springframework.integration.ftp.config - package org.springframework.integration.ftp.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.ftp.dsl - package org.springframework.integration.ftp.dsl
-
Provides FTP Components for the Java DSL.
- org.springframework.integration.ftp.filters - package org.springframework.integration.ftp.filters
-
Provides classes supporting FTP file filtering.
- org.springframework.integration.ftp.gateway - package org.springframework.integration.ftp.gateway
-
Provides classes supporting FTP gateways.
- org.springframework.integration.ftp.inbound - package org.springframework.integration.ftp.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.ftp.outbound - package org.springframework.integration.ftp.outbound
-
Provides classes for the FTP outbound channel adapter.
- org.springframework.integration.ftp.server - package org.springframework.integration.ftp.server
-
Provides classes related to FTP servers.
- org.springframework.integration.ftp.session - package org.springframework.integration.ftp.session
-
Provides classes supporting FTP sessions.
- org.springframework.integration.gateway - package org.springframework.integration.gateway
-
Provides classes supporting messaging gateways.
- org.springframework.integration.gemfire.config.xml - package org.springframework.integration.gemfire.config.xml
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.gemfire.inbound - package org.springframework.integration.gemfire.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.gemfire.metadata - package org.springframework.integration.gemfire.metadata
-
Provides classes for the Gemfire MetadataStore.
- org.springframework.integration.gemfire.outbound - package org.springframework.integration.gemfire.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.integration.gemfire.store - package org.springframework.integration.gemfire.store
-
Provides classes releated to storing messages.
- org.springframework.integration.gemfire.util - package org.springframework.integration.gemfire.util
-
Provides utility classes.
- org.springframework.integration.graph - package org.springframework.integration.graph
-
Provides classes related to the runtime object graph.
- org.springframework.integration.groovy - package org.springframework.integration.groovy
-
Base package for Groovy support.
- org.springframework.integration.groovy.config - package org.springframework.integration.groovy.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.handler - package org.springframework.integration.handler
-
Provides classes implementing various types of message handler.
- org.springframework.integration.handler.advice - package org.springframework.integration.handler.advice
-
Provides classes that are used to advise
MessageHandler
s with
cross-cutting concerns.
- org.springframework.integration.handler.support - package org.springframework.integration.handler.support
-
Provides classes for message handlers support.
- org.springframework.integration.history - package org.springframework.integration.history
-
Provides classes supporting the capture of message history.
- org.springframework.integration.http - package org.springframework.integration.http
-
Base package for Http support.
- org.springframework.integration.http.config - package org.springframework.integration.http.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.http.converter - package org.springframework.integration.http.converter
-
Provides classes supporting message conversion.
- org.springframework.integration.http.dsl - package org.springframework.integration.http.dsl
-
Provides HTTP Components support for Spring Integration Java DSL.
- org.springframework.integration.http.inbound - package org.springframework.integration.http.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.http.management - package org.springframework.integration.http.management
-
Provides classes related to management support.
- org.springframework.integration.http.multipart - package org.springframework.integration.http.multipart
-
Provides classes supporting multipart HTTP requests.
- org.springframework.integration.http.outbound - package org.springframework.integration.http.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.integration.http.support - package org.springframework.integration.http.support
-
Provides classes to support Http endpoints, including header
mapping.
- org.springframework.integration.ip - package org.springframework.integration.ip
-
Base package for IP (TCP/UDP) Support.
- org.springframework.integration.ip.config - package org.springframework.integration.ip.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.ip.dsl - package org.springframework.integration.ip.dsl
-
Provides TCP/UDP Component support for the Java DSL.
- org.springframework.integration.ip.event - package org.springframework.integration.ip.event
-
ApplicationEvents generated by the ip module.
- org.springframework.integration.ip.tcp - package org.springframework.integration.ip.tcp
-
Base package for TCP Support.
- org.springframework.integration.ip.tcp.connection - package org.springframework.integration.ip.tcp.connection
-
All things related to tcp connections - client and
server factories; listener and sender interfaces.
- org.springframework.integration.ip.tcp.serializer - package org.springframework.integration.ip.tcp.serializer
-
Byte array (de)serializers for putting some protocol on the
wire so that incoming messages can be constructed from stream data.
- org.springframework.integration.ip.udp - package org.springframework.integration.ip.udp
-
Base package for UDP support.
- org.springframework.integration.ip.util - package org.springframework.integration.ip.util
-
Provides utilities for IP support.
- org.springframework.integration.jdbc - package org.springframework.integration.jdbc
-
Root package of the Spring Integration JDBC module, which contains various
JDBC and Stored Procedure/Function supporting components.
- org.springframework.integration.jdbc.config - package org.springframework.integration.jdbc.config
-
Contains parser classes for the JDBC namespace support.
- org.springframework.integration.jdbc.lock - package org.springframework.integration.jdbc.lock
-
- org.springframework.integration.jdbc.metadata - package org.springframework.integration.jdbc.metadata
-
Contains JDBC implementation of MetadataStore
- org.springframework.integration.jdbc.store - package org.springframework.integration.jdbc.store
-
Provides JDBC-backed Message Store implementations.
- org.springframework.integration.jdbc.store.channel - package org.springframework.integration.jdbc.store.channel
-
Provides support classes for the JdbcChannelMessageStore.
- org.springframework.integration.jdbc.storedproc - package org.springframework.integration.jdbc.storedproc
-
Provides Stored Procedure/Function supporting classes.
- org.springframework.integration.jms - package org.springframework.integration.jms
-
Base package for JMS Support.
- org.springframework.integration.jms.config - package org.springframework.integration.jms.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.jms.dsl - package org.springframework.integration.jms.dsl
-
Provides JMS Component support for the Java DSL.
- org.springframework.integration.jms.util - package org.springframework.integration.jms.util
-
- org.springframework.integration.jmx - package org.springframework.integration.jmx
-
Base package for JMX support.
- org.springframework.integration.jmx.config - package org.springframework.integration.jmx.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.jpa.config.xml - package org.springframework.integration.jpa.config.xml
-
Provides parser classes to provide Xml namespace support for the Jpa components.
- org.springframework.integration.jpa.core - package org.springframework.integration.jpa.core
-
Provides core classes of the JPA module.
- org.springframework.integration.jpa.dsl - package org.springframework.integration.jpa.dsl
-
Provides JPA Components support for Java DSL.
- org.springframework.integration.jpa.inbound - package org.springframework.integration.jpa.inbound
-
Provides inbound Spring Integration Jpa components.
- org.springframework.integration.jpa.outbound - package org.springframework.integration.jpa.outbound
-
Provides Spring Integration components for doing outbound operations.
- org.springframework.integration.jpa.support - package org.springframework.integration.jpa.support
-
Provides various support classes used across Spring Integration Jpa Components.
- org.springframework.integration.jpa.support.parametersource - package org.springframework.integration.jpa.support.parametersource
-
Provides generic support for ParameterSources and ParameterSource Factories.
- org.springframework.integration.json - package org.springframework.integration.json
-
Provides classes supporting JSON in Spring Integration.
- org.springframework.integration.kafka.channel - package org.springframework.integration.kafka.channel
-
Provides classes related to message channels.
- org.springframework.integration.kafka.config.xml - package org.springframework.integration.kafka.config.xml
-
Provides parser classes to provide Xml namespace support for the Kafka components.
- org.springframework.integration.kafka.dsl - package org.springframework.integration.kafka.dsl
-
Provides Kafka Components support for Spring Integration Java DSL.
- org.springframework.integration.kafka.inbound - package org.springframework.integration.kafka.inbound
-
Provides inbound Spring Integration Kafka components.
- org.springframework.integration.kafka.outbound - package org.springframework.integration.kafka.outbound
-
Provides outbound Spring Integration Kafka components.
- org.springframework.integration.kafka.support - package org.springframework.integration.kafka.support
-
Provides support classes.
- org.springframework.integration.leader - package org.springframework.integration.leader
-
Temporary package until s-c-c-core is released.
- org.springframework.integration.leader.event - package org.springframework.integration.leader.event
-
Temporary package until s-c-c-core is released.
- org.springframework.integration.mail - package org.springframework.integration.mail
-
Base package for Mail support.
- org.springframework.integration.mail.config - package org.springframework.integration.mail.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.mail.dsl - package org.springframework.integration.mail.dsl
-
Provides Mail Components for the Java DSL.
- org.springframework.integration.mail.event - package org.springframework.integration.mail.event
-
Events generated by the mail module
- org.springframework.integration.mail.support - package org.springframework.integration.mail.support
-
Provides classes to support email.
- org.springframework.integration.mail.transformer - package org.springframework.integration.mail.transformer
-
Provides classes related to transforming mail messages.
- org.springframework.integration.mapping - package org.springframework.integration.mapping
-
Provides classes related to mapping to/from message headers.
- org.springframework.integration.mapping.support - package org.springframework.integration.mapping.support
-
Support classes for mapping.
- org.springframework.integration.message - package org.springframework.integration.message
-
Provides concrete
Message
implementations.
- org.springframework.integration.metadata - package org.springframework.integration.metadata
-
Provides classes supporting metadata stores.
- org.springframework.integration.mongodb.config - package org.springframework.integration.mongodb.config
-
Contains parser classes for the MongoDb namespace support.
- org.springframework.integration.mongodb.dsl - package org.springframework.integration.mongodb.dsl
-
Provides MongoDB Components support for Java DSL.
- org.springframework.integration.mongodb.inbound - package org.springframework.integration.mongodb.inbound
-
Provides classes related to the Mongo inbound channel adapters
- org.springframework.integration.mongodb.metadata - package org.springframework.integration.mongodb.metadata
-
Contains mongodb metadata store related classes
- org.springframework.integration.mongodb.outbound - package org.springframework.integration.mongodb.outbound
-
Provides classes related to the Mongo outbound channel adapters
- org.springframework.integration.mongodb.store - package org.springframework.integration.mongodb.store
-
Provides classes related to the MongoDB message store.
- org.springframework.integration.mongodb.support - package org.springframework.integration.mongodb.support
-
Provides supporting classes for this module.
- org.springframework.integration.monitor - package org.springframework.integration.monitor
-
Provides classes related to Spring Integration managed resources.
- org.springframework.integration.mqtt.config.xml - package org.springframework.integration.mqtt.config.xml
-
Provides parser classes to provide Xml namespace support for the MqttAdapter components.
- org.springframework.integration.mqtt.core - package org.springframework.integration.mqtt.core
-
Provides core classes of the MqttAdapter module.
- org.springframework.integration.mqtt.event - package org.springframework.integration.mqtt.event
-
ApplicationEvents generated by the mqtt module.
- org.springframework.integration.mqtt.inbound - package org.springframework.integration.mqtt.inbound
-
Provides inbound Spring Integration MqttAdapter components.
- org.springframework.integration.mqtt.outbound - package org.springframework.integration.mqtt.outbound
-
Provides Spring Integration components for doing outbound operations.
- org.springframework.integration.mqtt.support - package org.springframework.integration.mqtt.support
-
Provides various support classes used across Spring Integration MqttAdapter Components.
- org.springframework.integration.r2dbc.dsl - package org.springframework.integration.r2dbc.dsl
-
Provides classes for supporting Java DSL for R2DBC components.
- org.springframework.integration.r2dbc.inbound - package org.springframework.integration.r2dbc.inbound
-
Provides classes for supporting R2DBC inbound components.
- org.springframework.integration.r2dbc.outbound - package org.springframework.integration.r2dbc.outbound
-
Provides classes for supporting R2DBC outbound components.
- org.springframework.integration.redis.channel - package org.springframework.integration.redis.channel
-
Provides classes related to Redis-backed channels.
- org.springframework.integration.redis.config - package org.springframework.integration.redis.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.redis.event - package org.springframework.integration.redis.event
-
Events generated by the redis module
- org.springframework.integration.redis.inbound - package org.springframework.integration.redis.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.redis.metadata - package org.springframework.integration.redis.metadata
-
- org.springframework.integration.redis.outbound - package org.springframework.integration.redis.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.integration.redis.store - package org.springframework.integration.redis.store
-
Provides classes related to the Redis message store.
- org.springframework.integration.redis.support - package org.springframework.integration.redis.support
-
Provides supporting classes for this module.
- org.springframework.integration.redis.util - package org.springframework.integration.redis.util
-
Provides utility classes.
- org.springframework.integration.resource - package org.springframework.integration.resource
-
Provides classes related to messaging
using Spring
Resource
s
- org.springframework.integration.rmi - package org.springframework.integration.rmi
-
Base package for RMI support.
- org.springframework.integration.rmi.config - package org.springframework.integration.rmi.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.router - package org.springframework.integration.router
-
Provides classes supporting the router pattern.
- org.springframework.integration.routingslip - package org.springframework.integration.routingslip
-
Provides classes supporting the RoutingSlip pattern.
- org.springframework.integration.rsocket - package org.springframework.integration.rsocket
-
Provides common classes for RSocket components.
- org.springframework.integration.rsocket.config - package org.springframework.integration.rsocket.config
-
Provides classes for RSocket XML namespace parsing and configuration support.
- org.springframework.integration.rsocket.dsl - package org.springframework.integration.rsocket.dsl
-
Provides RSocket Components support for Spring Integration Java DSL.
- org.springframework.integration.rsocket.inbound - package org.springframework.integration.rsocket.inbound
-
Provides classes representing inbound RSocket components.
- org.springframework.integration.rsocket.outbound - package org.springframework.integration.rsocket.outbound
-
Provides classes representing outbound RSocket components.
- org.springframework.integration.scattergather - package org.springframework.integration.scattergather
-
Provides classes supporting the Scatter-Gather pattern.
- org.springframework.integration.scheduling - package org.springframework.integration.scheduling
-
Provides classes related to task scheduling.
- org.springframework.integration.scripting - package org.springframework.integration.scripting
-
Base package for scripting support.
- org.springframework.integration.scripting.config - package org.springframework.integration.scripting.config
-
Base package supporting configuration.
- org.springframework.integration.scripting.config.jsr223 - package org.springframework.integration.scripting.config.jsr223
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.scripting.dsl - package org.springframework.integration.scripting.dsl
-
Provides Scripting Components support for Spring Integration Java DSL.
- org.springframework.integration.scripting.jsr223 - package org.springframework.integration.scripting.jsr223
-
Provides classes supporting JSR223 Scripting.
- org.springframework.integration.security.channel - package org.springframework.integration.security.channel
-
Provides classes related to secured channels.
- org.springframework.integration.security.config - package org.springframework.integration.security.config
-
Provides classes for configuration - parsers, namespace handlers, bean post processors.
- org.springframework.integration.selector - package org.springframework.integration.selector
-
Provides classes related to message selection.
- org.springframework.integration.sftp.config - package org.springframework.integration.sftp.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.sftp.dsl - package org.springframework.integration.sftp.dsl
-
Provides SFTP Components for the Java DSL.
- org.springframework.integration.sftp.filters - package org.springframework.integration.sftp.filters
-
Provides classes supporting SFTP file filtering.
- org.springframework.integration.sftp.gateway - package org.springframework.integration.sftp.gateway
-
Provides classes supporting SFTP gateways.
- org.springframework.integration.sftp.inbound - package org.springframework.integration.sftp.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.sftp.outbound - package org.springframework.integration.sftp.outbound
-
Provides classes for the SFTP outbound channel adapter.
- org.springframework.integration.sftp.server - package org.springframework.integration.sftp.server
-
Provides classes related to SFTP servers.
- org.springframework.integration.sftp.session - package org.springframework.integration.sftp.session
-
Provides classes supporting SFTP sessions.
- org.springframework.integration.sftp.support - package org.springframework.integration.sftp.support
-
Provides general support classes for sftp.
- org.springframework.integration.splitter - package org.springframework.integration.splitter
-
Provides classes supporting the splitter pattern.
- org.springframework.integration.stomp - package org.springframework.integration.stomp
-
Provides core classes STOMP components.
- org.springframework.integration.stomp.config - package org.springframework.integration.stomp.config
-
Contains parser classes for the STOMP namespace support.
- org.springframework.integration.stomp.event - package org.springframework.integration.stomp.event
-
- org.springframework.integration.stomp.inbound - package org.springframework.integration.stomp.inbound
-
Provides classes which represent inbound STOMP components.
- org.springframework.integration.stomp.outbound - package org.springframework.integration.stomp.outbound
-
Provides classes which represent outbound STOMP components.
- org.springframework.integration.stomp.support - package org.springframework.integration.stomp.support
-
Provides classes to support STOMP components.
- org.springframework.integration.store - package org.springframework.integration.store
-
Provides classes releated to storing messages.
- org.springframework.integration.stream - package org.springframework.integration.stream
-
Base package for stream support.
- org.springframework.integration.stream.config - package org.springframework.integration.stream.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.support - package org.springframework.integration.support
-
Base core support package.
- org.springframework.integration.support.channel - package org.springframework.integration.support.channel
-
- org.springframework.integration.support.context - package org.springframework.integration.support.context
-
Provides classes supporting use of the application context.
- org.springframework.integration.support.converter - package org.springframework.integration.support.converter
-
Provides classes supporting message conversion.
- org.springframework.integration.support.json - package org.springframework.integration.support.json
-
Provides classes supporting json.
- org.springframework.integration.support.leader - package org.springframework.integration.support.leader
-
- org.springframework.integration.support.locks - package org.springframework.integration.support.locks
-
Provides classes related to locking resources.
- org.springframework.integration.support.management - package org.springframework.integration.support.management
-
Provides classes related to management support.
- org.springframework.integration.support.management.metrics - package org.springframework.integration.support.management.metrics
-
Provides interfaces related to 5.0 metrics.
- org.springframework.integration.support.management.micrometer - package org.springframework.integration.support.management.micrometer
-
Provides classes to support the use of Micrometer for metrics.
- org.springframework.integration.support.utils - package org.springframework.integration.support.utils
-
Provides global utility support classes for the runtime system.
- org.springframework.integration.syslog - package org.springframework.integration.syslog
-
Base package for Syslog Support.
- org.springframework.integration.syslog.config - package org.springframework.integration.syslog.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.syslog.inbound - package org.springframework.integration.syslog.inbound
-
Provides classes for inbound endpoints.
- org.springframework.integration.test.condition - package org.springframework.integration.test.condition
-
- org.springframework.integration.test.context - package org.springframework.integration.test.context
-
Test context-related components.
- org.springframework.integration.test.mail - package org.springframework.integration.test.mail
-
Provides testing utils for mail support.
- org.springframework.integration.test.matcher - package org.springframework.integration.test.matcher
-
Provides several BaseMatcher
implementations.
- org.springframework.integration.test.mock - package org.springframework.integration.test.mock
-
Utilities for mocking integration components.
- org.springframework.integration.test.predicate - package org.springframework.integration.test.predicate
-
- org.springframework.integration.test.rule - package org.springframework.integration.test.rule
-
Provides various test rules.
- org.springframework.integration.test.support - package org.springframework.integration.test.support
-
Provides several test support classes including for testing Spring Integration
request-response message scenarios.
- org.springframework.integration.test.util - package org.springframework.integration.test.util
-
Provides various test utilities, for example
TestUtils
provides convenience
helpers to easily retrieve private bean properties.
- org.springframework.integration.transaction - package org.springframework.integration.transaction
-
Provides classes supporting the use of transactions and
pseudo transactions in Spring Integration applications.
- org.springframework.integration.transformer - package org.springframework.integration.transformer
-
Contains core-implementation of various Transformers which includes Enrichers
and Filters.
- org.springframework.integration.transformer.support - package org.springframework.integration.transformer.support
-
Contains support classes for Transformers.
- org.springframework.integration.util - package org.springframework.integration.util
-
Provides core utility classes.
- org.springframework.integration.webflux.config - package org.springframework.integration.webflux.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.webflux.dsl - package org.springframework.integration.webflux.dsl
-
Provides WebFlux Components support for Spring Integration Java DSL.
- org.springframework.integration.webflux.inbound - package org.springframework.integration.webflux.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.webflux.outbound - package org.springframework.integration.webflux.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.integration.webflux.support - package org.springframework.integration.webflux.support
-
Provides classes to support WebFlux endpoints.
- org.springframework.integration.websocket - package org.springframework.integration.websocket
-
Provides classes used across all WebSocket components.
- org.springframework.integration.websocket.config - package org.springframework.integration.websocket.config
-
Contains parser classes for the WebSockets namespace support.
- org.springframework.integration.websocket.event - package org.springframework.integration.websocket.event
-
- org.springframework.integration.websocket.inbound - package org.springframework.integration.websocket.inbound
-
Provides classes which represent inbound WebSocket components.
- org.springframework.integration.websocket.outbound - package org.springframework.integration.websocket.outbound
-
Provides classes which represent outbound WebSocket components.
- org.springframework.integration.websocket.support - package org.springframework.integration.websocket.support
-
Provides support classes used from WebSocket components.
- org.springframework.integration.ws - package org.springframework.integration.ws
-
Provides several inbound and outbound Web Service components.
- org.springframework.integration.ws.config - package org.springframework.integration.ws.config
-
Contains parser classes for the Web Services namespace support.
- org.springframework.integration.ws.dsl - package org.springframework.integration.ws.dsl
-
Contains classes for DSL support.
- org.springframework.integration.xml - package org.springframework.integration.xml
-
Root package of the XML Module.
- org.springframework.integration.xml.config - package org.springframework.integration.xml.config
-
Contains parser classes for the XML namespace support.
- org.springframework.integration.xml.result - package org.springframework.integration.xml.result
-
- org.springframework.integration.xml.router - package org.springframework.integration.xml.router
-
Provides XML message routers.
- org.springframework.integration.xml.selector - package org.springframework.integration.xml.selector
-
- org.springframework.integration.xml.source - package org.springframework.integration.xml.source
-
- org.springframework.integration.xml.splitter - package org.springframework.integration.xml.splitter
-
- org.springframework.integration.xml.transformer - package org.springframework.integration.xml.transformer
-
Provides Transformer and Enricher implementations.
- org.springframework.integration.xml.transformer.support - package org.springframework.integration.xml.transformer.support
-
Contains support classes for Transformers.
- org.springframework.integration.xml.xpath - package org.springframework.integration.xml.xpath
-
Provides XPath supporting classes.
- org.springframework.integration.xmpp - package org.springframework.integration.xmpp
-
Root package of the Spring Integration XMPP Module.
- org.springframework.integration.xmpp.config - package org.springframework.integration.xmpp.config
-
Contains parser classes for the XMPP namespace support.
- org.springframework.integration.xmpp.core - package org.springframework.integration.xmpp.core
-
Provides classes shared across all XMPP components.
- org.springframework.integration.xmpp.inbound - package org.springframework.integration.xmpp.inbound
-
- org.springframework.integration.xmpp.outbound - package org.springframework.integration.xmpp.outbound
-
Provides XMPP outbound MessageHandler implementations.
- org.springframework.integration.xmpp.support - package org.springframework.integration.xmpp.support
-
Provides XMPP specific support classes.
- org.springframework.integration.zeromq - package org.springframework.integration.zeromq
-
Provides common classes for supporting ZeroMQ components.
- org.springframework.integration.zeromq.channel - package org.springframework.integration.zeromq.channel
-
Provides classes for message channels support over ZeroMQ.
- org.springframework.integration.zeromq.dsl - package org.springframework.integration.zeromq.dsl
-
Provides classes for supporting ZeroMQ component via Java DSL.
- org.springframework.integration.zeromq.inbound - package org.springframework.integration.zeromq.inbound
-
Provides classes for inbound channel adapters over ZeroMQ.
- org.springframework.integration.zeromq.outbound - package org.springframework.integration.zeromq.outbound
-
Provides classes for outbound channel adapters over ZeroMQ.
- org.springframework.integration.zookeeper.config - package org.springframework.integration.zookeeper.config
-
- org.springframework.integration.zookeeper.config.xml - package org.springframework.integration.zookeeper.config.xml
-
Base package for zookeeper configuration.
- org.springframework.integration.zookeeper.leader - package org.springframework.integration.zookeeper.leader
-
Temporary package until s-c-c-zookeeper is released.
- org.springframework.integration.zookeeper.lock - package org.springframework.integration.zookeeper.lock
-
Provides classes related to locking.
- org.springframework.integration.zookeeper.metadata - package org.springframework.integration.zookeeper.metadata
-
- origin(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
-
List of allowed origins, e.g.
- ORIGINAL_FILE - Static variable in class org.springframework.integration.file.FileHeaders
-
- OSDelegatingFileTailingMessageProducer - Class in org.springframework.integration.file.tail
-
A file tailing message producer that delegates to the OS tail program.
- OSDelegatingFileTailingMessageProducer() - Constructor for class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
-
- outboundAdapter(AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpOutboundEndpointSpec (adapter).
- outboundAdapter(File) - Static method in class org.springframework.integration.file.dsl.Files
-
- outboundAdapter(String) - Static method in class org.springframework.integration.file.dsl.Files
-
- outboundAdapter(Expression) - Static method in class org.springframework.integration.file.dsl.Files
-
- outboundAdapter(Function<Message<P>, ?>) - Static method in class org.springframework.integration.file.dsl.Files
-
- outboundAdapter(SessionFactory<FTPFile>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
-
- outboundAdapter(SessionFactory<FTPFile>, FileExistsMode) - Static method in class org.springframework.integration.ftp.dsl.Ftp
-
- outboundAdapter(RemoteFileTemplate<FTPFile>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
-
- outboundAdapter(RemoteFileTemplate<FTPFile>, FileExistsMode) - Static method in class org.springframework.integration.ftp.dsl.Ftp
-
- outboundAdapter(FtpRemoteFileTemplate) - Static method in class org.springframework.integration.ftp.dsl.Ftp
-
- outboundAdapter(FtpRemoteFileTemplate, FileExistsMode) - Static method in class org.springframework.integration.ftp.dsl.Ftp
-
- outboundAdapter(AbstractConnectionFactory) - Static method in class org.springframework.integration.ip.dsl.Tcp
-
Create an outbound gateway using the supplied connection factory.
- outboundAdapter(AbstractConnectionFactorySpec<?, ?>) - Static method in class org.springframework.integration.ip.dsl.Tcp
-
Create an outbound gateway using the supplied connection factory.
- outboundAdapter(String, int) - Static method in class org.springframework.integration.ip.dsl.Udp
-
Create an outbound unicast channel adapter using the supplied host and port.
- outboundAdapter(String) - Static method in class org.springframework.integration.ip.dsl.Udp
-
Create an outbound unicast channel adapter using the supplied destination
expression.
- outboundAdapter(Function<Message<?>, ?>) - Static method in class org.springframework.integration.ip.dsl.Udp
-
Create an outbound unicast channel adapter using the supplied destination
expression.
- outboundAdapter(JmsTemplate) - Static method in class org.springframework.integration.jms.dsl.Jms
-
- outboundAdapter(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
-
- outboundAdapter(EntityManagerFactory) - Static method in class org.springframework.integration.jpa.dsl.Jpa
-
- outboundAdapter(EntityManager) - Static method in class org.springframework.integration.jpa.dsl.Jpa
-
- outboundAdapter(JpaOperations) - Static method in class org.springframework.integration.jpa.dsl.Jpa
-
- outboundAdapter() - Static method in class org.springframework.integration.mail.dsl.Mail
-
- outboundAdapter(String) - Static method in class org.springframework.integration.mail.dsl.Mail
-
- outboundAdapter(MailSender) - Static method in class org.springframework.integration.mail.dsl.Mail
-
- outboundAdapter(SessionFactory<ChannelSftp.LsEntry>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
-
- outboundAdapter(SessionFactory<ChannelSftp.LsEntry>, FileExistsMode) - Static method in class org.springframework.integration.sftp.dsl.Sftp
-
- outboundAdapter(RemoteFileTemplate<ChannelSftp.LsEntry>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
-
- outboundAdapter(RemoteFileTemplate<ChannelSftp.LsEntry>, FileExistsMode) - Static method in class org.springframework.integration.sftp.dsl.Sftp
-
- outboundAdapter(SftpRemoteFileTemplate) - Static method in class org.springframework.integration.sftp.dsl.Sftp
-
- outboundAdapter(SftpRemoteFileTemplate, FileExistsMode) - Static method in class org.springframework.integration.sftp.dsl.Sftp
-
- outboundChannelAdapter(URI) - Static method in class org.springframework.integration.http.dsl.Http
-
- outboundChannelAdapter(String) - Static method in class org.springframework.integration.http.dsl.Http
-
- outboundChannelAdapter(Function<Message<P>, ?>) - Static method in class org.springframework.integration.http.dsl.Http
-
Create an
HttpMessageHandlerSpec
builder for one-way adapter based on provided
Function
to evaluate target
uri
against request message.
- outboundChannelAdapter(Expression) - Static method in class org.springframework.integration.http.dsl.Http
-
- outboundChannelAdapter(URI, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
-
- outboundChannelAdapter(String, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
-
- outboundChannelAdapter(Function<Message<P>, ?>, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
-
Create an
HttpMessageHandlerSpec
builder for one-way adapter
based on provided
Function
to evaluate target
uri
against request message
and
RestTemplate
for HTTP exchanges.
- outboundChannelAdapter(Expression, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
-
- outboundChannelAdapter(KafkaTemplate<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
-
- outboundChannelAdapter(ProducerFactory<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
-
- outboundChannelAdapter(R2dbcEntityOperations) - Static method in class org.springframework.integration.r2dbc.dsl.R2dbc
-
- outboundChannelAdapter(URI) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
- outboundChannelAdapter(String) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
- outboundChannelAdapter(Function<Message<P>, ?>) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
Create an
WebFluxMessageHandlerSpec
builder for one-way adapter based on provided
Function
to evaluate target
uri
against request message.
- outboundChannelAdapter(Expression) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
- outboundChannelAdapter(URI, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
- outboundChannelAdapter(String, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
- outboundChannelAdapter(Function<Message<P>, ?>, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
Create an
WebFluxMessageHandlerSpec
builder for one-way adapter
based on provided
Function
to evaluate target
uri
against request message
and
WebClient
for HTTP exchanges.
- outboundChannelAdapter(Expression, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
- outboundChannelAdapter(ZContext, String) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
-
- outboundChannelAdapter(ZContext, String, SocketType) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
-
- outboundGateway(AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
-
Create an initial AmqpOutboundEndpointSpec (gateway).
- outboundGateway(File) - Static method in class org.springframework.integration.file.dsl.Files
-
- outboundGateway(String) - Static method in class org.springframework.integration.file.dsl.Files
-
- outboundGateway(Expression) - Static method in class org.springframework.integration.file.dsl.Files
-
- outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.file.dsl.Files
-
- outboundGateway(SessionFactory<FTPFile>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.ftp.dsl.Ftp
-
- outboundGateway(SessionFactory<FTPFile>, String, String) - Static method in class org.springframework.integration.ftp.dsl.Ftp
-
- outboundGateway(RemoteFileTemplate<FTPFile>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.ftp.dsl.Ftp
-
- outboundGateway(RemoteFileTemplate<FTPFile>, String, String) - Static method in class org.springframework.integration.ftp.dsl.Ftp
-
- outboundGateway(SessionFactory<FTPFile>, MessageSessionCallback<FTPFile, ?>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
-
- outboundGateway(URI) - Static method in class org.springframework.integration.http.dsl.Http
-
- outboundGateway(String) - Static method in class org.springframework.integration.http.dsl.Http
-
- outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.http.dsl.Http
-
Create an
HttpMessageHandlerSpec
builder for request-reply gateway
based on provided
Function
to evaluate target
uri
against request message.
- outboundGateway(Expression) - Static method in class org.springframework.integration.http.dsl.Http
-
- outboundGateway(URI, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
-
- outboundGateway(String, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
-
- outboundGateway(Function<Message<P>, ?>, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
-
Create an
HttpMessageHandlerSpec
builder for request-reply gateway
based on provided
Function
to evaluate target
uri
against request message
and
RestTemplate
for HTTP exchanges.
- outboundGateway(Expression, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
-
- outboundGateway(AbstractClientConnectionFactory) - Static method in class org.springframework.integration.ip.dsl.Tcp
-
Create an outbound gateway using the supplied client connection factory.
- outboundGateway(TcpClientConnectionFactorySpec) - Static method in class org.springframework.integration.ip.dsl.Tcp
-
Create an outbound gateway using the supplied client connection factory.
- outboundGateway(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
-
- outboundGateway(ReplyingKafkaTemplate<K, V, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
-
- outboundGateway(ProducerFactory<K, V>, GenericMessageListenerContainer<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
-
- outboundGateway(MongoDatabaseFactory, MongoConverter) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
-
- outboundGateway(MongoOperations) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
-
- outboundGateway(String, Object...) - Static method in class org.springframework.integration.rsocket.dsl.RSockets
-
Create an
RSocketOutboundGatewaySpec
builder for request-reply gateway
based on provided
route
and optional variables to expand route template.
- outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.rsocket.dsl.RSockets
-
Create an
RSocketOutboundGatewaySpec
builder for request-reply gateway
based on provided
Function
to evaluate target
route
against request message.
- outboundGateway(Expression) - Static method in class org.springframework.integration.rsocket.dsl.RSockets
-
- outboundGateway(SessionFactory<ChannelSftp.LsEntry>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.sftp.dsl.Sftp
-
- outboundGateway(SessionFactory<ChannelSftp.LsEntry>, String, String) - Static method in class org.springframework.integration.sftp.dsl.Sftp
-
- outboundGateway(RemoteFileTemplate<ChannelSftp.LsEntry>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.sftp.dsl.Sftp
-
- outboundGateway(RemoteFileTemplate<ChannelSftp.LsEntry>, String, String) - Static method in class org.springframework.integration.sftp.dsl.Sftp
-
- outboundGateway(SessionFactory<ChannelSftp.LsEntry>, MessageSessionCallback<ChannelSftp.LsEntry, ?>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
-
- outboundGateway(URI) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
- outboundGateway(String) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
- outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
Create an
WebFluxMessageHandlerSpec
builder for request-reply gateway
based on provided
Function
to evaluate target
uri
against request message.
- outboundGateway(Expression) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
- outboundGateway(URI, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
- outboundGateway(String, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
- outboundGateway(Function<Message<P>, ?>, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
Create an
WebFluxMessageHandlerSpec
builder for request-reply gateway
based on provided
Function
to evaluate target
uri
against request message
and
WebClient
for HTTP exchanges.
- outboundGateway(Expression, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
-
- OutboundGatewayType - Enum in org.springframework.integration.jpa.support
-
Indicates the mode of operation for the outbound Jpa Gateway.
- outboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
- outboundMapper() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
Construct a default outbound header mapper.
- outboundMapper() - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Factory method for creating a basic outbound mapper instance.
- OutboundMessageMapper<T> - Interface in org.springframework.integration.mapping
-
Strategy interface for mapping from a
Message
to an Object.
- outboundMulticastAdapter(String, int) - Static method in class org.springframework.integration.ip.dsl.Udp
-
Create an outbound multicast channel adapter using the supplied host and port.
- outboundMulticastAdapter(String) - Static method in class org.springframework.integration.ip.dsl.Udp
-
Create an outbound multicast channel adapter using the supplied destination
expression.
- outboundMulticastAdapter(Function<Message<?>, ?>) - Static method in class org.springframework.integration.ip.dsl.Udp
-
Create an outbound multicast channel adapter using the supplied destination
expression.
- outboundReplyHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
- outboundRequestHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
- outputChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessageProducerSpec
-
- outputChannel(String) - Method in class org.springframework.integration.dsl.MessageProducerSpec
-
- outputChannel(MessageChannel) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
-
- outputExpression(String) - Method in class org.springframework.integration.dsl.AggregatorSpec
-
An expression to determine the output message from the released group.
- outputProcessor(MessageGroupProcessor) - Method in class org.springframework.integration.dsl.AggregatorSpec
-
A processor to determine the output message from the released group.
- outputProcessor(MessageGroupProcessor) - Method in class org.springframework.integration.dsl.BarrierSpec
-
- R2dbc - Class in org.springframework.integration.r2dbc.dsl
-
Java DSL Factory class for R2DBC components.
- R2dbcMessageHandler - Class in org.springframework.integration.r2dbc.outbound
-
Implementation of
ReactiveMessageHandler
which writes
Message payload into a Relational Database, using reactive r2dbc support.
- R2dbcMessageHandler(R2dbcEntityOperations) - Constructor for class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
-
Construct this instance using a fully created and initialized instance of provided
R2dbcEntityOperations
- R2dbcMessageHandler.Type - Enum in org.springframework.integration.r2dbc.outbound
-
- R2dbcMessageHandlerSpec - Class in org.springframework.integration.r2dbc.dsl
-
- R2dbcMessageHandlerSpec(R2dbcEntityOperations) - Constructor for class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
-
- R2dbcMessageSource - Class in org.springframework.integration.r2dbc.inbound
-
An instance of
MessageSource
which returns
a
Message
with a payload which is the result of
execution of query.
- R2dbcMessageSource(R2dbcEntityOperations, String) - Constructor for class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
-
Create an instance with the provided R2dbcEntityOperations
and SpEL expression
which should resolve to a Relational 'query' string.
- R2dbcMessageSource(R2dbcEntityOperations, Expression) - Constructor for class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
-
Create an instance with the provided R2dbcEntityOperations
and SpEL expression
which should resolve to a query string or StatementMapper.SelectSpec
instance.
- R2dbcMessageSource.SelectCreator - Class in org.springframework.integration.r2dbc.inbound
-
An instance of this class is used as a root object for query expression
to give a limited access only to the StatementMapper.createSelect(java.lang.String)
fluent API.
- R2dbcMessageSourceSpec - Class in org.springframework.integration.r2dbc.dsl
-
- R2dbcMessageSourceSpec(R2dbcEntityOperations, String) - Constructor for class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
-
- R2dbcMessageSourceSpec(R2dbcEntityOperations, Expression) - Constructor for class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
-
- RateLimiterRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
-
- RateLimiterRequestHandlerAdvice() - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
-
- RateLimiterRequestHandlerAdvice(String) - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
-
Construct an instance based on default rate limiter options and provided name.
- RateLimiterRequestHandlerAdvice(RateLimiter) - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
-
Construct an instance based on the provided RateLimiter
.
- RateLimiterRequestHandlerAdvice(RateLimiterConfig) - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
-
- RateLimiterRequestHandlerAdvice(RateLimiterConfig, String) - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
-
Construct an instance based on the provided RateLimiterConfig
and name.
- RateLimiterRequestHandlerAdvice.RateLimitExceededException - Exception in org.springframework.integration.handler.advice
-
A
MessagingException
wrapper for the
RequestNotPermitted
with the
requestMessage
and
target
context.
- raw() - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
-
Return a serializer with the default max message size for deserialization.
- raw(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
-
Return a serializer with the provided max message size for deserialization.
- RAW_HEADERS - Static variable in class org.springframework.integration.mail.MailHeaders
-
- rawMessageHeader(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
-
- rawMessageHeader(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
-
- RawRecordHeaderErrorMessageStrategy - Class in org.springframework.integration.kafka.support
-
- RawRecordHeaderErrorMessageStrategy() - Constructor for class org.springframework.integration.kafka.support.RawRecordHeaderErrorMessageStrategy
-
- reactiveAdapterRegistry(ReactiveAdapterRegistry) - Method in class org.springframework.integration.webflux.dsl.WebFluxInboundEndpointSpec
-
- reactiveInboundChannelAdapter(ReactiveMongoDatabaseFactory, String) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
-
- reactiveInboundChannelAdapter(ReactiveMongoDatabaseFactory, Query) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
-
- reactiveInboundChannelAdapter(ReactiveMongoOperations, String) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
-
- reactiveInboundChannelAdapter(ReactiveMongoOperations, Query) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
-
- reactiveMessageHandler - Variable in class org.springframework.integration.dsl.ReactiveMessageHandlerSpec
-
- ReactiveMessageHandlerAdapter - Class in org.springframework.integration.handler
-
- ReactiveMessageHandlerAdapter(ReactiveMessageHandler) - Constructor for class org.springframework.integration.handler.ReactiveMessageHandlerAdapter
-
- ReactiveMessageHandlerSpec<S extends ReactiveMessageHandlerSpec<S,H>,H extends ReactiveMessageHandler> - Class in org.springframework.integration.dsl
-
- ReactiveMessageHandlerSpec(H) - Constructor for class org.springframework.integration.dsl.ReactiveMessageHandlerSpec
-
- ReactiveMessageSourceProducer - Class in org.springframework.integration.endpoint
-
- ReactiveMessageSourceProducer(MessageSource<?>) - Constructor for class org.springframework.integration.endpoint.ReactiveMessageSourceProducer
-
- ReactiveMongoDbMessageHandlerSpec - Class in org.springframework.integration.mongodb.dsl
-
- ReactiveMongoDbMessageHandlerSpec(ReactiveMongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
-
- ReactiveMongoDbMessageHandlerSpec(ReactiveMongoOperations) - Constructor for class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
-
- ReactiveMongoDbMessageSource - Class in org.springframework.integration.mongodb.inbound
-
- ReactiveMongoDbMessageSource(ReactiveMongoDatabaseFactory, Expression) - Constructor for class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
-
Create an instance with the provided
ReactiveMongoDatabaseFactory
and SpEL expression
which should resolve to a MongoDb 'query' string (see https://www.mongodb.org/display/DOCS/Querying).
- ReactiveMongoDbMessageSource(ReactiveMongoOperations, Expression) - Constructor for class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
-
Create an instance with the provided
ReactiveMongoOperations
and SpEL expression
which should resolve to a Mongo 'query' string (see https://www.mongodb.org/display/DOCS/Querying).
- ReactiveMongoDbMessageSourceSpec - Class in org.springframework.integration.mongodb.dsl
-
- ReactiveMongoDbMessageSourceSpec(ReactiveMongoDatabaseFactory, Expression) - Constructor for class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
-
- ReactiveMongoDbMessageSourceSpec(ReactiveMongoOperations, Expression) - Constructor for class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
-
- ReactiveMongoDbStoringMessageHandler - Class in org.springframework.integration.mongodb.outbound
-
- ReactiveMongoDbStoringMessageHandler(ReactiveMongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
-
- ReactiveMongoDbStoringMessageHandler(ReactiveMongoOperations) - Constructor for class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
-
- reactiveOutboundChannelAdapter(ReactiveMongoDatabaseFactory) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
-
- reactiveOutboundChannelAdapter(ReactiveMongoOperations) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
-
- ReactiveRedisStreamMessageHandler - Class in org.springframework.integration.redis.outbound
-
- ReactiveRedisStreamMessageHandler(ReactiveRedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
-
- ReactiveRedisStreamMessageHandler(ReactiveRedisConnectionFactory, Expression) - Constructor for class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
-
- ReactiveRedisStreamMessageProducer - Class in org.springframework.integration.redis.inbound
-
A
MessageProducerSupport
for reading messages from a Redis Stream and publishing them into the provided
output channel.
- ReactiveRedisStreamMessageProducer(ReactiveRedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
- ReactiveRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
-
- ReactiveRequestHandlerAdvice(BiFunction<Message<?>, Mono<?>, Publisher<?>>) - Constructor for class org.springframework.integration.handler.advice.ReactiveRequestHandlerAdvice
-
Instantiate advice based on a provided
BiFunction
customizer.
- ReactiveStreamsConsumer - Class in org.springframework.integration.endpoint
-
An
AbstractEndpoint
implementation for Reactive Streams subscription into an
input channel and reactive consumption of messages from that channel.
- ReactiveStreamsConsumer(MessageChannel, MessageHandler) - Constructor for class org.springframework.integration.endpoint.ReactiveStreamsConsumer
-
- ReactiveStreamsConsumer(MessageChannel, Subscriber<Message<?>>) - Constructor for class org.springframework.integration.endpoint.ReactiveStreamsConsumer
-
- ReactiveStreamsConsumer(MessageChannel, ReactiveMessageHandler) - Constructor for class org.springframework.integration.endpoint.ReactiveStreamsConsumer
-
- ReactiveStreamsSubscribableChannel - Interface in org.springframework.integration.channel
-
- ReactorNettyTcpStompSessionManager - Class in org.springframework.integration.stomp
-
- ReactorNettyTcpStompSessionManager(ReactorNettyTcpStompClient) - Constructor for class org.springframework.integration.stomp.ReactorNettyTcpStompSessionManager
-
- read(Kryo, Input, Class<File>) - Method in class org.springframework.integration.codec.kryo.FileSerializer
-
- read(String, OutputStream) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- read(String, OutputStream) - Method in interface org.springframework.integration.file.remote.session.Session
-
- read(String, OutputStream) - Method in class org.springframework.integration.ftp.session.FtpSession
-
- read(Message<?>) - Static method in class org.springframework.integration.history.MessageHistory
-
- read(Class<? extends MultiValueMap<String, ?>>, HttpInputMessage) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
-
- read(InputStream, byte[], boolean) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
Read data from the socket and puts the data in buffer.
- read(EvaluationContext, Object, String) - Method in class org.springframework.integration.json.JsonPropertyAccessor
-
- read(String, OutputStream) - Method in class org.springframework.integration.sftp.session.SftpSession
-
- READ_DELAY - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- READ_ONLY_HEADERS - Static variable in class org.springframework.integration.context.IntegrationProperties
-
- readDelay(long) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
-
- Reader(String) - Constructor for class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
-
- reader - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
-
- readFraction() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
-
- readHeader(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
Read the header and returns the length of the data part.
- readHeaders(P, String) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
-
- readHeaders(JsonInboundMessageMapper.JsonMessageParser<?>, String) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
-
- readInt() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
-
Read characters building an int until a non-digit is found
- readInternal(Class, HttpInputMessage) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
-
- readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.DefaultMultipartFileReader
-
- readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
-
- readMultipartFile(MultipartFile) - Method in interface org.springframework.integration.http.multipart.MultipartFileReader
-
- readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.SimpleMultipartFileReader
-
- readOnly(boolean) - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
-
- readOnlyHeaders(String...) - Method in class org.springframework.integration.support.MessageBuilder
-
Specify a list of headers which should be considered as read only
and prohibited from being populated in the message.
- readPacket() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
Invoked by the factory when there is data to be read.
- readPayload(P, String) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
-
- readPayload(JsonInboundMessageMapper.JsonMessageParser<?>, String) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
-
- readRaw(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- readRaw(String) - Method in interface org.springframework.integration.file.remote.session.Session
-
- readRaw(String) - Method in class org.springframework.integration.ftp.session.FtpSession
-
- readRaw(String) - Method in class org.springframework.integration.sftp.session.SftpSession
-
- rebuild() - Method in class org.springframework.integration.graph.IntegrationGraphServer
-
Rebuild the graph, re-cache it, and return it.
- RECEIPT - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
-
- RECEIPT_ID - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
-
- ReceiptEvent - Class in org.springframework.integration.websocket.event
-
The
AbstractSubProtocolEvent
implementation, which is emitted
for the WebSocket sub-protocol-specific
RECEIPT
frame on the client side.
- ReceiptEvent(Object, Message<byte[]>) - Constructor for class org.springframework.integration.websocket.event.ReceiptEvent
-
- receive() - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
-
- receive() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- receive(long) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- receive() - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
Receive the first available message from this channel.
- receive(long) - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
Receive the first available message from this channel.
- receive() - Method in class org.springframework.integration.channel.NullChannel
-
- receive(long) - Method in class org.springframework.integration.channel.NullChannel
-
- receive() - Method in interface org.springframework.integration.core.MessageSource
-
Retrieve the next available message from this source.
- receive(MessageChannel, long) - Method in class org.springframework.integration.core.MessagingTemplate
-
- receive() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
-
- receive() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- receive(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- receive() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- receive(long) - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- receive() - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- receive() - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
-
- receive(long) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
-
- receive() - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- receive() - Method in interface org.springframework.integration.mail.MailReceiver
-
- RECEIVE_COUNTER_NAME - Static variable in interface org.springframework.integration.support.management.IntegrationManagement
-
- receiveAndConvert(MessageChannel, long) - Method in class org.springframework.integration.core.MessagingTemplate
-
- receiveBufferSize(int) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
-
- receiveCounters(Supplier<ReceiveCounters>) - Method in class org.springframework.integration.graph.MessageSourceNode
-
- receiveCounters(Supplier<ReceiveCounters>) - Method in class org.springframework.integration.graph.PollableChannelNode
-
- ReceiveCounters - Class in org.springframework.integration.graph
-
Counters for components that maintain receive counters.
- ReceiveCounters(long, long) - Constructor for class org.springframework.integration.graph.ReceiveCounters
-
- receiveCounters(Supplier<ReceiveCounters>) - Method in interface org.springframework.integration.graph.ReceiveCountersAware
-
- ReceiveCountersAware - Interface in org.springframework.integration.graph
-
- RECEIVED_DATE - Static variable in class org.springframework.integration.mail.MailHeaders
-
- RECEIVED_QOS - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
-
- RECEIVED_RETAINED - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
-
- RECEIVED_TOPIC - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
-
- receivedQos(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
-
Return the received QOS header.
- receivedRetained(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
-
Return the received retained header.
- receivedTopic(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
-
Return the received topic header.
- receiveMessage() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
Obtain the next message (if one is available).
- receiveMessage() - Method in class org.springframework.integration.endpoint.PollingConsumer
-
- receiveMessage() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- receiveMessage() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- receiveMessage(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- ReceiveMessageAdvice - Interface in org.springframework.integration.aop
-
An AOP advice to perform hooks before and/or after a receive()
contract is called.
- receiver - Variable in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
- receiver - Variable in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
-
- receiveRaw(boolean) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
-
Whether raw
ZMsg
is present as a payload of message to produce or
it is fully converted to a
Message
including
ZeroMqHeaders.TOPIC
header (if any).
- receiveTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
- receiveTimeout(long) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-
- receiveTimeout(long) - Method in class org.springframework.integration.dsl.PollerSpec
-
Specify a timeout in milliseconds to wait for a message in the
MessageChannel
.
- receiveTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
A receive timeout.
- receiveTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
- receiveTimeout(Long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
-
- receiveTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
-
- receiveTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsTemplateSpec
-
- recipient(String) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a recipient channel that always will be selected.
- recipient(String, String) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a recipient channel that will be selected if the the expression evaluates to 'true'.
- recipient(String, Expression) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a recipient channel that will be selected if the the expression evaluates to 'true'.
- recipient(String, GenericSelector<P>) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a recipient channel that will be selected if the the selector's accept method returns 'true'.
- recipient(MessageChannel) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a recipient channel that always will be selected.
- recipient(MessageChannel, String) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a recipient channel that will be selected if the the expression evaluates to 'true'.
- recipient(MessageChannel, Expression) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a recipient channel that will be selected if the the expression evaluates to 'true'.
- recipient(MessageChannel, GenericSelector<P>) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a recipient channel that will be selected if the the selector's accept method returns 'true'.
- Recipient(MessageChannel) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
-
- Recipient(MessageChannel, MessageSelector) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
-
- Recipient(String) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
-
- Recipient(String, MessageSelector) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
-
- recipientFlow(GenericSelector<P>, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a subflow that will be invoked if the selector's accept methods returns 'true'.
- recipientFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a subflow that will be invoked as a recipient.
- recipientFlow(String, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a subflow that will be invoked if the expression evaluates to 'true'.
- recipientFlow(Expression, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a subflow that will be invoked if the expression evaluates to 'true'.
- RecipientListRouter - Class in org.springframework.integration.router
-
<recipient-list-router id="simpleRouter" input-channel="routingChannelA">
<recipient channel="channel1"/>
<recipient channel="channel2"/>
</recipient-list-router>
- RecipientListRouter() - Constructor for class org.springframework.integration.router.RecipientListRouter
-
- RecipientListRouter.Recipient - Class in org.springframework.integration.router
-
- RecipientListRouterManagement - Interface in org.springframework.integration.router
-
Exposes adding/removing individual recipients operations for
RecipientListRouter.
- RecipientListRouterParser - Class in org.springframework.integration.config.xml
-
Parser for the <recipient-list-router/> element.
- RecipientListRouterParser() - Constructor for class org.springframework.integration.config.xml.RecipientListRouterParser
-
- RecipientListRouterSpec - Class in org.springframework.integration.dsl
-
- RecipientListRouterSpec() - Constructor for class org.springframework.integration.dsl.RecipientListRouterSpec
-
- recipientMessageSelector(String, MessageSelector) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a recipient channel that will be selected if the the selector's accept method returns 'true'.
- recipientMessageSelector(MessageChannel, MessageSelector) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a recipient channel that will be selected if the the selector's accept method returns 'true'.
- recipientMessageSelectorFlow(MessageSelector, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
-
Adds a subflow that will be invoked if the selector's accept methods returns 'true'.
- record(long, TimeUnit) - Method in interface org.springframework.integration.support.management.metrics.TimerFacade
-
- record(long, TimeUnit) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimer
-
- recordFilterStrategy(RecordFilterStrategy<K, V>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
-
Specify a RecordFilterStrategy
to wrap
KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener
into
FilteringMessageListenerAdapter
.
- recordMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
-
Set the message converter to use with a record-based consumer.
- recover(RetryContext) - Method in class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
-
- recoverer - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
-
- recoveryBackOff(BackOff) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Specify the
BackOff
for interval between recovery attempts.
- recoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
Set a RecoveryCallback
when using retry within the adapter.
- recoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Set a RecoveryCallback
when using retry within the adapter.
- recoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
-
A RecoveryCallback
instance for retry operation;
if null, the exception will be thrown to the container after retries are exhausted.
- recoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
-
A RecoveryCallback
instance for retry operation;
if null, the exception will be thrown to the container after retries are exhausted.
- recoveryInterval(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
- recoveryInterval(long) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
- recoveryInterval(long) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
Specify a recovery interval.
- recoveryInterval(long) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
-
- recoveryInterval(Long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
-
- RecursiveDirectoryScanner - Class in org.springframework.integration.file
-
- RecursiveDirectoryScanner() - Constructor for class org.springframework.integration.file.RecursiveDirectoryScanner
-
- recursiveFindAnnotation(Class<? extends Annotation>, Annotation, List<Annotation>, Set<Annotation>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
-
- RedisChannelMessageStore - Class in org.springframework.integration.redis.store
-
- RedisChannelMessageStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.store.RedisChannelMessageStore
-
Construct a message store that uses Java Serialization for messages.
- RedisChannelParser - Class in org.springframework.integration.redis.config
-
Parser for the 'channel' and 'publish-subscribe-channel' elements of the
Spring Integration Redis namespace.
- RedisChannelParser() - Constructor for class org.springframework.integration.redis.config.RedisChannelParser
-
- RedisChannelPriorityMessageStore - Class in org.springframework.integration.redis.store
-
- RedisChannelPriorityMessageStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
-
- RedisExceptionEvent - Class in org.springframework.integration.redis.event
-
- RedisExceptionEvent(Object, Throwable) - Constructor for class org.springframework.integration.redis.event.RedisExceptionEvent
-
- RedisHeaders - Class in org.springframework.integration.redis.support
-
Pre-defined names and prefixes to be used for
for dealing with headers required by Redis components
- RedisInboundChannelAdapter - Class in org.springframework.integration.redis.inbound
-
- RedisInboundChannelAdapter(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- RedisInboundChannelAdapterParser - Class in org.springframework.integration.redis.config
-
- RedisInboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisInboundChannelAdapterParser
-
- RedisIntegrationEvent - Class in org.springframework.integration.redis.event
-
- RedisIntegrationEvent(Object) - Constructor for class org.springframework.integration.redis.event.RedisIntegrationEvent
-
- RedisIntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.redis.event.RedisIntegrationEvent
-
- RedisLockRegistry - Class in org.springframework.integration.redis.util
-
- RedisLockRegistry(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.util.RedisLockRegistry
-
Constructs a lock registry with the default (60 second) lock expiration.
- RedisLockRegistry(RedisConnectionFactory, String, long) - Constructor for class org.springframework.integration.redis.util.RedisLockRegistry
-
Constructs a lock registry with the supplied lock expiration.
- RedisMessageStore - Class in org.springframework.integration.redis.store
-
- RedisMessageStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.store.RedisMessageStore
-
- RedisMessageStore(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.store.RedisMessageStore
-
- RedisMetadataStore - Class in org.springframework.integration.redis.metadata
-
- RedisMetadataStore(RedisProperties) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
-
- RedisMetadataStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
-
- RedisMetadataStore(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
-
- RedisMetadataStore(RedisOperations<String, ?>) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
-
- RedisMetadataStore(RedisOperations<String, ?>, String) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
-
- RedisNamespaceHandler - Class in org.springframework.integration.redis.config
-
Namespace handler for Spring Integration's 'redis' namespace.
- RedisNamespaceHandler() - Constructor for class org.springframework.integration.redis.config.RedisNamespaceHandler
-
- RedisOutboundChannelAdapterParser - Class in org.springframework.integration.redis.config
-
Parser for the <outbound-channel-adapter/>
component.
- RedisOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisOutboundChannelAdapterParser
-
- RedisOutboundGateway - Class in org.springframework.integration.redis.outbound
-
The Gateway component implementation to perform Redis commands with provided arguments and to return command result.
- RedisOutboundGateway(RedisTemplate<?, ?>) - Constructor for class org.springframework.integration.redis.outbound.RedisOutboundGateway
-
- RedisOutboundGateway(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisOutboundGateway
-
- RedisOutboundGatewayParser - Class in org.springframework.integration.redis.config
-
Parser for the <int-redis:outbound-gateway/>
component.
- RedisOutboundGatewayParser() - Constructor for class org.springframework.integration.redis.config.RedisOutboundGatewayParser
-
- RedisPublishingMessageHandler - Class in org.springframework.integration.redis.outbound
-
- RedisPublishingMessageHandler(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- RedisQueueInboundChannelAdapterParser - Class in org.springframework.integration.redis.config
-
Parser for the <queue-inbound-channel-adapter> element of the 'redis' namespace.
- RedisQueueInboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueInboundChannelAdapterParser
-
- RedisQueueInboundGateway - Class in org.springframework.integration.redis.inbound
-
- RedisQueueInboundGateway(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- RedisQueueInboundGatewayParser - Class in org.springframework.integration.redis.config
-
Parser for the <queue-inbound-gateway> element of the 'redis' namespace.
- RedisQueueInboundGatewayParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueInboundGatewayParser
-
- RedisQueueMessageDrivenEndpoint - Class in org.springframework.integration.redis.inbound
-
- RedisQueueMessageDrivenEndpoint(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- RedisQueueOutboundChannelAdapter - Class in org.springframework.integration.redis.outbound
-
- RedisQueueOutboundChannelAdapter(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
- RedisQueueOutboundChannelAdapter(Expression, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
- RedisQueueOutboundChannelAdapterParser - Class in org.springframework.integration.redis.config
-
Parser for the <int-redis:queue-outbound-channel-adapter> element.
- RedisQueueOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueOutboundChannelAdapterParser
-
- RedisQueueOutboundGateway - Class in org.springframework.integration.redis.outbound
-
- RedisQueueOutboundGateway(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
-
- RedisQueueOutboundGatewayParser - Class in org.springframework.integration.redis.config
-
Parser for the <int-redis:queue-outbound-channel-adapter> element.
- RedisQueueOutboundGatewayParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueOutboundGatewayParser
-
- RedisStoreInboundChannelAdapterParser - Class in org.springframework.integration.redis.config
-
Parser for Redis store inbound adapters
- RedisStoreInboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisStoreInboundChannelAdapterParser
-
- RedisStoreMessageSource - Class in org.springframework.integration.redis.inbound
-
Inbound channel adapter which returns a Message representing a view into
a Redis store.
- RedisStoreMessageSource(RedisTemplate<String, ?>, Expression) - Constructor for class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
Creates an instance with the provided
RedisTemplate
and SpEL expression
which should resolve to a 'key' name of the collection to be used.
- RedisStoreMessageSource(RedisConnectionFactory, Expression) - Constructor for class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
Creates an instance with the provided
RedisConnectionFactory
and SpEL expression
which should resolve to a 'key' name of the collection to be used.
- RedisStoreOutboundChannelAdapterParser - Class in org.springframework.integration.redis.config
-
Parser for the <redis:store-outbound-channel-adapter> element.
- RedisStoreOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisStoreOutboundChannelAdapterParser
-
- RedisStoreWritingMessageHandler - Class in org.springframework.integration.redis.outbound
-
Implementation of
MessageHandler
which writes
Message data into a Redis store identified by a key
String
.
- RedisStoreWritingMessageHandler(RedisTemplate<String, ?>) - Constructor for class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
- RedisStoreWritingMessageHandler(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
- REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
-
- REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- REFRESH - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- REFRESH_CHECK_DELAY_ATTRIBUTE - Static variable in class org.springframework.integration.scripting.config.AbstractScriptParser
-
- RefreshableResourceScriptSource - Class in org.springframework.integration.scripting
-
- RefreshableResourceScriptSource(Resource, long) - Constructor for class org.springframework.integration.scripting.RefreshableResourceScriptSource
-
- refreshCheckDelay(long) - Method in class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
-
The refreshCheckDelay in milliseconds for refreshable script resource.
- refreshCheckDelay(long) - Method in class org.springframework.integration.scripting.dsl.ScriptSpec
-
The refreshCheckDelay in milliseconds for refreshable script resource.
- refreshGraph() - Method in class org.springframework.integration.http.management.IntegrationGraphController
-
- regexFileNameFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Specify a simple pattern to match remote files (e.g.
- regexFileNameFilter(String) - Method in class org.springframework.integration.ftp.dsl.FtpOutboundGatewaySpec
-
- regexFileNameFilter(String) - Method in class org.springframework.integration.sftp.dsl.SftpOutboundGatewaySpec
-
- regexFilter(String) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
-
- regexFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
-
Configure a regex pattern filter (e.g.
- regexFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
-
Configure a regex pattern filter (e.g.
- regexFilter(String) - Method in class org.springframework.integration.ftp.dsl.FtpInboundChannelAdapterSpec
-
Specify a regular expression to match remote files.
- regexFilter(String) - Method in class org.springframework.integration.ftp.dsl.FtpStreamingInboundChannelAdapterSpec
-
Specify a regular expression to match remote files (e.g.
- regexFilter(String) - Method in class org.springframework.integration.sftp.dsl.SftpInboundChannelAdapterSpec
-
- regexFilter(String) - Method in class org.springframework.integration.sftp.dsl.SftpStreamingInboundChannelAdapterSpec
-
Specify a regular expression to match remote files (e.g.
- regexMputFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
- RegexPatternFileListFilter - Class in org.springframework.integration.file.filters
-
Implementation of AbstractRegexPatternMatchingFileListFilter for java.io.File instances.
- RegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.RegexPatternFileListFilter
-
- RegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.file.filters.RegexPatternFileListFilter
-
- RegexTestXPathMessageSelector - Class in org.springframework.integration.xml.selector
-
XPath
MessageSelector
that tests if a
provided String value matches a given Regular Expression.
- RegexTestXPathMessageSelector(String, Map<String, String>, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
-
Creates a selector which attempts to match the given regex and supports multiple namespaces.
- RegexTestXPathMessageSelector(String, String, String, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
-
Creates a selector which attempts to match the given regex and supports a single namespace.
- RegexTestXPathMessageSelector(String, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
-
Creates a non-namespaced selector which attempts to match the given regex.
- RegexTestXPathMessageSelector(XPathExpression, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
-
Creates a selector which attempts to match the given regex against the evaluation result
of the provided
XPathExpression
.
- RegexUtils - Class in org.springframework.integration.ip.util
-
Regular Expression Utilities.
- register(S, Consumer<S>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- register() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
-
- register() - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
-
Register an
IntegrationFlow
and all the dependant and support components
in the application context and return an associated
IntegrationFlowRegistration
control object.
- registerBean(String, Object) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
-
- registerBeanDefinition(BeanDefinitionHolder, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
-
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.IntegrationComponentScanRegistrar
-
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.IntegrationRegistrar
-
Invoked by the framework when an @EnableIntegration annotation is encountered.
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.MessageHistoryRegistrar
-
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.MessagingGatewayRegistrar
-
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.PublisherRegistrar
-
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.http.config.IntegrationGraphControllerRegistrar
-
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptorRegistrar
-
- registerChannel(String, MessageChannel) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
-
- registerConverter(BeanDefinitionRegistry, BeanMetadataElement) - Method in class org.springframework.integration.config.IntegrationConverterInitializer
-
- registerEndpoint(String, Object) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
-
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Registers a TcpListener to receive messages after
the payload has been converted from the input data.
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
Delegate TCP Client Connection factories that are used to receive
data need a Listener to send the messages to.
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
Delegate TCP Client Connection factories that are used to receive
data need a Listener to send the messages to.
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
Set the listener that will receive incoming Messages.
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- registerMessageGroupExpiryCallback(MessageGroupStore.MessageGroupCallback) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
- registerMessageGroupExpiryCallback(MessageGroupStore.MessageGroupCallback) - Method in interface org.springframework.integration.store.MessageGroupStore
-
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.channel.NullChannel
-
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.channel.QueueChannel
-
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
-
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.handler.MessageHandlerSupport
-
- registerMetricsCaptor(MetricsCaptor) - Method in interface org.springframework.integration.support.management.IntegrationManagement
-
- registerOutputChannelIfCan(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- registerReplyMessageCorrelatorIfNecessary() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- registerScriptExecutorProviderIfNecessary(BeanDefinitionRegistry) - Method in class org.springframework.integration.groovy.config.GroovyIntegrationConfigurationInitializer
-
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Registers a TcpSender; for server sockets, used to
provide connection information so a sender can be used
to reply to incoming messages.
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
Registers a sender.
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- registerSenders(List<TcpSender>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
Registers the senders.
- registerSpelFunctionBean(BeanDefinitionRegistry, String, String, String) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
-
- registerTestListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
Set a temporary listener to receive just the first incoming message.
- registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
-
- registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.CompositeKryoRegistrar
-
- registerTypes(Kryo) - Method in interface org.springframework.integration.codec.kryo.KryoRegistrar
-
This method is invoked by the
PojoCodec
and
applied to the
Kryo
instance whenever a new instance is created.
- registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
- registerWebSocketHandlers(WebSocketHandlerRegistry) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
-
- registration(IntegrationFlow) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
-
- registration(IntegrationFlow) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
-
- RegistrationIds - Class in org.springframework.integration.codec.kryo
-
Default registration ids for serializers provided by the framework.
- reject(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
-
REJECT the associated message if the callback is not null.
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.springframework.integration.util.CallerBlocksPolicy
-
- RELATIVE_PATH - Static variable in class org.springframework.integration.file.FileHeaders
-
- release() - Method in class org.springframework.integration.util.UpperBound
-
Releases one lock on the underlying semaphore.
- release(int) - Method in class org.springframework.integration.util.UpperBound
-
Releases several locks on the underlying semaphore.
- releaseConnection() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- releaseExpression(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
-
- releaseItem(T) - Method in interface org.springframework.integration.util.Pool
-
Releases an item back into the pool.
- releaseItem(T) - Method in class org.springframework.integration.util.SimplePool
-
Returns an item to the pool.
- releasePartialSequences(boolean) - Method in class org.springframework.integration.dsl.ResequencerSpec
-
- ReleaseStrategy - Interface in org.springframework.integration.aggregator
-
Strategy for determining when a group of messages reaches a state of
completion (i.e.
- ReleaseStrategy - Annotation Type in org.springframework.integration.annotation
-
Indicates that a method is capable of asserting if a list of messages or
payload objects is complete.
- releaseStrategy(Object, String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
-
- releaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
-
- ReleaseStrategyFactoryBean - Class in org.springframework.integration.config
-
- ReleaseStrategyFactoryBean() - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
-
- ReloadableResourceBundleExpressionSource - Class in org.springframework.integration.expression
-
ExpressionSource
implementation that accesses resource bundles using specified basenames.
- ReloadableResourceBundleExpressionSource() - Constructor for class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
- REMAINING_RECORDS - Static variable in class org.springframework.integration.kafka.inbound.KafkaMessageSource
-
The number of records remaining from the previous poll.
- remainingCapacity() - Method in class org.springframework.integration.store.MessageGroupQueue
-
- REMOTE_DIRECTORY - Static variable in class org.springframework.integration.file.FileHeaders
-
- REMOTE_FILE - Static variable in class org.springframework.integration.file.FileHeaders
-
- REMOTE_FILE_INFO - Static variable in class org.springframework.integration.file.FileHeaders
-
A remote file information representation
- REMOTE_HOST_PORT - Static variable in class org.springframework.integration.file.FileHeaders
-
A remote host/port the file has been polled from
- REMOTE_PORT - Static variable in class org.springframework.integration.ip.IpHeaders
-
The remote port from which a TCP message was received.
- REMOTE_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- REMOTE_TIMEOUT_EXPRESSION - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- remoteComparator(Comparator<F>) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
-
Set a comparator to sort the retrieved list of F
(the Type that represents
the remote file) prior to applying filters and max fetch size.
- remoteDirectory(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
-
Specify a remote directory path.
- remoteDirectory(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
-
Specify a remote directory path
Function
.
- remoteDirectory(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
-
Specify the full path to the remote directory.
- remoteDirectory(String) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
-
Specify the full path to the remote directory.
- remoteDirectory(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
-
Specify an expression that evaluates to the full path to the remote directory.
- remoteDirectory(Function<Message<?>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
-
Specify a function that is invoked to determine the full path to the remote directory.
- remoteDirectoryExpression(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
-
Specify a remote directory path SpEL expression.
- remoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
-
Specify an expression that evaluates to the full path to the remote directory.
- remoteDirectoryExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Set the remote directory expression used to determine the remote directory to which
files will be sent.
- remoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Set the remote directory expression used to determine the remote directory to which
files will be sent.
- remoteDirectoryFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Specify a
Function
for remote directory.
- RemoteFileInboundChannelAdapterSpec<F,S extends RemoteFileInboundChannelAdapterSpec<F,S,MS>,MS extends AbstractInboundFileSynchronizingMessageSource<F>> - Class in org.springframework.integration.file.dsl
-
- RemoteFileInboundChannelAdapterSpec(AbstractInboundFileSynchronizer<F>) - Constructor for class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
-
- remoteFileMetadataStore(MetadataStore) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
-
- RemoteFileOperations<F> - Interface in org.springframework.integration.file.remote
-
Strategy for performing operations on remote files.
- RemoteFileOperations.OperationsCallback<F,T> - Interface in org.springframework.integration.file.remote
-
Callback for using the same session for multiple
RemoteFileTemplate operations.
- RemoteFileOutboundChannelAdapterParser - Class in org.springframework.integration.file.config
-
- RemoteFileOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.RemoteFileOutboundChannelAdapterParser
-
- RemoteFileOutboundGatewaySpec<F,S extends RemoteFileOutboundGatewaySpec<F,S>> - Class in org.springframework.integration.file.dsl
-
- RemoteFileOutboundGatewaySpec(AbstractRemoteFileOutboundGateway<F>) - Constructor for class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
- remoteFileSeparator(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
-
Specify a remote file separator symbol.
- remoteFileSeparator(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
-
Configure the file name path separator used by the remote system.
- remoteFileSeparator(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Set the file separator when dealing with remote files; default '/'.
- remoteFileSeparator(String) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
-
Configure the file name path separator used by the remote system.
- RemoteFileStreamingInboundChannelAdapterSpec<F,S extends RemoteFileStreamingInboundChannelAdapterSpec<F,S,MS>,MS extends AbstractRemoteFileStreamingMessageSource<F>> - Class in org.springframework.integration.file.dsl
-
- RemoteFileStreamingInboundChannelAdapterSpec() - Constructor for class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
-
- remoteFileTemplate - Variable in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
- RemoteFileTemplate<F> - Class in org.springframework.integration.file.remote
-
A general abstraction for dealing with remote files.
- RemoteFileTemplate(SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.RemoteFileTemplate
-
- remoteFileTemplateExplicitlySet(boolean) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- RemoteFileUtils - Class in org.springframework.integration.file.remote
-
Utility methods for supporting remote file operations.
- remotePath(AbstractFileInfo<F>) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
- remoteTimeout(long) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
-
- remoteTimeout(Function<Message<P>, ?>) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
-
Configure a
Function
that will be invoked at runtime to determine the destination to
which a message will be sent.
- remove(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- remove(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
-
- remove(int) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
-
- remove(String) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
-
Destroy an
IntegrationFlow
bean (as well as all its dependant beans)
for provided
flowId
and clean up all the local cache for it.
- remove(String) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
-
Destroy an
IntegrationFlow
bean (as well as all its dependant beans)
for provided
flowId
and clean up all the local cache for it.
- remove(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
-
- remove(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
-
- remove(F) - Method in class org.springframework.integration.file.filters.AcceptOnceFileListFilter
-
- remove(F) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
-
- remove(F) - Method in interface org.springframework.integration.file.filters.ResettableFileListFilter
-
Remove the specified file from the filter so it will pass on the next attempt.
- remove(String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Remove a remote file.
- remove(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- remove(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- remove(String) - Method in interface org.springframework.integration.file.remote.session.Session
-
- remove(String) - Method in class org.springframework.integration.ftp.session.FtpSession
-
- remove(String) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
-
- remove(int) - Method in class org.springframework.integration.history.MessageHistory
-
- remove(Object) - Method in class org.springframework.integration.history.MessageHistory
-
- remove(String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
-
- remove(String) - Method in interface org.springframework.integration.metadata.MetadataStore
-
Remove a value for the given key from this MetadataStore.
- remove(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
-
- remove(String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
-
- remove(String) - Method in class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
-
Remove the metadata entry for the provided key
and return its value
, if any,
using findAndRemove
MongoDB operation.
- remove(String) - Method in class org.springframework.integration.redis.metadata.RedisMetadataStore
-
- remove(String) - Method in class org.springframework.integration.sftp.session.SftpSession
-
- remove(Message<?>) - Method in interface org.springframework.integration.store.MessageGroup
-
Remove the message from this group.
- remove(UUID) - Method in class org.springframework.integration.store.MessageGroupMetadata
-
- remove(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- remove() - Method in interface org.springframework.integration.support.management.metrics.MeterFacade
-
Remove this meter facade.
- remove() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.AbstractMeter
-
- remove(Object) - Method in class org.springframework.integration.support.MutableMessageHeaders
-
- remove(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
-
- removeAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
-
- removeAll(Collection<UUID>) - Method in class org.springframework.integration.store.MessageGroupMetadata
-
- removeAllIdleItems() - Method in interface org.springframework.integration.util.Pool
-
Removes all idle items from the pool.
- removeAllIdleItems() - Method in class org.springframework.integration.util.SimplePool
-
- removeChannelMapping(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Remove a channel mapping for the given key if present.
- removeChannelMapping(String) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
-
- removeChannelMapping(String) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
-
Remove a channel mapping for the given key if present.
- removed(ServerSession, Path, boolean, Throwable) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
-
- removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- removeDeadConnection(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 connection is closed.
- removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- removeDestination(String...) - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
-
Remove a destination (or destinations) from the subscribed list and unsubscribe it.
- removedFromPool(T) - Method in interface org.springframework.integration.util.SimplePool.PoolItemCallback
-
Called by the pool when an item is forcibly removed from the pool - for example
when the pool size is reduced.
- removeFromIdCache(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Remove a Message Id from the idCache.
- removeHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
-
Remove the handler from the internal handler Set.
- removeHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
-
Remove a message handler.
- removeHeader(String) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
Remove the value for the given header name.
- removeHeader(String) - Method in class org.springframework.integration.support.MessageBuilder
-
Remove the value for the given header name.
- removeHeader(String) - Method in class org.springframework.integration.support.MutableMessageBuilder
-
- removeHeaders(String...) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
Removes all headers provided via array of 'headerPatterns'.
- removeHeaders(String...) - Method in class org.springframework.integration.support.MessageBuilder
-
Removes all headers provided via array of 'headerPatterns'.
- removeHeaders(String...) - Method in class org.springframework.integration.support.MutableMessageBuilder
-
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- removeInterceptor(int) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
-
- removeInterceptor(int) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
-
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
- removeInterceptor(int) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
- removeInterceptor(int) - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- removeInterceptor(int) - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
-
- removeInterceptor(int) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
-
- removeLifecycle(SmartLifecycle) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
Remove the provided SmartLifecycle from all the roles,
for example when a SmartLifecycle bean is destroyed.
- removeListener(MetadataStoreListener) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
-
- removeListener(MetadataStoreListener) - Method in interface org.springframework.integration.metadata.ListenableMetadataStore
-
Unregisters a listener
- removeListener(MetadataStoreListener) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
-
- removeMessage(UUID) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
- removeMessage(UUID) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- removeMessage(UUID) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- removeMessage(UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- removeMessage(UUID) - Method in interface org.springframework.integration.store.MessageStore
-
Remove the Message with the given id from the MessageStore, if present, and return it.
- removeMessage(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- removeMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
- removeMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
- removeMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- removeMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- removeMessageGroup(Object) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
-
- removeMessageGroup(Object) - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
-
- removeMessageGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
Remove the MessageGroup with the provided group ID.
- removeMessageGroup(Object) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
-
Remove the message group with this id.
- removeMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- removeMessagesFromGroup(Object, Message<?>...) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in interface org.springframework.integration.store.MessageGroupStore
-
Persist the deletion of messages from the group.
- removeMessagesFromGroup(Object, Message<?>...) - Method in interface org.springframework.integration.store.MessageGroupStore
-
Persist the deletion of messages from the group.
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- removeMeter(MeterFacade) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor
-
Remove a meter facade.
- removeMeter(MeterFacade) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
-
- removeRecipient(String) - Method in class org.springframework.integration.router.RecipientListRouter
-
- removeRecipient(String, String) - Method in class org.springframework.integration.router.RecipientListRouter
-
- removeRecipient(String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
-
Remove all recipients that match the channelName.
- removeRecipient(String, String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
-
Remove all recipients that match the channelName and expression.
- removeRemoteFileMetadata(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Remove a metadata for remote file associated with the provided local file.
- removeSessionFactory(Object) - Method in class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
-
Remove a session factory.
- removeTopic(String...) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
-
Remove a topic (or topics) from the subscribed list.
- removeTopic(String...) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
- rename(String, String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Rename a remote file, creating directories if needed.
- rename(String, String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- rename(String, String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- rename(String, String) - Method in interface org.springframework.integration.file.remote.session.Session
-
- rename(String, String) - Method in class org.springframework.integration.ftp.session.FtpSession
-
- rename(String, String) - Method in class org.springframework.integration.sftp.session.SftpSession
-
- RENAME_TO - Static variable in class org.springframework.integration.file.FileHeaders
-
- renameExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Specify a SpEL expression for files renaming during transfer.
- renameExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Specify a SpEL expression for files renaming during transfer.
- renameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Specify a
Function
for files renaming during transfer.
- rendezvous() - Method in class org.springframework.integration.dsl.Channels
-
- rendezvous(String) - Method in class org.springframework.integration.dsl.Channels
-
- rendezvous() - Static method in class org.springframework.integration.dsl.MessageChannels
-
- rendezvous(String) - Static method in class org.springframework.integration.dsl.MessageChannels
-
- RendezvousChannel - Class in org.springframework.integration.channel
-
- RendezvousChannel() - Constructor for class org.springframework.integration.channel.RendezvousChannel
-
- RendezvousChannelSpec - Class in org.springframework.integration.dsl
-
- RendezvousChannelSpec() - Constructor for class org.springframework.integration.dsl.RendezvousChannelSpec
-
- renew(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
- renew(String) - Method in interface org.springframework.integration.jdbc.lock.LockRepository
-
- RenewableLockRegistry - Interface in org.springframework.integration.support.locks
-
A
LockRegistry
implementing this interface supports the renewal
of the time to live of a lock.
- renewLock(Object) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
-
- renewLock(Object) - Method in interface org.springframework.integration.support.locks.RenewableLockRegistry
-
Renew the time to live of the lock is associated with the parameter object.
- reopen(boolean) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
-
If true
, close and reopen the file between reading chunks.
- replace(String, String, String) - Method in class org.springframework.integration.gemfire.metadata.GemfireMetadataStore
-
- replace(String, String, String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
-
- replace(String, String, String) - Method in interface org.springframework.integration.metadata.ConcurrentMetadataStore
-
Atomically replace the value for the key in the store if the old
value matches the oldValue argument.
- replace(String, String, String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
-
- replace(String, String, String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
-
- replace(String, String, String) - Method in class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
-
Replace an existing metadata entry value
with a new one.
- replace(String, String, String) - Method in class org.springframework.integration.redis.metadata.RedisMetadataStore
-
- replace(String, String, String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
-
- replaceChannelMappings(Properties) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Convenience method allowing conversion of a list
of mappings in a control-bus message.
- replaceChannelMappings(Properties) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
-
- replaceChannelMappings(Properties) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
-
Provide mappings from channel keys to channel names.
- replaceRecipients(Properties) - Method in class org.springframework.integration.router.RecipientListRouter
-
- replaceRecipients(Properties) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
-
Replace recipient.
- REPLY_CHANNEL - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- REPLY_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- REPLY_TO - Static variable in class org.springframework.integration.mail.MailHeaders
-
- replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.EnricherSpec
-
- replyChannel(String) - Method in class org.springframework.integration.dsl.EnricherSpec
-
- replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
-
Set a reply channel.
- replyChannel(String) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
-
Set a reply channel.
- replyChannel(String) - Method in class org.springframework.integration.dsl.GatewayProxySpec
-
Identifies the default channel the gateway proxy will subscribe to, to receive reply
Message
s, the payloads of
which will be converted to the return type of the method signature.
- replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.GatewayProxySpec
-
Identifies the default channel the gateway proxy will subscribe to, to receive reply
Message
s, the payloads of
which will be converted to the return type of the method signature.
- replyChannel(Object) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- replyChannel(Object, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
-
A reply channel to use.
- replyChannel(String) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
-
A reply channel name to use.
- replyChannelExpression(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- replyChannelExpression(String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- replyChannelFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- replyChannelFunction(Function<Message<P>, ?>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- replyChannelInChainAllowed(Element) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
-
Override to allow 'reply-channel' within a chain, for components where it
makes sense (e.g.
- replyChannelInChainAllowed(Element) - Method in class org.springframework.integration.config.xml.EnricherParser
-
- replyContainer() - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
Configure a reply container with default properties.
- replyContainer(Consumer<JmsOutboundGatewaySpec.ReplyContainerSpec>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
- ReplyContainerProperties() - Constructor for class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- replyDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
-
- replyDestination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
- replyDestination(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
- replyDestination(Function<Message<P>, ?>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
Configure a
Function
that will be invoked at run time to determine the destination from
which a reply will be received.
- replyDestinationExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
- replyHeadersMappedLast(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
When mapping headers for the outbound (reply) message, determine whether the headers are
mapped before the message is converted, or afterwards.
- replyKey(String) - Method in class org.springframework.integration.http.dsl.HttpControllerEndpointSpec
-
- replyMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
-
- replyMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec
-
Set a message converter for replies (when a gateway).
- replyPayloadToFlux(boolean) - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
-
The boolean flag to identify if the reply payload should be as a
Flux
from the response body
or as resolved value from the Mono
of the response body.
- replyPriority(int) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
-
- ReplyProducingMessageHandlerWrapper - Class in org.springframework.integration.handler
-
- ReplyProducingMessageHandlerWrapper(MessageHandler) - Constructor for class org.springframework.integration.handler.ReplyProducingMessageHandlerWrapper
-
- replyPubSubDomain(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
- ReplyRequiredException - Exception in org.springframework.integration.handler
-
Exception that indicates no reply message is produced by a handler
that does have a value of true for the 'requiresReply' property.
- ReplyRequiredException(Message<?>, String) - Constructor for exception org.springframework.integration.handler.ReplyRequiredException
-
- ReplyRequiredException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.handler.ReplyRequiredException
-
- replyTimeout(Long) - Method in class org.springframework.integration.dsl.EnricherSpec
-
- replyTimeout(Long) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
-
Set a reply timeout.
- replyTimeout(long) - Method in class org.springframework.integration.dsl.GatewayProxySpec
-
Allows to specify how long this gateway will wait for the reply Message
before returning.
- replyTimeout(long) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
-
A reply timeout to use.
- replyTimeToLive(long) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
-
- replyTo(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the ReplyTo: address.
- replyToExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the expression that will be evaluated to determine the ReplyTo: address.
- replyToFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set a function that will be invoked to determine the ReplyTo: address based on the
message.
- request - Variable in class org.springframework.integration.ftp.server.FtpRequestEvent
-
- REQUEST_HANDLER_ADVICE_CHAIN - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- REQUEST_METHOD - Static variable in class org.springframework.integration.http.HttpHeaders
-
- REQUEST_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- REQUEST_URL - Static variable in class org.springframework.integration.http.HttpHeaders
-
- requestCallback(WebServiceMessageCallback) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
-
- requestChannel(MessageChannel) - Method in class org.springframework.integration.dsl.EnricherSpec
-
- requestChannel(String) - Method in class org.springframework.integration.dsl.EnricherSpec
-
- requestChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
-
A request channel to use.
- requestChannel(String) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
-
A request channel name to use.
- requestDestination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
- requestDestination(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
- requestDestination(Function<Message<P>, ?>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
Configure a
Function
that will be invoked at runtime to determine the destination to
which a message will be sent.
- requestDestinationExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
- requestedContentTypeResolver(RequestedContentTypeResolver) - Method in class org.springframework.integration.webflux.dsl.WebFluxInboundEndpointSpec
-
- requestElementType(ResolvableType) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
-
Specify a type of payload to be generated when the inbound RSocket request
content is read by the converters/encoders.
- requestFactory(ClientHttpRequestFactory) - Method in class org.springframework.integration.http.dsl.HttpMessageHandlerSpec
-
- RequestHandlerCircuitBreakerAdvice - Class in org.springframework.integration.handler.advice
-
A circuit breaker that stops calling a failing service after threshold
failures, until halfOpenAfter milliseconds has elapsed.
- RequestHandlerCircuitBreakerAdvice() - Constructor for class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
-
- RequestHandlerCircuitBreakerAdvice.CircuitBreakerOpenException - Exception in org.springframework.integration.handler.advice
-
An exception thrown when the circuit breaker is in an open state.
- RequestHandlerRetryAdvice - Class in org.springframework.integration.handler.advice
-
Uses spring-retry to perform stateless or stateful retry.
- RequestHandlerRetryAdvice() - Constructor for class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- requestMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
-
- requestMapping - Variable in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
-
- requestMapping(Consumer<HttpInboundEndpointSupportSpec.RequestMappingSpec>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
-
- RequestMapping - Class in org.springframework.integration.http.inbound
-
- RequestMapping() - Constructor for class org.springframework.integration.http.inbound.RequestMapping
-
- RequestMessageCallback(WebServiceMessageCallback, Message<?>) - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.RequestMessageCallback
-
- requestPayload(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.EnricherSpec
-
- requestPayloadExpression(String) - Method in class org.springframework.integration.dsl.EnricherSpec
-
- requestPayloadType(Class<?>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
-
Specify the type of payload to be generated when the inbound HTTP request content is read by the
HttpMessageConverter
s.
- requestPayloadType(ResolvableType) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
-
Specify the type of payload to be generated when the inbound HTTP request content is read by the
HttpMessageConverter
s.
- requestPubSubDomain(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
-
- RequestReplyExchanger - Interface in org.springframework.integration.gateway
-
Interface for a request/reply Message exchange.
- RequestReplyHeaderMapper<T> - Interface in org.springframework.integration.mapping
-
Request/Reply strategy interface for mapping
MessageHeaders
to and from other
types of objects.
- RequestResponseScenario - Class in org.springframework.integration.test.support
-
Defines a Spring Integration request response test scenario.
- RequestResponseScenario(String, String) - Constructor for class org.springframework.integration.test.support.RequestResponseScenario
-
Create an instance
- requestSubFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.EnricherSpec
-
The request sub-flow.
- requestTimeout(Long) - Method in class org.springframework.integration.dsl.EnricherSpec
-
- requestTimeout(Long) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
-
Set a request timeout.
- requestTimeout(long) - Method in class org.springframework.integration.dsl.GatewayProxySpec
-
Provides the amount of time dispatcher would wait to send a Message
.
- requestTimeout(long) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
-
A request timeout to use.
- requeue(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
-
REQUEUE the associated message if the callback is not null.
- requiresDestruction(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition.ReplyProducerCleaner
-
- requiresDestruction(Object) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
- requiresDestruction(Object) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
-
- requiresDestruction(Object) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- requiresDestruction(Object) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
-
- requiresReply(boolean) - Method in class org.springframework.integration.dsl.BarrierSpec
-
- requiresReply(boolean) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
-
- rescheduleAt(Message<?>, Date) - Method in class org.springframework.integration.handler.DelayHandler
-
- reschedulePersistedMessages() - Method in class org.springframework.integration.handler.DelayHandler
-
Used for reading persisted Messages in the 'messageStore' to reschedule them e.g.
- reschedulePersistedMessages() - Method in interface org.springframework.integration.handler.DelayHandlerManagement
-
- resequence() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- resequence(Consumer<ResequencerSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- ResequencerParser - Class in org.springframework.integration.config.xml
-
Parser for the <resequencer> element.
- ResequencerParser() - Constructor for class org.springframework.integration.config.xml.ResequencerParser
-
- ResequencerSpec - Class in org.springframework.integration.dsl
-
- ResequencerSpec() - Constructor for class org.springframework.integration.dsl.ResequencerSpec
-
- ResequencingMessageGroupProcessor - Class in org.springframework.integration.aggregator
-
This class implements all the strategy interfaces needed for a default resequencer.
- ResequencingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.ResequencingMessageGroupProcessor
-
- ResequencingMessageHandler - Class in org.springframework.integration.aggregator
-
- ResequencingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
-
- ResequencingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
-
- ResequencingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
-
- reset() - Method in class org.springframework.integration.scheduling.SimplePollSkipStrategy
-
Resume polling at the next Trigger
event.
- reset() - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
-
- reset() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
-
- resetBeans(String...) - Method in class org.springframework.integration.test.context.MockIntegrationContext
-
Reinstate the mocked beans after execution test to their real state.
- resetCache() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
-
Clear the cache of sessions; also any in-use sessions will be closed when
returned to the cache.
- resetServer() - Method in class org.springframework.integration.test.mail.TestMailServer.ImapServer
-
- resetServer() - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
-
- resetSharedSession() - Method in interface org.springframework.integration.file.remote.session.SharedSessionCapable
-
Resets the shared session so the next #getSession()
will return a session
using a new connection.
- resetSharedSession() - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
- ResettableFileListFilter<F> - Interface in org.springframework.integration.file.filters
-
A
FileListFilter
that can be reset by removing a specific file from its
state.
- resolutionRequired(boolean) - Method in class org.springframework.integration.dsl.RouterSpec
-
- RESOLVABLE_TYPE - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
-
The header to represent a
ResolvableType
for the target deserialized object.
- resolve(String, Message<?>) - Method in interface org.springframework.integration.redis.outbound.ArgumentsStrategy
-
- resolve(String, Message<?>) - Method in class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
-
- resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.CollectionArgumentResolver
-
- resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.MapArgumentResolver
-
- resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.PayloadExpressionArgumentResolver
-
- resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.PayloadsArgumentResolver
-
- resolveAttribute(List<Annotation>, String, Class<T>) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
-
Get the attribute value from the annotation hierarchy, returning the first non-empty
value closest to the annotated method.
- resolveAttributeToBoolean(String) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- resolveDestination(String) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
-
- resolveErrorChannel(MessageHeaders) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
- resolveHttpStatusFromHeaders(MessageHeaders) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.ChainParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalWireTapParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.IntegrationManagementParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.PollerParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
-
- resolvePrimitiveType(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
-
Resolve the given class if it is a primitive wrapper class,
returning the corresponding primitive type instead.
- resolveSessionId(Message<?>) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
-
- resolveSessionId(Message<?>) - Method in class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
-
- resolveTargetBeanFromMethodWithBeanAnnotation(Method) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- resolveTargetBeanFromMethodWithBeanAnnotation(Method) - Method in class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
-
- resolveTargetBeanName(Method) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- resourceHolder - Variable in class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
-
- ResourceInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
-
Parser for 'resource-inbound-channel-adapter'
- ResourceInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.ResourceInboundChannelAdapterParser
-
- ResourceRetrievingMessageSource - Class in org.springframework.integration.resource
-
- ResourceRetrievingMessageSource(String) - Constructor for class org.springframework.integration.resource.ResourceRetrievingMessageSource
-
- ResponseMessageExtractor() - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.ResponseMessageExtractor
-
- rest() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
-
- restartAckThread() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
If exposed as an MBean, can be used to restart the ack thread if a fatal
(bind) error occurred, without bouncing the JVM.
- ResultFactory - Interface in org.springframework.integration.xml.result
-
Factory to create a
Result
possibly taking into account the
provided message payload instance.
- ResultToDocumentTransformer - Class in org.springframework.integration.xml.transformer
-
- ResultToDocumentTransformer() - Constructor for class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
-
- ResultToDocumentTransformer(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
-
- ResultToStringTransformer - Class in org.springframework.integration.xml.transformer
-
- ResultToStringTransformer() - Constructor for class org.springframework.integration.xml.transformer.ResultToStringTransformer
-
- ResultToStringTransformer(TransformerFactory) - Constructor for class org.springframework.integration.xml.transformer.ResultToStringTransformer
-
- ResultTransformer - Interface in org.springframework.integration.xml.transformer
-
Implementations of this class allow for the transformation of
Result
objects to other formats.
- resume() - Method in interface org.springframework.integration.core.Pausable
-
Resume the endpoint if paused.
- resume() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
-
- resume() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
- resume() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
-
- retainAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
-
- RETAINED - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
-
- retainOriginal - Variable in class org.springframework.integration.syslog.RFC5424SyslogParser
-
- retrieveMBeanNames() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
- retrievingGateway(EntityManagerFactory) - Static method in class org.springframework.integration.jpa.dsl.Jpa
-
- retrievingGateway(EntityManager) - Static method in class org.springframework.integration.jpa.dsl.Jpa
-
- retrievingGateway(JpaOperations) - Static method in class org.springframework.integration.jpa.dsl.Jpa
-
- RetrievingJpaOutboundGatewayParser - Class in org.springframework.integration.jpa.config.xml
-
The Parser for the Retrieving Jpa Outbound Gateway.
- RetrievingJpaOutboundGatewayParser() - Constructor for class org.springframework.integration.jpa.config.xml.RetrievingJpaOutboundGatewayParser
-
- RETRY_INTERVAL - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- RetryAdviceParser - Class in org.springframework.integration.config.xml
-
- RetryAdviceParser() - Constructor for class org.springframework.integration.config.xml.RetryAdviceParser
-
- retryConnection() - Method in interface org.springframework.integration.ip.tcp.connection.ClientModeCapable
-
Immediately attempt to establish the connection.
- retryConnection() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- retryConnection() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- retryConnection() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- retryDelay(long) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
-
Set an additional delay to apply when retrying after a release failure.
- RetryExceptionNotAvailableException(Message<?>, String) - Constructor for exception org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer.RetryExceptionNotAvailableException
-
- retryInterval(long) - Method in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
-
- retryInterval(long) - Method in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
-
- retryInterval(long) - Method in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
-
- retryOps - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
-
- RetryStateGenerator - Interface in org.springframework.integration.handler.advice
-
Strategy interface for generating a RetryState
instance
based on a message.
- retryTemplate(RetryTemplate) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
-
Set a RetryTemplate
to use for retrying a message delivery within the
adapter.
- retryTemplate(RetryTemplate) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Set a RetryTemplate
to use for retrying a message delivery within the
adapter.
- retryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
-
Specify a RetryTemplate
instance to wrap
KafkaInboundGateway.IntegrationRecordMessageListener
into
RetryingMessageListenerAdapter
.
- retryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
-
Specify a RetryTemplate
instance to wrap
KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener
into
RetryingMessageListenerAdapter
.
- returnChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the channel to which returned messages are sent.
- ReturnedAmqpMessageException - Exception in org.springframework.integration.amqp.support
-
A MessagingException for a returned message.
- ReturnedAmqpMessageException(Message<?>, Message, int, String, String, String) - Constructor for exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
-
- returnedMessage(ReturnedMessage) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- ReversibleFileListFilter<F> - Interface in org.springframework.integration.file.filters
-
A
FileListFilter
that allows the caller to reverse (roll back) state
changes.
- revertLogLevels(String, TestUtils.LevelsContainer) - Static method in class org.springframework.integration.test.util.TestUtils
-
- RFC5424MessageConverter - Class in org.springframework.integration.syslog
-
- RFC5424MessageConverter() - Constructor for class org.springframework.integration.syslog.RFC5424MessageConverter
-
- RFC5424MessageConverter(RFC5424SyslogParser) - Constructor for class org.springframework.integration.syslog.RFC5424MessageConverter
-
Construct an instance with a non-standard parser.
- RFC5424SyslogParser - Class in org.springframework.integration.syslog
-
Parse for RFC 5424 syslog messages; when used with TCP, requires the use
of a RFC6587SyslogDeserializer
which decodes the framing.
- RFC5424SyslogParser() - Constructor for class org.springframework.integration.syslog.RFC5424SyslogParser
-
Construct a default parser; do not retain the original message content unless there
is an error.
- RFC5424SyslogParser(boolean) - Constructor for class org.springframework.integration.syslog.RFC5424SyslogParser
-
- RFC5424SyslogParser.Reader - Class in org.springframework.integration.syslog
-
- RFC5424SyslogParser.Severity - Enum in org.springframework.integration.syslog
-
- RFC6587SyslogDeserializer - Class in org.springframework.integration.syslog.inbound
-
RFC5424/6587 Deserializer.
- RFC6587SyslogDeserializer() - Constructor for class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
-
- RFC6587SyslogDeserializer(Deserializer<byte[]>) - Constructor for class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
-
Construct an instance using the specified
Deserializer
for
non-transparent frames.
- rm(Message<?>, Session<F>, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Perform remote delete for the provided path.
- rm(Message<?>, Session<FTPFile>, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
-
- rmdir(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- rmdir(String) - Method in interface org.springframework.integration.file.remote.session.Session
-
Remove a remote directory.
- rmdir(String) - Method in class org.springframework.integration.ftp.session.FtpSession
-
- rmdir(String) - Method in class org.springframework.integration.sftp.session.SftpSession
-
- RmiInboundGateway - Class in org.springframework.integration.rmi
-
- RmiInboundGateway() - Constructor for class org.springframework.integration.rmi.RmiInboundGateway
-
Deprecated.
- RmiInboundGatewayParser - Class in org.springframework.integration.rmi.config
-
- RmiInboundGatewayParser() - Constructor for class org.springframework.integration.rmi.config.RmiInboundGatewayParser
-
Deprecated.
- RmiNamespaceHandler - Class in org.springframework.integration.rmi.config
-
- RmiNamespaceHandler() - Constructor for class org.springframework.integration.rmi.config.RmiNamespaceHandler
-
Deprecated.
- RmiOutboundGateway - Class in org.springframework.integration.rmi
-
- RmiOutboundGateway(String) - Constructor for class org.springframework.integration.rmi.RmiOutboundGateway
-
Deprecated.
Construct an instance with a `RequestReplyExchanger` built from the
default
RmiProxyFactoryBean
.
- RmiOutboundGateway(String, RmiOutboundGateway.RmiProxyFactoryBeanConfigurer) - Constructor for class org.springframework.integration.rmi.RmiOutboundGateway
-
Deprecated.
Construct an instance with a `RequestReplyExchanger` built from the
default
RmiProxyFactoryBean
which can be modified by the
configurer.
- RmiOutboundGateway.RmiProxyFactoryBeanConfigurer - Interface in org.springframework.integration.rmi
-
Deprecated.
Allows configuration of the proxy factory bean before the RMI proxy is created.
- RmiOutboundGatewayParser - Class in org.springframework.integration.rmi.config
-
- RmiOutboundGatewayParser() - Constructor for class org.springframework.integration.rmi.config.RmiOutboundGatewayParser
-
Deprecated.
- Role - Annotation Type in org.springframework.integration.annotation
-
Annotate endpoints to assign them to a role.
- ROLE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- role(String) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
-
- role(String) - Method in class org.springframework.integration.dsl.EndpointSpec
-
Specify the role for the endpoint.
- role(String) - Method in class org.springframework.integration.dsl.SourcePollingChannelAdapterSpec
-
- rollback(F, List<F>) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
-
Indicate that not all files previously passed by this filter (in
FileListFilter.filterFiles(Object[])
have been processed; the file must be in the list of files; it, and all files after it, will
be considered to have not been processed and will be considered next time.
- rollback(F, List<F>) - Method in class org.springframework.integration.file.filters.AcceptOnceFileListFilter
-
- rollback(F, List<F>) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
-
- rollback(F, List<F>) - Method in interface org.springframework.integration.file.filters.ReversibleFileListFilter
-
Indicate that not all files previously passed by this filter (in
FileListFilter.filterFiles(Object[])
have been processed; the file must be in the list of files; it, and all files after it, will
be considered to have not been processed and will be considered next time.
- rollbackFromFileToListEnd(List<F>, F) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
- rollbackFromFileToListEnd(List<F>, F) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- ROME_TOOLS_PRESENT - Static variable in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
- RotatingServerAdvice - Class in org.springframework.integration.file.remote.aop
-
A smart poller advice that rotates across multiple remote servers/directories.
- RotatingServerAdvice(DelegatingSessionFactory<?>, List<RotationPolicy.KeyDirectory>) - Constructor for class org.springframework.integration.file.remote.aop.RotatingServerAdvice
-
Create an instance that rotates to the next server/directory if no message is
received.
- RotatingServerAdvice(DelegatingSessionFactory<?>, List<RotationPolicy.KeyDirectory>, boolean) - Constructor for class org.springframework.integration.file.remote.aop.RotatingServerAdvice
-
Create an instance that rotates to the next server/directory depending on the fair
argument.
- RotatingServerAdvice(RotationPolicy) - Constructor for class org.springframework.integration.file.remote.aop.RotatingServerAdvice
-
Construct an instance that rotates according to the supplied
RotationPolicy
.
- RotationPolicy - Interface in org.springframework.integration.file.remote.aop
-
A strategy for rotating advices to allow reconfiguring
the message source before and/or after a poll.
- RotationPolicy.KeyDirectory - Class in org.springframework.integration.file.remote.aop
-
A key for a thread-local store and its related directory pair.
- RoundRobinLoadBalancingStrategy - Class in org.springframework.integration.dispatcher
-
- RoundRobinLoadBalancingStrategy() - Constructor for class org.springframework.integration.dispatcher.RoundRobinLoadBalancingStrategy
-
- route(String, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- route(String, String, Consumer<RouterSpec<Object, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- route(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MethodInvokingRouter
for the discovered method
of the provided service and its method with default options.
- route(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MethodInvokingRouter
for the method
of the provided service and its method with default options.
- route(Object, String, Consumer<RouterSpec<Object, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- route(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- route(String, Consumer<RouterSpec<T, ExpressionEvaluatingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- route(Class<S>, Function<S, T>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- route(Class<P>, Function<P, T>, Consumer<RouterSpec<T, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- route(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- route(MessageProcessorSpec<?>, Consumer<RouterSpec<Object, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- route(S, Consumer<S>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- route(AbstractMessageRouter) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- route(R, Consumer<GenericEndpointSpec<R>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- route(Function<S, T>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
-
- route(Function<S, T>, Consumer<RouterSpec<T, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
-
- routeByException(Consumer<RouterSpec<Class<? extends Throwable>, ErrorMessageExceptionTypeRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- Router - Annotation Type in org.springframework.integration.annotation
-
Indicates that a method is capable of resolving to a channel or channel name
based on a message, message header(s), or both.
- RouterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
-
Post-processor for Methods annotated with
@Router
.
- RouterAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.RouterAnnotationPostProcessor
-
- RouterFactoryBean - Class in org.springframework.integration.config
-
Factory bean for creating a Message Router.
- RouterFactoryBean() - Constructor for class org.springframework.integration.config.RouterFactoryBean
-
- RouterSpec<K,R extends AbstractMappingMessageRouter> - Class in org.springframework.integration.dsl
-
- RouterSpec(R) - Constructor for class org.springframework.integration.dsl.RouterSpec
-
- routeToRecipients(Consumer<RecipientListRouterSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- ROUTING_SLIP - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
-
- routingKey(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Configure an AMQP routing key for sending messages.
- routingKeyExpression(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
A SpEL expression to evaluate routing key at runtime.
- routingKeyExpression(Expression) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
A SpEL expression to evaluate routing key at runtime.
- routingKeyFunction(Function<Message<?>, String>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
A function to evaluate routing key at runtime.
- RoutingMessageHandlerNode - Class in org.springframework.integration.graph
-
Represents an endpoint that can route to multiple channels.
- RoutingMessageHandlerNode(int, String, MessageHandler, String, String, Collection<String>) - Constructor for class org.springframework.integration.graph.RoutingMessageHandlerNode
-
- routingSlip(Object...) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- routingSlip(Boolean, Object...) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- RoutingSlipHeaderValueMessageProcessor - Class in org.springframework.integration.transformer.support
-
- RoutingSlipHeaderValueMessageProcessor(Object...) - Constructor for class org.springframework.integration.transformer.support.RoutingSlipHeaderValueMessageProcessor
-
- RoutingSlipRouteStrategy - Interface in org.springframework.integration.routingslip
-
The RoutingSlip
strategy to determine the next replyChannel
.
- RSocketConnectedEvent - Class in org.springframework.integration.rsocket
-
An
IntegrationEvent
to indicate that
RSocket
from the client is connected
to the server.
- RSocketConnectedEvent(Object, Map<String, Object>, DataBuffer, RSocketRequester) - Constructor for class org.springframework.integration.rsocket.RSocketConnectedEvent
-
- rsocketConnector(AbstractRSocketConnector) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
-
- RSocketInboundGateway - Class in org.springframework.integration.rsocket.inbound
-
- RSocketInboundGateway(String...) - Constructor for class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
-
Instantiate based on the provided path patterns to map this endpoint for incoming RSocket requests.
- RSocketInboundGatewayParser - Class in org.springframework.integration.rsocket.config
-
Parser for the <inbound-gateway/> element of the 'rsocket' namespace.
- RSocketInboundGatewayParser() - Constructor for class org.springframework.integration.rsocket.config.RSocketInboundGatewayParser
-
- RSocketInboundGatewaySpec - Class in org.springframework.integration.rsocket.dsl
-
- RSocketInboundGatewaySpec(String...) - Constructor for class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
-
- RSocketInteractionModel - Enum in org.springframework.integration.rsocket
-
The RSocket protocol interaction models.
- rSocketMessageHandler - Variable in class org.springframework.integration.rsocket.AbstractRSocketConnector
-
- RSocketNamespaceHandler - Class in org.springframework.integration.rsocket.config
-
Namespace handler for Spring Integration XML configuration for RSocket support.
- RSocketNamespaceHandler() - Constructor for class org.springframework.integration.rsocket.config.RSocketNamespaceHandler
-
- RSocketOutboundGateway - Class in org.springframework.integration.rsocket.outbound
-
An Outbound Messaging Gateway for RSocket requests.
- RSocketOutboundGateway(String, Object...) - Constructor for class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
-
Instantiate based on the provided RSocket endpoint route
and optional variables to expand route template.
- RSocketOutboundGateway(Expression) - Constructor for class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
-
Instantiate based on the provided SpEL expression to evaluate an RSocket endpoint route
at runtime against a request message.
- RSocketOutboundGatewayParser - Class in org.springframework.integration.rsocket.config
-
Parser for the 'outbound-gateway' element of the rsocket namespace.
- RSocketOutboundGatewayParser() - Constructor for class org.springframework.integration.rsocket.config.RSocketOutboundGatewayParser
-
- RSocketOutboundGatewaySpec - Class in org.springframework.integration.rsocket.dsl
-
- RSocketOutboundGatewaySpec(String, Object...) - Constructor for class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
-
- RSocketOutboundGatewaySpec(Expression) - Constructor for class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
-
- RSockets - Class in org.springframework.integration.rsocket.dsl
-
The RSocket components Factory.
- rsocketStrategies(RSocketStrategies) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
-
- RubyScriptExecutor - Class in org.springframework.integration.scripting.jsr223
-
- RubyScriptExecutor() - Constructor for class org.springframework.integration.scripting.jsr223.RubyScriptExecutor
-
- run() - Method in class org.springframework.integration.channel.AbstractExecutorChannel.MessageHandlingTask
-
- run() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- run() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
-
Reads lines from stdout and sends in a message to the output channel.
- run() - Method in class org.springframework.integration.ip.tcp.connection.ClientModeConnectionManager
-
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
-
If there is no listener, this method exits.
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
If no listener registers, exits.
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
If there is no listener,
this method exits.
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
If no listener registers, exits.
- run() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- run() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
Process acknowledgments, if requested.
- run() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
Expire all message groups older than the
timeout
provided.
- run() - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
-
- run() - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
-
- runReaper() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
Cancel the scheduled reap task and run immediately; then reschedule.
- runReaper() - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
-
Cancel the scheduled reap task and run immediately; then reschedule.
- sameExceptIgnorableHeaders(Message<P>, String...) - Static method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
-
- SampleFacade - Interface in org.springframework.integration.support.management.metrics
-
- sb - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
-
- scanEachPoll(boolean) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
-
Set this flag if you want to make sure the internal queue is
refreshed with the latest content of the input directory on each poll.
- scanner(DirectoryScanner) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
-
Specify a custom scanner.
- scanner(DirectoryScanner) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
-
Configure a scanner to use for the file system scan after transfer.
- scatterGather(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- scatterGather(MessageChannel, Consumer<AggregatorSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- scatterGather(MessageChannel, Consumer<AggregatorSpec>, Consumer<ScatterGatherSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- scatterGather(Consumer<RecipientListRouterSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- scatterGather(Consumer<RecipientListRouterSpec>, Consumer<AggregatorSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- scatterGather(Consumer<RecipientListRouterSpec>, Consumer<AggregatorSpec>, Consumer<ScatterGatherSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- ScatterGatherHandler - Class in org.springframework.integration.scattergather
-
- ScatterGatherHandler(MessageHandler, MessageHandler) - Constructor for class org.springframework.integration.scattergather.ScatterGatherHandler
-
- ScatterGatherHandler(MessageChannel, MessageHandler) - Constructor for class org.springframework.integration.scattergather.ScatterGatherHandler
-
- ScatterGatherParser - Class in org.springframework.integration.config.xml
-
Parser for the <scatter-gather> element.
- ScatterGatherParser() - Constructor for class org.springframework.integration.config.xml.ScatterGatherParser
-
- ScatterGatherSpec - Class in org.springframework.integration.dsl
-
- ScatterGatherSpec(ScatterGatherHandler) - Constructor for class org.springframework.integration.dsl.ScatterGatherSpec
-
- SCHEDULER - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- ScriptExecutingMessageProcessor - Class in org.springframework.integration.scripting.jsr223
-
- ScriptExecutingMessageProcessor(ScriptSource, ScriptExecutor) - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
-
- ScriptExecutingMessageProcessor(ScriptSource, ScriptVariableGenerator, ScriptExecutor) - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
-
- ScriptExecutingMessageProcessor(ScriptSource, ScriptExecutor, Map<String, Object>) - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
-
- ScriptExecutingMessageSource - Class in org.springframework.integration.scripting
-
- ScriptExecutingMessageSource(AbstractScriptExecutingMessageProcessor<?>) - Constructor for class org.springframework.integration.scripting.ScriptExecutingMessageSource
-
- ScriptExecutingProcessorFactory - Class in org.springframework.integration.scripting.config
-
- ScriptExecutingProcessorFactory() - Constructor for class org.springframework.integration.scripting.config.ScriptExecutingProcessorFactory
-
- ScriptExecutor - Interface in org.springframework.integration.scripting
-
A script evaluation abstraction against
ScriptSource
and optional binding
variables
.
- ScriptExecutorFactory - Class in org.springframework.integration.scripting.jsr223
-
The scripting configuration utilities.
- ScriptingException - Exception in org.springframework.integration.scripting
-
- ScriptingException(String) - Constructor for exception org.springframework.integration.scripting.ScriptingException
-
- ScriptingException(String, Throwable) - Constructor for exception org.springframework.integration.scripting.ScriptingException
-
- ScriptMessageSourceSpec - Class in org.springframework.integration.scripting.dsl
-
- ScriptMessageSourceSpec(Resource) - Constructor for class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
-
- ScriptMessageSourceSpec(String) - Constructor for class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
-
- ScriptNamespaceHandler - Class in org.springframework.integration.scripting.config.jsr223
-
- ScriptNamespaceHandler() - Constructor for class org.springframework.integration.scripting.config.jsr223.ScriptNamespaceHandler
-
- ScriptParser - Class in org.springframework.integration.scripting.config.jsr223
-
- ScriptParser() - Constructor for class org.springframework.integration.scripting.config.jsr223.ScriptParser
-
- Scripts - Class in org.springframework.integration.scripting.dsl
-
The factory for Dynamic Language Scripts (Groovy, Ruby, Python, JavaScript etc.).
- ScriptSpec - Class in org.springframework.integration.scripting.dsl
-
- ScriptVariableGenerator - Interface in org.springframework.integration.scripting
-
Strategy interface to provide a
Map
of variables to the script execution context.
- searchForNewMessages() - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Subclasses must implement this method to return new mail messages.
- searchForNewMessages() - Method in class org.springframework.integration.mail.ImapMailReceiver
-
Retrieves new messages from this receiver's folder.
- searchForNewMessages() - Method in class org.springframework.integration.mail.Pop3MailReceiver
-
- searchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
- searchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.mail.dsl.ImapMailInboundChannelAdapterSpec
-
- SearchTermStrategy - Interface in org.springframework.integration.mail
-
- SecuredChannel - Annotation Type in org.springframework.integration.security.channel
-
An annotation to be applied for the
MessageChannel
bean definition
from JavaConfig - on
@Bean
method level.
- SecuredChannelsParser - Class in org.springframework.integration.security.config
-
- SecuredChannelsParser() - Constructor for class org.springframework.integration.security.config.SecuredChannelsParser
-
- SecurityContextPropagationChannelInterceptor - Class in org.springframework.integration.security.channel
-
- SecurityContextPropagationChannelInterceptor() - Constructor for class org.springframework.integration.security.channel.SecurityContextPropagationChannelInterceptor
-
- SecurityIntegrationConfigurationInitializer - Class in org.springframework.integration.security.config
-
The Integration Security infrastructure beanFactory
initializer.
- SecurityIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.security.config.SecurityIntegrationConfigurationInitializer
-
- selector(String) - Method in class org.springframework.integration.dsl.WireTapSpec
-
- selector(Expression) - Method in class org.springframework.integration.dsl.WireTapSpec
-
- selector(MessageSelector) - Method in class org.springframework.integration.dsl.WireTapSpec
-
- selector(Function<MimeMessage, Boolean>) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
Configure a
Function
to select messages.
- selector(Function<MimeMessage, Boolean>) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
-
Configure a
Function
to select messages.
- SELECTOR_ACCEPT_METHOD - Static variable in class org.springframework.integration.util.ClassUtils
-
The org.springframework.integration.core.GenericSelector#accept(Object)
method object.
- SelectorChainParser - Class in org.springframework.integration.config.xml
-
Parser for the <selector-chain/> element.
- SelectorChainParser() - Constructor for class org.springframework.integration.config.xml.SelectorChainParser
-
- selectorExpression(String) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
Configure a SpEL expression to select messages.
- selectorExpression(Expression) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
- selectorExpression(String) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
-
Configure a SpEL expression to select messages.
- selectorExpression(Expression) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
-
Configure a SpEL expression to select messages.
- SelectorParser - Class in org.springframework.integration.config.xml
-
Parser for a top-level <selector/> element.
- SelectorParser() - Constructor for class org.springframework.integration.config.xml.SelectorParser
-
- send(Message<?>) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Send a message on this channel.
- send(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Send a message on this channel.
- send(Message<?>) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
-
- send(Message<?>, long) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
-
- send(Message<?>, long) - Method in class org.springframework.integration.channel.NullChannel
-
- send(Message<?>) - Method in class org.springframework.integration.channel.NullChannel
-
- send(Message<?>) - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
-
- send(Message<?>, long) - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
-
- send(Message<?>) - Method in class org.springframework.integration.dsl.support.MessageChannelReference
-
- send(Message<?>, long) - Method in class org.springframework.integration.dsl.support.MessageChannelReference
-
- send(Message<?>, FileExistsMode...) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Send a file to a remote server, based on information in a message.
- send(Message<?>, String, FileExistsMode...) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Send a file to a remote server, based on information in a message.
- send(Message<?>, FileExistsMode...) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- send(Message<?>, String, FileExistsMode...) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- send(String) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
- send(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- send(Message<?>) - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
Converts and sends the message.
- send(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- send(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
-
- send(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- SEND_TIMEOUT_ATTRIBUTE - Static variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- SEND_TIMER_NAME - Static variable in interface org.springframework.integration.support.management.IntegrationManagement
-
- sendAck(Message<byte[]>) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- sendAndReceive(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.MessagingTemplate
-
- sendAndReceive(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- sendAndReceiveMessage(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- sendAndReceiveMessageReactive(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- sender - Variable in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
-
- sendErrorMessage(Message<?>, Throwable) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
- sendErrorMessageIfNecessary(Message<?>, Exception) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
Send an error message based on the exception and message.
- sendExceptionToListener(Exception) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- sendFailureChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Set the channel to which failed send results are sent.
- sendFailureChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Set the channel to which failed send results are sent.
- sendingTaskExecutor(Executor) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
Specify a task executor to be used to send messages to the downstream flow.
- sendMessage(Message<?>) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- sendOutput(Object, Object, boolean) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
Send an output Message.
- sendOutputs(Object, Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
- sendPartialResultOnExpiry(boolean) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
-
- sendSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
-
The
Consumer
callback to configure a publishing socket.
- sendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Set the channel to which successful send results are sent.
- sendSuccessChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Set the channel to which successful send results are sent.
- sendTimeout(long) - Method in class org.springframework.integration.dsl.BarrierSpec
-
- sendTimeout(long) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
-
- sendTimeout(long) - Method in class org.springframework.integration.dsl.MessageProducerSpec
-
Configure the default timeout value to use for send operations.
- sendTimeout(long) - Method in class org.springframework.integration.dsl.PollerSpec
-
- sendTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
- sendTimer() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- sendTimer() - Method in class org.springframework.integration.handler.MessageHandlerSupport
-
- sendTimers(Supplier<SendTimers>) - Method in class org.springframework.integration.graph.MessageChannelNode
-
- sendTimers(Supplier<SendTimers>) - Method in class org.springframework.integration.graph.MessageHandlerNode
-
- SendTimers - Class in org.springframework.integration.graph
-
Success and failure timer stats.
- SendTimers(TimerStats, TimerStats) - Constructor for class org.springframework.integration.graph.SendTimers
-
- sendTimers(Supplier<SendTimers>) - Method in interface org.springframework.integration.graph.SendTimersAware
-
- SendTimersAware - Interface in org.springframework.integration.graph
-
- sendToPipe(ByteBuffer) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- sendToPipe(ByteBuffer) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
-
Overrides super class method to perform decryption and/or participate
in handshaking.
- SEQUENCE - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
-
- SEQUENCE_DETAILS - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
-
- SEQUENCE_NAME - Static variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- SEQUENCE_NAME - Static variable in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- SEQUENCE_NUMBER - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
-
- SEQUENCE_SIZE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
-
- SequenceAwareMessageGroup(MessageGroup) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler.SequenceAwareMessageGroup
-
- SequenceSizeReleaseStrategy - Class in org.springframework.integration.aggregator
-
An implementation of
ReleaseStrategy
that simply compares the current size of
the message list to the expected 'sequenceSize'.
- SequenceSizeReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
-
Construct an instance that does not support releasing partial sequences.
- SequenceSizeReleaseStrategy(boolean) - Constructor for class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
-
Construct an instance that supports releasing partial sequences if
releasePartialSequences is true.
- serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
-
Writes the byte[] to the stream and appends \r\n.
- serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
Write the byte[] to the output stream, preceded by a 4 byte
length in network byte order (big endian).
- serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
-
- serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArraySingleTerminatorSerializer
-
Writes the byte[] to the stream and appends the terminator.
- serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
-
Writes the byte[] to the stream, prefixed by an ASCII STX character and
terminated with an ASCII ETX character.
- serialize(Map<?, ?>, OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
-
- serialize(MessageHeaders, JsonGenerator, SerializerProvider) - Method in class org.springframework.integration.support.json.MessageHeadersJacksonSerializer
-
- serialize(MimeType, JsonGenerator, SerializerProvider) - Method in class org.springframework.integration.support.json.MimeTypeSerializer
-
- serializer() - Static method in class org.springframework.integration.dsl.Transformers
-
- serializer(Serializer<Object>) - Static method in class org.springframework.integration.dsl.Transformers
-
- serializer(Serializer<?>) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
-
- serializeWithType(MessageHeaders, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class org.springframework.integration.support.json.MessageHeadersJacksonSerializer
-
- serializeWithType(MimeType, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class org.springframework.integration.support.json.MimeTypeSerializer
-
- SerializingHttpMessageConverter - Class in org.springframework.integration.http.converter
-
- SerializingHttpMessageConverter() - Constructor for class org.springframework.integration.http.converter.SerializingHttpMessageConverter
-
Creates a new instance of the SerializingHttpMessageConverter
.
- SERVER - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
-
- ServerRSocketConnector - Class in org.springframework.integration.rsocket
-
- ServerRSocketConnector(ServerRSocketMessageHandler) - Constructor for class org.springframework.integration.rsocket.ServerRSocketConnector
-
Instantiate a server connector based on a provided
ServerRSocketMessageHandler
with an assumption that RSocket server is created externally as well.
- ServerRSocketConnector(String, int) - Constructor for class org.springframework.integration.rsocket.ServerRSocketConnector
-
Instantiate a server connector based on the TcpServerTransport
.
- ServerRSocketConnector(HttpServer) - Constructor for class org.springframework.integration.rsocket.ServerRSocketConnector
-
Instantiate a server connector based on the WebsocketServerTransport
.
- ServerRSocketConnector(ServerTransport<CloseableChannel>) - Constructor for class org.springframework.integration.rsocket.ServerRSocketConnector
-
Instantiate a server connector based on the provided ServerTransport
.
- ServerRSocketMessageHandler - Class in org.springframework.integration.rsocket
-
An IntegrationRSocketMessageHandler
extension for RSocket service side.
- ServerRSocketMessageHandler() - Constructor for class org.springframework.integration.rsocket.ServerRSocketMessageHandler
-
- ServerRSocketMessageHandler(boolean) - Constructor for class org.springframework.integration.rsocket.ServerRSocketMessageHandler
-
- ServerWebSocketContainer - Class in org.springframework.integration.websocket
-
- ServerWebSocketContainer(String...) - Constructor for class org.springframework.integration.websocket.ServerWebSocketContainer
-
- ServerWebSocketContainer.SockJsServiceOptions - Class in org.springframework.integration.websocket
-
- ServerWebSocketContainerParser - Class in org.springframework.integration.websocket.config
-
- ServerWebSocketContainerParser() - Constructor for class org.springframework.integration.websocket.config.ServerWebSocketContainerParser
-
- SERVICE_NAME_PREFIX - Static variable in class org.springframework.integration.rmi.RmiInboundGateway
-
Deprecated.
- ServiceActivatingHandler - Class in org.springframework.integration.handler
-
- ServiceActivatingHandler(Object) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
-
- ServiceActivatingHandler(Object, Method) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
-
- ServiceActivatingHandler(Object, String) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
-
- ServiceActivatingHandler(MessageProcessor<T>) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
-
- ServiceActivator - Annotation Type in org.springframework.integration.annotation
-
Indicates that a method is capable of handling a message or message payload.
- ServiceActivatorAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
-
- ServiceActivatorAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.ServiceActivatorAnnotationPostProcessor
-
- ServiceActivatorFactoryBean - Class in org.springframework.integration.config
-
- ServiceActivatorFactoryBean() - Constructor for class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- ServiceActivatorParser - Class in org.springframework.integration.config.xml
-
Parser for the <service-activator> element.
- ServiceActivatorParser() - Constructor for class org.springframework.integration.config.xml.ServiceActivatorParser
-
- ServiceUnavailableException - Exception in org.springframework.integration.ws
-
The
WebServiceException
extension to indicate that the server endpoint is
temporary unavailable.
- ServiceUnavailableException(String) - Constructor for exception org.springframework.integration.ws.ServiceUnavailableException
-
- ServiceUnavailableException(String, Throwable) - Constructor for exception org.springframework.integration.ws.ServiceUnavailableException
-
- Session<F> - Interface in org.springframework.integration.file.remote.session
-
Common abstraction for a Session with a remote File system.
- session(Session) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
- session(Session) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
-
Provide the Java Mail
Session
to use.
- SESSION - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
-
- SESSION_TRANSACTED - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
-
- SESSION_TRANSACTED_STRING - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
-
- sessionAcknowledgeMode(int) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
-
A session acknowledgement mode.
- sessionAcknowledgeMode(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
-
- sessionAcknowledgeMode(int) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
-
- sessionAcknowledgeModeName(String) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
-
A session acknowledgement mode name.
- SessionCallback<F,T> - Interface in org.springframework.integration.file.remote
-
Callback invoked by RemoteFileOperations.execute()
- allows multiple operations
on a session.
- SessionCallbackWithoutResult<F> - Interface in org.springframework.integration.file.remote
-
Simple convenience implementation of
SessionCallback
for cases where
no result is returned.
- SessionClosedEvent - Class in org.springframework.integration.ftp.server
-
An event emitted when a session is closed.
- SessionClosedEvent(FtpSession) - Constructor for class org.springframework.integration.ftp.server.SessionClosedEvent
-
- SessionClosedEvent - Class in org.springframework.integration.sftp.server
-
An event emitted when a session is closed.
- SessionClosedEvent(ServerSession) - Constructor for class org.springframework.integration.sftp.server.SessionClosedEvent
-
- sessionFactory - Variable in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- SessionFactory<F> - Interface in org.springframework.integration.file.remote.session
-
Factory for acquiring
Session
instances.
- SessionFactoryLocator<F> - Interface in org.springframework.integration.file.remote.session
-
- SessionFactoryMapBuilder<T> - Class in org.springframework.integration.file.remote.session
-
- SessionFactoryMapBuilder() - Constructor for class org.springframework.integration.file.remote.session.SessionFactoryMapBuilder
-
- SessionOpenedEvent - Class in org.springframework.integration.ftp.server
-
An event emitted when a session is opened.
- SessionOpenedEvent(FtpSession) - Constructor for class org.springframework.integration.ftp.server.SessionOpenedEvent
-
- SessionOpenedEvent - Class in org.springframework.integration.sftp.server
-
An event emitted when a session is opened.
- SessionOpenedEvent(ServerSession, int) - Constructor for class org.springframework.integration.sftp.server.SessionOpenedEvent
-
- sessions - Variable in class org.springframework.integration.websocket.IntegrationWebSocketContainer
-
- sessionTransacted(boolean) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
-
A session transaction mode.
- sessionTransacted(Boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
-
- sessionTransacted(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
-
- set(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
-
- set(int, Properties) - Method in class org.springframework.integration.history.MessageHistory
-
- SET_MODIFIED - Static variable in class org.springframework.integration.file.FileHeaders
-
- setAcceptMessagesWhileStopping(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setAckAddress(String) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
-
- setAckCounter(int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setAckDeferred(boolean) - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
-
- setAckDeferred(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
-
- setAckDiscarded(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
A boolean
flag to indicate if FilteringMessageListenerAdapter
should acknowledge discarded records or not.
- setAcknowledge(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
-
- setAcknowledged(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
-
- setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setActive(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setActivePollPeriod(long) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
-
Deprecated.
Set the poll period when messages are returned.
- setActivePollPeriod(long) - Method in class org.springframework.integration.aop.SimpleActiveIdleReceiveMessageAdvice
-
Set the poll period when messages are returned.
- setAddContentTypeHeader(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
Set to true to add a content type header; default false.
- setAdditionalFlags(Message) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Optional method allowing you to set additional flags.
- setAdditionalFlags(Message) - Method in class org.springframework.integration.mail.ImapMailReceiver
-
- setAdditionalPropertiesCallback(Function<NamedComponent, Map<String, Object>>) - Method in class org.springframework.integration.graph.IntegrationGraphServer
-
- setAdmin(AmqpAdmin) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
- setAdviceChain(Advice[]) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setAdviceMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
- setAfterCommitChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setAfterCommitExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setAfterRollbackChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setAfterRollbackExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setAge(long, TimeUnit) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
-
Set the age that files have to be before being passed by this filter.
- setAge(Duration) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
-
Set the age that files have to be before being passed by this filter.
- setAge(long) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
-
Set the age that files have to be before being passed by this filter.
- setAllowCredentials(Boolean) - Method in class org.springframework.integration.http.inbound.CrossOrigin
-
- setAllowedHeaders(String...) - Method in class org.springframework.integration.http.inbound.CrossOrigin
-
- setAllowedOrigins(String...) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
-
Configure allowed Origin
header values.
- setAllowedPatterns(String...) - Method in class org.springframework.integration.support.converter.AllowListDeserializingConverter
-
Set simple patterns for allowable packages/classes for deserialization.
- setAllowedPatterns(String...) - Method in class org.springframework.integration.transformer.PayloadDeserializingTransformer
-
- setAllowUnknownKeys(boolean) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
When no
UserInfo
has been provided, set to true to unconditionally allow
connecting to an unknown host or when a host's key has changed (see
knownHosts
).
- setAlwaysAcceptDirectories(Boolean) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
-
Set to true to indicate that the pattern should not be applied to directories.
- setAlwaysAcceptDirectories(boolean) - Method in class org.springframework.integration.file.filters.AbstractDirectoryAwareFileListFilter
-
Set to true so that filters that support this feature can unconditionally pass
directories; default false.
- setAlwaysUseResultFactory(boolean) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
Specify whether to always use result factory even for directly supported payload types
- setAlwaysUseSourceFactory(boolean) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
-
- setAlwaysUseSourceFactory(boolean) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
Specify whether to always use source factory even for directly supported payload types.
- setAmqpAdmin(AmqpAdmin) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
Provide an instance of AmqpAdmin for implicitly declaring Queues if the queueName is not provided.
- setAmqpAdmin(AmqpAdmin) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
This is an optional reference to an AmqpAdmin to use when
declaring a Queue implicitly for a PollableAmqpChannel.
- setAppendNewLine(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setAppendNewLine(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
If 'true' will append a new-line after each write.
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.dsl.context.IntegrationFlowBeanPostProcessor
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.graph.IntegrationGraphServer
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.event.outbound.ApplicationEventPublishingMessageHandler
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
- setApplicationName(String) - Method in class org.springframework.integration.graph.IntegrationGraphServer
-
Set the application name that will appear in the 'contentDescriptor' under
the 'name' key.
- setApplySequence(boolean) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
-
Specify whether to apply the sequence number and size headers to the
messages prior to invoking the subscribed handlers.
- setApplySequence(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- setApplySequence(boolean) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- setApplySequence(boolean) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
Specify whether to apply sequence numbers to the messages prior to sending to the handlers.
- setApplySequence(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setApplySequence(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
- setApplySequence(boolean) - Method in class org.springframework.integration.router.AbstractMessageRouter
-
Specify whether to apply the sequence number and size headers to the messages prior to sending to the recipient
channels.
- setApplySequence(boolean) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
-
Set the applySequence flag to the specified value.
- setArgumentsSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
-
- setArgumentsStrategy(ArgumentsStrategy) - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
-
- setAsMap(boolean) - Method in class org.springframework.integration.syslog.DefaultMessageConverter
-
Set false will leave the payload as the original complete syslog.
- setAsync(Boolean) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
Currently only exposed on the service activator
namespace.
- setAsync(boolean) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
Allow async replies.
- setAsync(boolean) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
Set to true if you don't want to block when sending messages.
- setAsyncEvents(boolean) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
- setAsyncExecutor(Executor) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setAttributeName(String) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
-
Specify the name of the attribute to be retrieved.
- setAuthenticator(Authenticator) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setAuthValue(String) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setAutoAck(boolean) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
Set whether or not acknowledge message read in the Consumer Group.
- setAutoCloseFolder(boolean) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- setAutoCloseFolder(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setAutoCreateDirectory(Boolean) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setAutoCreateDirectory(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
Specify whether to create the source directory automatically if it does
not yet exist upon initialization.
- setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Specify whether to create the destination directory automatically if it
does not yet exist upon initialization.
- setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Determine whether the remote directory should automatically be created when
sending files to the remote system.
- setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
A boolean
flag to indicate automatically create the directory or not.
- setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
Determine whether the remote directory should automatically be created when
sending files to the remote system.
- setAutoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
A boolean
flag to identify if local directory should be created automatically.
- setAutoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- setAutoReceipt(boolean) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setAutoStartup(Boolean) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setAutoStartup(Boolean) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
-
Set the auto startup.
- setAutoStartup(boolean) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
-
- setBackendPort(int) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
-
Specify a fixed port for backend socket of the proxy.
- setBackendSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
-
Provide a
Consumer
to configure a proxy backend socket with arbitrary options, like security.
- setBacklog(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setBacklog(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
The number of sockets in the connection backlog.
- setBaseDirectory(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
-
Set the location for the properties file.
- setBasename(String) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set a single basename, following the basic ResourceBundle convention of
not specifying file extension or language codes, but referring to a Spring
resource location: e.g.
- setBasenames(String[]) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set an array of basenames, each following the basic ResourceBundle convention
of not specifying file extension or language codes, but referring to a Spring
resource location: e.g.
- setBatchingStrategy(BatchingStrategy) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
Set a batching strategy to use when de-batching messages created by a batching
producer (such as the BatchingRabbitTemplate).
- setBatchingStrategy(BatchingStrategy) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Set a batching strategy to use when de-batching messages.
- setBatchingStrategy(BatchingStrategy) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
Set a batching strategy to use when de-batching messages.
- setBatchMessageConverter(BatchMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
Set the message converter to use with a batch-based consumer.
- setBatchMode(AmqpInboundChannelAdapter.BatchMode) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
When the listener container is configured with consumerBatchEnabled, set the payload
type for messages generated for the batches.
- setBatchSize(Integer) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.json.JsonToObjectTransformer
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.redis.store.RedisMessageStore
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.DelegatingMessageGroupProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.channel.interceptor.WireTap
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.core.ErrorMessagePublisher
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.core.MessagingTemplate
-
Overridden to set the destination resolver to a integrationChannelResolver
bean.
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.file.filters.ExpressionFileListFilter
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.BeanNameMessageProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.ExpressionCommandMessageProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.LambdaMessageProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.jmx.config.IntegrationMBeanExportConfiguration
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.monitor.IntegrationJmxAttributeSource
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.converter.MapMessageConverter
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.syslog.DefaultMessageConverter
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.test.context.MockIntegrationContext
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.support.ExpressionEvaluatingHeaderValueMessageProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.support.RoutingSlipHeaderValueMessageProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
Specify a BeanFactory in order to enable resolution via @beanName
in the expression.
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
-
- setBeanName(String) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
-
- setBeanName(String) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
-
- setBeanName(String) - Method in class org.springframework.integration.channel.NullChannel
-
- setBeanName(String) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
-
- setBeanName(String) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- setBeanName(String) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
-
- setBeanName(String) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- setBeanName(String) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
-
- setBeanName(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
-
- setBeanName(String) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
-
- setBeanName(String) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- setBeanName(String) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
-
- setBeforeCommitChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setBeforeCommitExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setBindFunction(BiFunction<DatabaseClient.GenericExecuteSpec, ?, DatabaseClient.GenericExecuteSpec>) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
-
Set a
BiFunction
which is used to bind parameters into the update query.
- setBindPort(int) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
-
Configure a port for TCP protocol binding via ZMQ.Socket.bind(String)
.
- setBindSourceMessage(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- setBindSourceMessage(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
- setBindSourceRecord(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
-
- setBindSourceRecord(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
- setBodyExtractor(BodyExtractor<?, ? super ClientHttpResponse>) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
-
- setBoundaryTrigger(Predicate<Message<?>>) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
Configure a
Predicate
for messages to determine a window boundary in the
Flux.windowUntil(java.util.function.Predicate<T>)
operator.
- setBufferSize(Integer) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setBufferSize(int) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Set the buffer size to use while writing to files; default 8192.
- setBufferSize(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setBusyWaitMillis(long) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- setBytesMessageMapper(BytesMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
- setBytesMessageMapper(BytesMessageMapper) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
- setBytesPerMessage(int) - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
-
- setCacheEntries(Map<String, String>) - Method in class org.springframework.integration.gemfire.outbound.CacheWritingMessageHandler
-
- setCacheEntryExpressions(Map<Expression, Expression>) - Method in class org.springframework.integration.gemfire.outbound.CacheWritingMessageHandler
-
- setCacheLevel(Integer) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setCacheLevel(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setCacheLevelName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setCacheManager(CacheManager) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
-
- setCacheOperations(CacheOperation...) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
-
Configure a set of
CacheOperation
which are going to be applied to the
AbstractReplyProducingMessageHandler.RequestHandler#handleRequestMessage(Message)
method via
IntegrationCacheAspect
.
- setCacheResolver(CacheResolver) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
-
- setCacheSeconds(int) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set the number of seconds to cache loaded properties files.
- setCancelIdleInterval(long) - Method in class org.springframework.integration.mail.ImapMailReceiver
-
IDLE commands will be terminated after this interval; useful in cases where a connection
might be silently dropped.
- setCandidate(Candidate) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
- setCaseSensitive(boolean) - Method in class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
-
Set to true to make the header name pattern match case sensitive.
- setCaseSensitive(boolean) - Method in class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
-
Specify whether comparison of value returned by
XPathExpression
to test value should be case sensitive.
- setChannel(MessageChannel) - Method in class org.springframework.integration.core.ErrorMessagePublisher
-
- setChannelAttributeName(String) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
-
- setChannelConnectTimeout(Duration) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Set the connect timeout.
- setChannelConnectTimeout(Duration) - Method in class org.springframework.integration.sftp.session.SftpSession
-
Set the connect timeout.
- setChannelKeyFallback(boolean) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
When true (default), if a resolved channel key does not exist in the channel map,
the key itself is used as the channel name, which we will attempt to resolve to a
channel.
- setChannelMap(Map<String, String>) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
-
- setChannelMapping(String, String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Add a channel mapping from the provided key to channel name.
- setChannelMapping(String, String) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
-
- setChannelMapping(String, String) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
-
Add a channel mapping from the provided key to channel name.
- setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Provide mappings from channel keys to channel names.
- setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
-
- setChannelMappings(Map<String, String>) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
-
Provide mappings from channel keys to channel names.
- setChannelMessageStoreQueryProvider(ChannelMessageStoreQueryProvider) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
- setChannelName(String) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
-
- setChannelName(String) - Method in class org.springframework.integration.core.ErrorMessagePublisher
-
- setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
-
- setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
Set the handler's channel resolver.
- setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.core.ErrorMessagePublisher
-
- setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.router.RecipientListRouter.Recipient
-
- setChannels(List<MessageChannel>) - Method in class org.springframework.integration.router.RecipientListRouter
-
Set the channels for this router.
- setChannelTransacted(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setCharset(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setCharset(String) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Set the charset name to use when writing a File from a String-based
Message payload.
- setCharset(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Set the charset to use when converting String payloads to bytes as the content of the
remote file.
- setCharset(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
Set the charset to use when converting String payloads to bytes as the content of the
remote file.
- setCharset(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
Set the charset to use when converting String payloads to bytes as the content of the
remote file.
- setCharset(Charset) - Method in class org.springframework.integration.file.splitter.FileSplitter
-
Set the charset to be used when reading the file, when something other than the default
charset is required.
- setCharset(String) - Method in class org.springframework.integration.file.transformer.FileToStringTransformer
-
Set the charset name to use when copying the File to a String.
- setCharset(Charset) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
-
Sets the character set used for writing form data.
- setCharset(String) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Specify the charset name to use for converting String-typed payloads to bytes.
- setCharset(String) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
Set the charset to use when converting outbound String messages to byte[]
.
- setCharset(String) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
-
- setCharset(String) - Method in class org.springframework.integration.mail.transformer.MailToStringTransformer
-
Specify the name of the Charset to use when converting from bytes.
- setCharset(String) - Method in class org.springframework.integration.syslog.RFC5424MessageConverter
-
- setChmod(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setChmod(int) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Set the file permissions after uploading, e.g.
- setChmod(int) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Set the file permissions after uploading, e.g.
- setChmod(int) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
Set the file permissions after uploading, e.g.
- setChmodOctal(String) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
String setter for Spring XML convenience.
- setChmodOctal(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
String setter for Spring XML convenience.
- setChmodOctal(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
String setter for Spring XML convenience.
- setCipherSuites(String[]) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setClassifier(Classifier<? super Throwable, Boolean>) - Method in class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
-
- setClearOnFlush(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setClient(CuratorFramework) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
- setClientId(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setClientLibraryUrl(String) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
-
- setClientMode(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
ACTIVE_LOCAL_DATA_CONNECTION_MODE = 0
A constant indicating the FTP session is expecting all transfers
to occur between the client (local) and server and that the server
should connect to the client's data port to initiate a data transfer.
- setClientMode(boolean) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- setClientMode(boolean) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- setClientMode(boolean) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- setClientRSocketConnector(ClientRSocketConnector) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
-
- setClientRSocketKeyStrategy(BiFunction<Map<String, Object>, DataBuffer, Object>) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
-
Configure a strategy to determine a key for the client
RSocketRequester
connected.
- setClientRSocketKeyStrategy(BiFunction<Map<String, Object>, DataBuffer, Object>) - Method in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
-
- setClientVersion(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Allows you to set the client version property.
- setCloseOnRefresh(boolean) - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
When using a shared connection
singleUse
is false,
set this to true to close the old shared connection after a refresh.
- setCloseStreamAfterSend(boolean) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
Set to true to close the connection ouput stream after sending without
closing the connection.
- setCloseTimeout(Duration) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
-
Set the close timeout - default 30 seconds.
- setCodecConfigurer(ServerCodecConfigurer) - Method in class org.springframework.integration.webflux.inbound.WebFluxInboundEndpoint
-
- setCollection(String) - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
-
Specify a collection name to track change events from.
- setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
Sets the SpEL
Expression
that should resolve to a collection name
used by the
Query
.
- setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
-
Set the SpEL
Expression
that should resolve to a collection name
used by the
Query
.
- setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
-
- setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
-
- setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
-
- setCollectionNameExpressionString(String) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
-
- setCollectionType(RedisCollectionFactoryBean.CollectionType) - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
- setCollectionType(RedisCollectionFactoryBean.CollectionType) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
- setCombineFunction(Function<Flux<Message<?>>, Mono<Message<?>>>) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
Configure a transformation
Function
to apply for a
Flux
window to emit.
- setCommandExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
-
- setCommandExpressionString(String) - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
-
- setComparator(Comparator<File>) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setComparator(Comparator<F>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Set a comparator to sort the retrieved list of F
(the Type that represents
the remote file) prior to applying filters and max fetch size.
- setCompareValues(BiPredicate<String, String>) - Method in class org.springframework.integration.selector.MetadataStoreSelector
-
Set a
BiPredicate
to compare old and new values in the metadata store for
the key.
- setCompilerConfiguration(CompilerConfiguration) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
Specify the CompilerConfiguration
options to customize the Groovy script compilation.
- setCompileStatic(boolean) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
Specify the boolean
flag to indicate if the GroovyClassLoader
's compiler
should be customised for the CompileStatic
hint for the provided script.
- setComplete(boolean) - Method in class org.springframework.integration.mongodb.store.MessageDocument
-
- setCompletionTimeout(long) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
Set the completion timeout for operations.
- setCompletionTimeout(long) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
Set the completion timeout for async operations.
- setComponentName(String) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
Sets the name of the handler component.
- setComponentName(String) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
Sets the name of this component.
- setComponentName(String) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setComponentName(String) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setComponentName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setComponentName(String) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- setComponentNamePatterns(String[]) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
The patterns for which components will be tracked; default '*' (all trackable
components).
- setComponentNamePatterns(String[]) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
Set the array of simple patterns for component names to register (defaults to '*').
- setComponentNamePatternsSet(Set<String>) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
The patterns for which components will be tracked; default '*' (all trackable
components).
- setComponentNamePatternsString(String) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
A comma-delimited list of patterns for which components will be tracked; default '*' (all trackable
components).
- setComponentType(String) - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
-
- setComponentType(String) - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
-
- setConcurrency(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setConcurrentConsumers(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setConcurrentConsumers(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setConcurrentConsumers(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setConfig(FTPClientConfig) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setConfirmAckChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the channel to which acks are send (publisher confirms).
- setConfirmAckChannelName(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the channel name to which acks are send (publisher confirms).
- setConfirmCorrelationExpression(Expression) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set a SpEL expression to evaluate confirm correlation at runtime.
- setConfirmCorrelationExpressionString(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set a SpEL expression to evaluate confirm correlation at runtime.
- setConfirmNackChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the channel to which nacks are send (publisher confirms).
- setConfirmNackChannelName(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the channel name to which nacks are send (publisher confirms).
- setConfirmTimeout(long) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set a timeout after which a nack will be synthesized if no publisher confirm has
been received within that time.
- setConnectHeaders(StompHeaders) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- setConnectionConfiguration(XMPPTCPConnectionConfiguration) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- setConnectionFactory(AbstractClientConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
Sets the client or server connection factory; for this (an inbound adapter), if
the factory is a client connection factory, the sockets are owned by a sending
channel adapter and this adapter is used to receive replies.
- setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
Sets the client or server connection factory; for this (an outbound adapter), if
the factory is a server connection factory, the sockets are owned by a receiving
channel adapter and this adapter is used to send replies.
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.DynamicJmsTemplate
-
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the JMS ConnectionFactory that this gateway should use.
- setConnectionFactory(AbstractServerConnectionFactory) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setConnectionFactory(AbstractServerConnectionFactory) - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
-
- setConnectionOptions(MqttConnectOptions) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
-
Set the preconfigured MqttConnectOptions
.
- setConnectionTest(Predicate<TcpConnectionSupport>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
Set a
Predicate
that will be invoked to test a new connection; return true
to accept the connection, false the reject.
- setConnectionTimeout(int) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
-
Set the connection timeout in seconds; default: 10.
- setConnectionWaitTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setConnectorConfigurer(RSocketConnectorConfigurer) - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
-
Callback to configure the ClientRSocketFactory
directly.
- setConnectTimeout(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
Set the connect timeout for the socket.
- setConnectTimeout(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setConnectTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
Set the connection timeout in seconds.
- setConnectTimeout(long) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
-
Specify the the timeout in milliseconds to wait for the STOMP session establishment.
- setConnectUrl(String) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
-
Configure a connection to the ZeroMQ proxy with the pair of ports over colon
for proxy frontend and backend sockets.
- setConnectUrl(String) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
-
Configure an URL for ZMQ.Socket.connect(String)
.
- setConsumeDelay(Duration) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
-
Specify a Duration
to delay consumption when no data received.
- setConsumeDelay(Duration) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
-
Specify a Duration
to delay consumption when no data received.
- setConsumerGroup(String) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
Set the name of the Consumer Group.
- setConsumerName(String) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
Set the name of the consumer.
- setConsumersPerQueue(Integer) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setConsumerStopAction(ConsumerStopAction) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
-
Set the consumer stop action.
- setConsumes(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setContainerType(Class<? extends AbstractMessageListenerContainer>) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setContentType(String) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
- setContentType(String) - Method in class org.springframework.integration.json.ObjectToJsonTransformer
-
Sets the content-type header value
- setControlEncoding(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
-
- setConverter(MqttMessageConverter) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
-
- setConverter(MessageConverter) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
Set the message converter to use; if this is provided, the adapter qos and retained
settings are ignored.
- setConverter(MessageConverter) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setConverter(MessageConverter) - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
-
- setConverter(Converter<T, U>) - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
-
Specify the converter to use.
- setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.router.XPathRouter
-
Specify the Converter to use when converting payloads prior to XPath evaluation.
- setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
-
Specify the converter used to convert payloads prior to XPath testing.
- setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
-
Specify the Converter to use when converting payloads prior to validation.
- setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
-
Specify the
XmlPayloadConverter
to use when converting a Message payload prior to XPath evaluation.
- setConvertExceptions(boolean) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingMessagingGateway
-
Flag to determine if conversion and writing out of message handling exceptions should be attempted (default
false, in which case they will simply be re-thrown).
- setCopyOnGet(boolean) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- setCorrelationId(Object) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
- setCorrelationId(Object) - Method in class org.springframework.integration.support.MessageBuilder
-
- setCorrelationKey(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Provide the name of a JMS property that should be copied from the request
Message to the reply Message.
- setCorrelationKey(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Provide the name of a JMS property that should hold a generated UUID that
the receiver of the JMS Message would expect to represent the CorrelationID.
- setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
-
Set the CorrelationStrategy to be used to determine the correlation key for incoming messages
- setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
- setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setCreateConsumerGroup(boolean) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
Create the Consumer Group if and only if it does not exist.
- setCreateDocuments(boolean) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
-
- setCreatedTime(long) - Method in class org.springframework.integration.mongodb.store.MessageDocument
-
- setCriteriaExpression(Expression) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
-
Set a SpEL expression to evaluate a Criteria
for query to execute.
- setCrossOrigin(CrossOrigin) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
Set the
CrossOrigin
to permit cross origin requests for this endpoint.
- setCustomConverters(Object...) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
-
- setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
-
- setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
- setDataMimeType(MimeType) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
-
Configure a
MimeType
for data exchanging.
- setDataMimeType(MimeType) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
-
- setDataSource(DataSource) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
The JDBC
DataSource
to use when interacting with the database.
- setDataTimeout(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
Set the (socket option) timeout on the data connection.
- setDatatypes(Class<?>...) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Specify the Message payload datatype(s) supported by this channel.
- setDecodeFluxAsUnit(boolean) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
-
Configure an option to decode an incoming Flux
as a single unit or each its event separately.
- setDecoratorFactories(WebSocketHandlerDecoratorFactory...) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
-
Configure one or more factories to decorate the handler used to process
WebSocket messages.
- setDefaultChannel(MessageChannel) - Method in class org.springframework.integration.core.MessagingTemplate
-
Invokes setDefaultDestination(MessageChannel)
- provided for
backward compatibility.
- setDefaultChannelName(String) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
-
- setDefaultChannelName(String) - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
-
A channel bean name to be used as default for publishing.
- setDefaultChannelName(String) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
-
Set the default channel where Messages should be sent if the annotation
itself does not provide a channel.
- setDefaultDelay(long) - Method in class org.springframework.integration.handler.DelayHandler
-
Set the default delay in milliseconds.
- setDefaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
Set the delivery mode to use if the message has no
"amqp_deliveryMode"
header and the message property was not set by the
MessagePropertiesConverter
.
- setDefaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setDefaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the default delivery mode.
- setDefaultDomain(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
The JMX domain to use for MBeans registered.
- setDefaultEncoding(String) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set the default charset to use for parsing properties files.
- setDefaultErrorChannel(MessageChannel) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
-
- setDefaultErrorChannelName(String) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
-
Specify the bean name of default error channel for this error handler.
- setDefaultLoggingEnabled(boolean) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
-
Disable all logging in the normal message flow in framework components.
- setDefaultMultipartCharset(String) - Method in class org.springframework.integration.http.multipart.SimpleMultipartFileReader
-
Specify the default charset name to use when converting multipart file
content into Strings if the multipart itself does not provide a charset.
- setDefaultNotificationType(String) - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
-
Specify a dot-delimited String representing the Notification type to
use by default when no explicit Notification mapper
has been configured.
- setDefaultOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- setDefaultOutputChannel(MessageChannel) - Method in class org.springframework.integration.router.AbstractMessageRouter
-
Set the default channel where Messages should be sent if channel resolution
fails to return any channels.
- setDefaultOutputChannelName(String) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- setDefaultOutputChannelName(String) - Method in class org.springframework.integration.router.AbstractMessageRouter
-
- setDefaultOverwrite(boolean) - Method in class org.springframework.integration.transformer.HeaderEnricher
-
- setDefaultPriority(int) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- setDefaultQos(int) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
- setDefaultReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set the default reply channel.
- setDefaultReplyChannelName(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set the default reply channel bean name.
- setDefaultReplyDestination(Destination) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Set the default reply destination to send reply messages to.
- setDefaultReplyQueueName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Set the name of the default reply queue to send reply messages to.
- setDefaultReplyTimeout(Long) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set the default timeout value for receiving reply messages.
- setDefaultReplyTimeoutExpression(Expression) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set an expression to be evaluated to determine the default timeout value for
receiving reply messages.
- setDefaultReplyTimeoutExpressionString(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set an expression to be evaluated to determine the default timeout value for
receiving reply messages.
- setDefaultReplyTo(String) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
The
defaultReplyTo
address with the form
(exchange)/(routingKey)
- setDefaultReplyTopicName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Set the name of the default reply topic to send reply messages to.
- setDefaultRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set the default request channel.
- setDefaultRequestChannelName(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set the default request channel bean name.
- setDefaultRequestTimeout(Long) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set the default timeout value for sending request messages.
- setDefaultRequestTimeoutExpression(Expression) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set an expression to be evaluated to determine the default timeout value for
sending request messages.
- setDefaultRequestTimeoutExpressionString(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set an expression to be evaluated to determine the default timeout value for
sending request messages.
- setDefaultRetained(boolean) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
- setDefaultTimeout(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
Set the (socket option) timeout on the command socket.
- setDefaultTopic(String) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
Set the topic to which the message will be published if the
topicExpression
evaluates to `null`.
- setDelay(int) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the value to set in the x-delay
header when using the
RabbitMQ delayed message exchange plugin.
- setDelay(Long) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setDelayedAdviceChain(List<Advice>) - Method in class org.springframework.integration.handler.DelayHandler
-
Specify the List<Advice>
to advise
DelayHandler.ReleaseMessageHandler
proxy.
- setDelayedMessageErrorChannel(MessageChannel) - Method in class org.springframework.integration.handler.DelayHandler
-
Set a message channel to which an
ErrorMessage
will be sent if sending the
released message fails.
- setDelayedMessageErrorChannelName(String) - Method in class org.springframework.integration.handler.DelayHandler
-
Set a message channel name to which an
ErrorMessage
will be sent if sending
the released message fails.
- setDelayExpression(Expression) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the SpEL expression to calculate the x-delay
header when using the
RabbitMQ delayed message exchange plugin.
- setDelayExpression(Expression) - Method in class org.springframework.integration.handler.DelayHandler
-
Specify the
Expression
that should be checked for a delay period (in
milliseconds) or a Date to delay until.
- setDelayExpressionString(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the SpEL expression to calculate the x-delay
header when using the
RabbitMQ delayed message exchange plugin.
- setDelayExpressionString(String) - Method in class org.springframework.integration.handler.DelayHandler
-
Specify the Expression
that should be checked for a delay period (in
milliseconds) or a Date to delay until.
- setDelayWhenEmpty(Duration) - Method in class org.springframework.integration.endpoint.ReactiveMessageSourceProducer
-
Configure a Duration
to delay next pull request when the previous one
was empty.
- setDeleteAfterPoll(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
If set to 'true', the retrieved objects are deleted from the database upon
being polled.
- setDeleteFiles(boolean) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
-
Specify whether to delete the File after transformation.
- setDeleteInBatch(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
If not set, this property defaults to false
, which means that
deletion occurs on a per object basis if a collection of entities is being
deleted.
- setDeleteRemoteFiles(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Set to true to enable deletion of remote files after successful transfer.
- setDeleteSourceFiles(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setDeleteSourceFiles(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Specify whether to delete source Files after writing to the destination
directory.
- setDelimiters(String) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- setDelimiters(String) - Method in class org.springframework.integration.splitter.DefaultMessageSplitter
-
Set delimiters to use for tokenizing String values.
- setDeliveryModeExpression(Expression) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
Specify a SpEL expression to evaluate a deliveryMode
for the JMS message to send.
- setDeliveryModeExpressionString(String) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
Specify a SpEL expression to evaluate a deliveryMode
for the JMS message to send.
- setDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set whether message delivery should be persistent or non-persistent,
specified as a boolean value ("true" or "false").
- setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setDeserializer(Deserializer<? extends Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
A converter for deserializing byte arrays to messages.
- setDeserializer(Deserializer<? extends Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
A converter for deserializing byte arrays to messages.
- setDeserializer(Deserializer<Object>) - Method in class org.springframework.integration.transformer.PayloadDeserializingTransformer
-
- setDestination(Destination) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setDestination(Destination) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
-
- setDestination(Destination) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
- setDestination(String) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
-
- setDestinationExpression(Expression) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
- setDestinationExpression(Expression) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
-
- setDestinationName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setDestinationName(String) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
-
- setDestinationName(String) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
- setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Set the DestinationResolver that should be used to resolve reply
destination names for this listener.
- setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Provide the
DestinationResolver
to use when resolving either a
'requestDestinationName' or 'replyDestinationName' value.
- setDirectory(File) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setDirectory(File) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setDirectory(File) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
Specify the input directory.
- setDirectoryExpression(Expression) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
-
Set the channel to which late arriving trigger messages are sent.
- setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.config.FilterFactoryBean
-
- setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.filter.MessageFilter
-
Specify a channel where rejected Messages should be sent.
- setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
-
Specify a channel where rejected Messages should be sent.
- setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
-
Specify a channel where rejected Messages should be sent.
- setDiscardChannelName(String) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setDiscardChannelName(String) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
-
Set the name of the channel to which late arriving trigger messages are sent.
- setDiscardChannelName(String) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setDiscardChannelName(String) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- setDiscardChannelName(String) - Method in class org.springframework.integration.filter.MessageFilter
-
- setDiscardChannelName(String) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
-
Specify a channel name where rejected Messages should be sent.
- setDiscardChannelName(String) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
-
Specify a channel bean name (resolved to
MessageChannel
lazily)
where rejected Messages should be sent.
- setDiscardWithinAdvice(boolean) - Method in class org.springframework.integration.config.FilterFactoryBean
-
- setDiscardWithinAdvice(boolean) - Method in class org.springframework.integration.filter.MessageFilter
-
Set to 'true' if you wish the discard processing to occur within any
request handler advice applied to this filter.
- setDisconnectCompletionTimeout(long) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
Set the completion timeout when disconnecting.
- setDisconnectCompletionTimeout(long) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
Set the completion timeout when disconnecting.
- setDisconnectDelay(long) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
-
- setDocumentBuilder(DocumentBuilderFactory) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
-
- setDomainType(Class<?>) - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
-
Specify an object type to convert an event body to.
- setDurable(boolean) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
-
- setDurableSubscriptionName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setDuration(Duration) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
-
Set the duration.
- setDynamicChannelLimit(int) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Set a limit for how many dynamic channels are retained (for reporting purposes).
- setEmbeddedPartsAsBytes(boolean) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
When a header mapper is provided determine whether an embedded
Part
(e.g
Message
or
Multipart
content is rendered as a byte[] in the
payload.
- setEmbeddedPartsAsBytes(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setEnableDaemonThread(Boolean) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
If true, all threads will be daemon threads.
- setEnableStatusReader(boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
If false, thread for capturing stderr will not be started
and stderr output will be ignored
- setEnableStatusReader(boolean) - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
-
If false, thread for capturing stderr will not be started
and stderr output will be ignored
- setEncodeUri(boolean) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
- setEncodeUri(boolean) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setEncoding(String) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setEncoding(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
-
Encoding to use when storing data in ZooKeeper
- setEncodingMode(DefaultUriBuilderFactory.EncodingMode) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Set the encoding mode to use.
- setEncodingMode(DefaultUriBuilderFactory.EncodingMode) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
- setEncodingMode(DefaultUriBuilderFactory.EncodingMode) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
-
- setEncodingMode(DefaultUriBuilderFactory.EncodingMode) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
Set the encoding mode to use.
- setEnd(Boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setEnd(boolean) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
-
If true, tail from the end of the file, otherwise
include all lines from the beginning.
- setEndpoints(IntegrationRSocketEndpoint...) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
-
- setEntityClass(Class<?>) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Sets the class type which is being used for retrieving entities from the
database.
- setEntityClass(Class<?>) - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
- setEntityClass(Class<?>) - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
-
- setEntityClass(Class<?>) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
-
- setEnvironment(Environment) - Method in class org.springframework.integration.config.IntegrationComponentScanRegistrar
-
- setEnvironment(Environment) - Method in class org.springframework.integration.config.IntegrationManagementConfiguration
-
- setEnvironment(Environment) - Method in class org.springframework.integration.jmx.config.IntegrationMBeanExportConfiguration
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set the error channel.
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set the error channel.
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.support.MessageBuilder
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Set the content enricher's error channel to allow the error handling flow to return
of an alternative object to use for enrichment if exceptions occur in the
downstream flow.
- setErrorChannelName(String) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
Set the error channel name.
- setErrorChannelName(String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setErrorChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
-
- setErrorChannelName(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set the error channel name.
- setErrorChannelName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set the error channel name.
- setErrorChannelName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setErrorChannelName(String) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- setErrorChannelName(String) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- setErrorChannelName(String) - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
-
- setErrorChannelName(String) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
- setErrorChannelName(String) - Method in class org.springframework.integration.support.MessageBuilder
-
- setErrorChannelName(String) - Method in class org.springframework.integration.transformer.ContentEnricher
-
- setErrorCode(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
The error code to use to signal an error in the message handling.
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
-
Provide an
ErrorHandler
strategy for handling Exceptions that
occur downstream from this channel.
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
-
- setErrorHandler(CacheErrorHandler) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
-
Set the
CacheErrorHandler
instance to use to handle errors
thrown by the cache provider.
- setErrorHandler(ResponseErrorHandler) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setErrorMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
- setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the error message strategy to use for returned (or negatively confirmed)
messages.
- setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.core.ErrorMessagePublisher
-
- setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set the error message strategy implementation to use when sending error messages after
send failures.
- setErrorOnTimeout(boolean) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
If errorOnTimeout is true, construct an instance that will send an
ErrorMessage
with a
MessageTimeoutException
payload to the error
channel if a reply is expected but none is received.
- setErrorOnTimeout(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setErrorOnTimeout(boolean) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- setErrorsKey(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
The key used to expose
Errors
in the core,
in the case that message handling fails.
- setEvaluateAsString(boolean) - Method in class org.springframework.integration.xml.router.XPathRouter
-
- setEvaluationContext(StandardEvaluationContext) - Method in class org.springframework.integration.transformer.DecodingTransformer
-
- setEvaluationType(XPathEvaluationType) - Method in class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
-
- setEvaluationType(XPathEvaluationType) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
-
- setEventTypes(Class<?>...) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
Set the list of event types (classes that extend ApplicationEvent) that
this adapter should send to the message channel.
- setExceptionListener(ExceptionListener) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setExchange(FanoutExchange) - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
-
Configure the FanoutExchange instance.
- setExchange(FanoutExchange) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
Set the FanoutExchange to use.
- setExchangeName(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Configure an AMQP exchange name for sending messages.
- setExchangeNameExpression(Expression) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Configure a SpEL expression to evaluate an exchange name at runtime.
- setExchangeNameExpressionString(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- setExcludedInboundStandardResponseHeaderNames(String...) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Provide header names from the list of standard headers that should be suppressed when
mapping inbound endpoint response headers.
- setExcludedOutboundStandardRequestHeaderNames(String...) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Provide header names from the list of standard headers that should be suppressed when
mapping outbound endpoint request headers.
- setExecutor(Executor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- setExecutor(Executor) - Method in class org.springframework.integration.redis.util.RedisLockRegistry
-
Set the
Executor
, where is not provided then a default of
cached thread pool Executor will be used.
- setExecutorService(ExecutorService) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
Set the
ExecutorService
, where is not provided then a default of
single thread Executor will be used.
- setExistsMode(FtpRemoteFileTemplate.ExistsMode) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
-
- setExpectedResponseType(Class<?>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Specify the expected response type for the REST request
otherwise the default response type is
ResponseEntity
and will
be returned as a payload of the reply Message.
- setExpectedResponseType(Class<?>) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
-
Specify an response type for the RSocket response.
- setExpectedResponseTypeExpression(Expression) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Specify the
Expression
to determine the type for the expected response
The returned value of the expression could be an instance of
Class
or
String
representing a fully qualified class name.
- setExpectedResponseTypeExpression(Expression) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
-
Specify an
Expression
to determine the type for the RSocket response.
- setExpectedType(Class<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
-
- setExpectedType(Class<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
-
Set the result type expected from evaluation of the expression.
- setExpectMessage(boolean) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
When data is retrieved from the Redis queue, does the returned data represent
just the payload for a Message, or does the data represent a serialized
Message
?.
- setExpectReply(boolean) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
Set to true if this endpoint is a gateway.
- setExpectReply(boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setExpectReply(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Specify whether a reply Message is expected.
- setExpectReply(boolean) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Specify whether a reply Message is expected.
- setExpectReply(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Specify whether a JMS reply Message is expected.
- setExpectReply(boolean) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
-
Specify whether a reply Message is expected.
- setExpectReply(boolean) - Method in class org.springframework.integration.rmi.RmiInboundGateway
-
Deprecated.
Specify whether the gateway should be expected to return a reply.
- setExpectSingleResult(boolean) - Method in class org.springframework.integration.jdbc.StoredProcOutboundGateway
-
This parameter indicates that only one result object shall be returned from
the Stored Procedure/Function Call.
- setExpectSingleResult(boolean) - Method in class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
-
This parameter indicates that only one result object shall be returned from
the Stored Procedure/Function Call.
- setExpectSingleResult(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
This parameter indicates that only one result object shall be returned as
a result from the executed JPA operation.
- setExpectSingleResult(boolean) - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
Allows you to manage which find* method to invoke on
MongoTemplate
.
- setExpectSingleResult(boolean) - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
-
- setExpectSingleResult(boolean) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
-
- setExpectSingleResult(boolean) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
-
The flag to manage which find* method to invoke on R2dbcEntityOperations
.
- setExpirationDate(Long) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
- setExpirationDate(Date) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
- setExpirationDate(Long) - Method in class org.springframework.integration.support.MessageBuilder
-
- setExpirationDate(Date) - Method in class org.springframework.integration.support.MessageBuilder
-
- setExpireDuration(Duration) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
Configure a Duration
how often to clean up old orphaned groups from the store.
- setExpireDuration(Duration) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
-
Configure a Duration
how often to run a scheduled purge task.
- setExpireDurationMillis(long) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
Configure a Duration
(in millis) how often to clean up old orphaned groups from the store.
- setExpireDurationMillis(Long) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setExpireGroupsUponCompletion(boolean) - Method in class org.springframework.integration.aggregator.AggregatingMessageHandler
-
Will set the 'expireGroupsUponCompletion' flag.
- setExpireGroupsUponCompletion(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setExpireGroupsUponTimeout(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
Expire (completely remove) a group if it is completed due to timeout.
- setExpireGroupsUponTimeout(boolean) - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
-
Overridden to false for a resequencer so late messages are immediately discarded rather
than waiting for the next timeout
- setExpireGroupsUponTimeout(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setExpireOnDestroy(boolean) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
Flag to indicate that the stores should be expired when this component is destroyed (i.e.
- setExpireTimeout(long) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
Configure a timeout in milliseconds for purging old orphaned groups from the store.
- setExpireTimeout(Long) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setExpireTimeout(long) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
-
Configure a timeout for old groups in the store to purge.
- setExpiryCallbacks(Collection<MessageGroupStore.MessageGroupCallback>) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
Convenient injection point for expiry callbacks in the message store.
- setExplicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setExplicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Specify whether explicit QoS settings are enabled
(deliveryMode, priority, and timeToLive).
- setExplicitQosEnabledForReplies(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Specify whether explicit QoS should be enabled for replies
(for timeToLive, priority, and deliveryMode settings).
- setExposeCaptureSocket(boolean) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
-
Whether to bind and expose a capture socket for the proxy data.
- setExposedHeaders(String...) - Method in class org.springframework.integration.http.inbound.CrossOrigin
-
- setExposeListenerChannel(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setExposeListenerSession(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setExpression(Expression) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
Set a SpEL expression to use.
- setExpression(String) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
-
Specify an expression to be evaluated against the Message
in order to generate a file name.
- setExpression(String) - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
- setExpression(String) - Method in class org.springframework.integration.jpa.support.JpaParameter
-
- setExpressionString(String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
Set a SpEL expression to use.
- setExtensionProvider(ExtensionElementProvider<? extends ExtensionElement>) - Method in class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
-
Specify an ExtensionElementProvider
to build an ExtensionElement
for the Stanza.addExtension(ExtensionElement)
instead of body
.
- setExtractBody(boolean) - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
-
- setExtractPayload(boolean) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
Set to true to extract the payload and map the headers; otherwise
the entire message is converted and sent.
- setExtractPayload(Boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setExtractPayload(boolean) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Specify whether the outbound message's payload should be extracted
when preparing the request body.
- setExtractPayload(boolean) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
-
The flag to indicate if we should extract
body
from JMS Message,
or use the received JMS Message as
Message
payload
.
- setExtractPayload(boolean) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
Specify whether the payload should be extracted from each integration
Message to be used as the JMS Message body.
- setExtractPayload(boolean) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
Configure this channel adapter to extract or not value from the
Record
.
- setExtractPayload(boolean) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- setExtractPayload(boolean) - Method in class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
-
Set to true
to extract the payload; otherwise
the entire message is sent.
- setExtractPayload(boolean) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
- setExtractPayload(boolean) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
-
- setExtractPayload(boolean) - Method in class org.springframework.integration.ws.SimpleWebServiceInboundGateway
-
- setExtractPayload(boolean) - Method in class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
-
- setExtractPayload(boolean) - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
-
Specify whether the source Message's payload should be extracted prior
to marshalling.
- setExtractPayloadElements(boolean) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Sets the flag signifying that if the payload is a "multivalue" (i.e., Collection or Map),
it should be saved using addAll/putAll semantics.
- setExtractReplyPayload(boolean) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
Specify whether only the reply Message's payload should be passed in the response.
- setExtractReplyPayload(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Specify whether the Spring Integration reply Message's payload should be
extracted prior to converting into a JMS Message.
- setExtractReplyPayload(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
This property describes what to do with a JMS reply Message.
- setExtractRequestPayload(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Specify whether the JMS request Message's body should be extracted prior
to converting into a Spring Integration Message.
- setExtractRequestPayload(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
This property describes how a JMS Message should be generated from the
Spring Integration Message.
- setFailover(boolean) - Method in class org.springframework.integration.channel.DirectChannel
-
Specify whether the channel's dispatcher should have failover enabled.
- setFailover(boolean) - Method in class org.springframework.integration.channel.ExecutorChannel
-
Specify whether the channel's dispatcher should have failover enabled.
- setFailover(boolean) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
-
Specify whether this dispatcher should failover when a single
MessageHandler
throws an Exception.
- setFailureChannel(MessageChannel) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
Set the channel to which to send the
ErrorMessage
after evaluating the
failure expression.
- setFailureChannelName(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
Set the channel name to which to send the
ErrorMessage
after evaluating the
failure expression.
- setFallbackToSystemLocale(boolean) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set whether to fall back to the system Locale if no files for a specific
Locale have been found.
- setFaultMessageResolver(FaultMessageResolver) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setFile(File) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setFile(File) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
The name of the file you wish to tail.
- setFileDelay(Long) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setFileEncodings(Properties) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set per-file charsets to use for parsing properties files.
- setFileExistsMode(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setFileExistsMode(FileExistsMode) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Will set the
FileExistsMode
that specifies what will happen in
case the destination exists.
- setFileExistsMode(FileExistsMode) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Determine the action to take when using GET and MGET operations when the file
already exists locally, or PUT and MPUT when the file exists on the remote
system.
- setFileInfoJson(boolean) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
- setFileName(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
-
- setFileNameExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Set the file name expression to determine the full path to the remote file.
- setFileNameExpression(Expression) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Provide the
FileNameGenerator
strategy to use when generating
the destination file's name.
- setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Set the file name generator used to generate the remote filename to be used when transferring
files to the remote system.
- setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
Set the file name generator used to generate the remote filename to be used when
transferring files to the remote system.
- setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
Set the file name generator used to generate the remote filename to be used when transferring
files to the remote system.
- setFilenamePattern(String) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
-
- setFilenameRegex(String) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
-
- setFileType(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
File types defined by FTP
constants:
FTP.ASCII_FILE_TYPE
FTP.EBCDIC_FILE_TYPE
FTP.BINARY_FILE_TYPE
(DEFAULT)
FTP.LOCAL_FILE_TYPE
- setFileVisitOptions(FileVisitOption...) - Method in class org.springframework.integration.file.RecursiveDirectoryScanner
-
The options to configure the traversal.
- setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
-
- setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
-
- setFilter(FileListFilter<File>) - Method in interface org.springframework.integration.file.DirectoryScanner
-
Sets a custom filter to be used by this scanner.
- setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
- setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.HeadDirectoryScanner
-
- setFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
Set the filter to be applied to the remote files before transferring.
- setFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- setFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Set the filter to be applied to the remote files before transferring.
- setFilter(NotificationFilter) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
- setFilter(CollectionFilter<Resource>) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
-
- setFilterHeadersInToMessage(boolean) - Method in class org.springframework.integration.support.converter.MapMessageConverter
-
- setFilterInRetry(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
The boolean
flag to specify the order how
RetryingMessageListenerAdapter
and
FilteringMessageListenerAdapter
are wrapped to each other,
if both of them are present.
- setFirstLineAsHeader(String) - Method in class org.springframework.integration.file.splitter.FileSplitter
-
Specify the header name for the first line to be carried as a header in the
messages emitted for the remaining lines.
- setFirstResultExpression(Expression) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Set the expression that will be evaluated to get the first result in the query executed.
- setFixedRate(boolean) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
-
Specify whether the periodic interval should be measured between the
scheduled start times rather than between actual completion times.
- setFlush(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setFlushExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Specify a SpEL expression that evaluates to a
Boolean
to determine whether
the producer should be flushed after the send.
- setFlushInterval(long) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setFlushInterval(long) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
- setFlushOnUpdate(boolean) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
-
Determine whether the metadataStore should be flushed on each update (if
Flushable
).
- setFlushPredicate(FileWritingMessageHandler.MessageFlushPredicate) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setFlushPredicate(FileWritingMessageHandler.MessageFlushPredicate) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
- setFlushSize(int) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
If the provided value is greater than
0
, then
EntityManager.flush()
will be called after persistence operations as well as within batch operations.
- setFlushWhenIdle(boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setFlushWhenIdle(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Determine whether the
flushInterval
applies only
to idle files (default) or whether to flush on that interval after the first
write to a previously flushed or new file.
- setForceReleaseAdviceChain(List<Advice>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setForceReleaseAdviceChain(List<Advice>) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setForRecursion(boolean) - Method in class org.springframework.integration.file.filters.AbstractDirectoryAwareFileListFilter
-
Set to true to inform a recursive gateway operation to use the full file path as
the metadata key.
- setFrontendPort(int) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
-
Specify a fixed port for frontend socket of the proxy.
- setFrontendSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
-
Provide a
Consumer
to configure a proxy frontend socket with arbitrary options, like security.
- setFunctions(Map<String, Method>) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
-
- setFuturesChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set the futures channel.
- setFuturesChannelName(String) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set the futures channel name.
- setGatewayType(OutboundGatewayType) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
-
- setGatewayType(OutboundGatewayType) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- setGatherChannel(MessageChannel) - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
-
- setGatherTimeout(long) - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
-
- setGenericMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
- setGlobalMethodMetadata(GatewayMethodMetadata) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setGroupCreatedTime(long) - Method in class org.springframework.integration.mongodb.store.MessageDocument
-
- setGroupId(String) - Method in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
-
Set the group id for the consumer; if not set, the bean name will be used.
- setGroupId(Object) - Method in class org.springframework.integration.mongodb.store.MessageDocument
-
- setGroupTimeoutExpression(Expression) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setGroupTimeoutExpression(Expression) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setHalfOpenAfter(long) - Method in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
-
- setHandback(Object) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
Specify a handback object to provide context to the listener
upon notification.
- setHandler(Object) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setHandlers(List<MessageHandler>) - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- setHandshakeHandler(HandshakeHandler) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
-
- setHandshakeHeaders(WebSocketHttpHeaders) - Method in class org.springframework.integration.stomp.WebSocketStompSessionManager
-
- setHandshakeTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
-
Set the timeout while waiting for handshake data (in seconds).
- setHashMapper(HashMapper<String, ?, ?>) - Method in class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
-
- setHashMapRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
Set the registration id for
HashMap
.
- setHeader(String, Object) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
Set the value for the given header name.
- setHeader(String, Object) - Method in class org.springframework.integration.support.MessageBuilder
-
Set the value for the given header name.
- setHeader(String, Object) - Method in class org.springframework.integration.support.MutableMessageBuilder
-
- setHeaderExpressionMap(Map<String, Map<String, String>>) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
-
- setHeaderExpressions(Map<String, String>) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
-
- setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
-
- setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
Specifies a Map of SpEL expressions to evaluate in order to generate the Message headers.
- setHeaderExpressions(Map<String, HeaderValueMessageProcessor<?>>) - Method in class org.springframework.integration.transformer.ContentEnricher
-
- setHeaderIfAbsent(String, Object) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
Set the value for the given header name only if the header name is not already associated with a value.
- setHeaderIfAbsent(String, Object) - Method in class org.springframework.integration.support.MessageBuilder
-
Set the value for the given header name only if the header name is not already associated with a value.
- setHeaderIfAbsent(String, Object) - Method in class org.springframework.integration.support.MutableMessageBuilder
-
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- setHeaderMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
Set the
HeaderMapper
to use when mapping between HTTP headers and MessageHeaders.
- setHeaderMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Set the
HeaderMapper
to use when mapping between HTTP headers and MessageHeaders.
- setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Provide a
JmsHeaderMapper
implementation to use when
converting between JMS Messages and Spring Integration Messages.
- setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
-
- setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
-
- setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Provide a
JmsHeaderMapper
implementation for mapping the
Spring Integration Message Headers to/from JMS Message properties.
- setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
- setHeaderMapper(KafkaHeaderMapper) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set the header mapper to use.
- setHeaderMapper(HeaderMapper<MimeMessage>) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Set the header mapper; if a header mapper is not provided, the message payload is
a
MimeMessage
, when provided, the headers are mapped and the payload is
the
MimeMessage
content.
- setHeaderMapper(HeaderMapper<MimeMessage>) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setHeaderMapper(HeaderMapper<StompHeaders>) - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
-
- setHeaderMapper(HeaderMapper<StompHeaders>) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
-
- setHeaderMapper(SoapHeaderMapper) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
-
- setHeaderMapper(SoapHeaderMapper) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setHeaderMapper(XmppHeaderMapper) - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
-
- setHeaderMapper(XmppHeaderMapper) - Method in class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
-
- setHeaderName(String) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
-
Specify a custom header name to check for the file name.
- setHeaderNames(String...) - Method in class org.springframework.integration.support.converter.MapMessageConverter
-
- setHeaders(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setHeaders(HttpHeaders) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
-
- setHeadersFunction(Function<MessageGroup, Map<String, Object>>) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
-
- setHeadersFunction(Function<MessageGroup, Map<String, Object>>) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setHeadersLast(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setHeadersMap(Map<String, String>) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
-
- setHeadersMappedLast(boolean) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
When mapping headers for the outbound message, determine whether the headers are
mapped before the message is converted, or afterwards.
- setHeadersMappedLast(boolean) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
When mapping headers for the outbound message, determine whether the headers are
mapped before the message is converted, or afterwards.
- setHeaderType(Class<?>) - Method in class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
-
- setHeaderTypes(Map<String, Class<?>>) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
-
- setHeartBeatMillis(long) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- setHeartbeatTime(long) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
-
- setHost(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setHost(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setHost(String) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Set the host; requires the factory to be stopped.
- setHost(String) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setHost(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
The url of the host you want connect to.
- setHost(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setHostKeyAlias(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Sets the host key alias, used when comparing the host key to the known
hosts list.
- setHttpMessageCacheSize(int) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
-
- setHttpMethod(HttpMethod) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
- setHttpMethodExpression(Expression) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
- setIdExpression(Expression) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setIdleBetweenTries(Duration) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
-
Specify a @link Duration} to sleep between lock record insert/update attempts.
- setIdleConsumerLimit(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setIdleEventInterval(long) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
How often to emit FileTailingMessageProducerSupport.FileTailingIdleEvent
s in milliseconds.
- setIdleEventInterval(long) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
- setIdlePollPeriod(long) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
-
Deprecated.
Set the poll period when messages are not returned.
- setIdlePollPeriod(long) - Method in class org.springframework.integration.aop.SimpleActiveIdleReceiveMessageAdvice
-
Set the poll period when messages are not returned.
- setIdleReplyContainerTimeout(long) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the target timeout for idle containers, in seconds.
- setIdleReplyContainerTimeout(long, TimeUnit) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the target timeout for idle containers.
- setIdleTaskExecutionLimit(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setIdleTaskExecutionLimit(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setIgnoreColumnMetaData(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
For fully supported databases, the underlying
SimpleJdbcCall
can
retrieve the parameter information for the to be invoked Stored Procedure
from the JDBC Meta-data.
- setIgnoreEmptyResponses(boolean) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
Specify whether empty String response payloads should be ignored.
- setIgnoreExpressionFailures(boolean) - Method in class org.springframework.integration.handler.DelayHandler
-
- setIgnoreFailures(boolean) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
-
Specify whether failures for one or more of the handlers should be
ignored.
- setIgnoreFailures(boolean) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
Specify whether failures for one or more of the handlers should be ignored.
- setIgnoreHidden(Boolean) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
-
Specify whether hidden files shall be ignored.
- setIgnoreSendFailures(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- setIgnoreSendFailures(boolean) - Method in class org.springframework.integration.router.AbstractMessageRouter
-
Specify whether send failures for one or more of the recipients should be ignored.
- setImplicit(boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setImplicitChannel(boolean) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- setImportMetadata(AnnotationMetadata) - Method in class org.springframework.integration.config.IntegrationManagementConfiguration
-
- setImportMetadata(AnnotationMetadata) - Method in class org.springframework.integration.jmx.config.IntegrationMBeanExportConfiguration
-
- setInboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setInboundHeaderNames(String...) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Provide the header names that should be mapped from an HTTP request (for inbound
adapters) or HTTP response (for outbound adapters) to a Spring Integration
Message's headers.
- setInboundHeaderNames(String[]) - Method in class org.springframework.integration.stomp.support.StompHeaderMapper
-
- setInboundMessageMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
-
- setInboundPrefix(String) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
-
Specify a prefix to be appended to the integration message header name
for any JMS property that is being mapped into the MessageHeaders.
- setInclusive(boolean) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
Set to true to set the length header to include the length of the header in
addition to the payload.
- setInitialDuration(Duration) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
-
Specify the delay for the initial execution.
- setInitialValue(int) - Method in class org.springframework.integration.codec.kryo.KryoClassListRegistrar
-
Set the initial ID value.
- setInputChannel(MessageChannel) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setInputChannelName(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setIntegrationComponents(Map<Object, String>) - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.transformer.ContentEnricher
-
- setInteractionModel(RSocketInteractionModel) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
-
- setInteractionModelExpression(Expression) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
-
Configure a SpEL expression to evaluate an
RSocketInteractionModel
for the RSocket request type at runtime against a request message.
- setInteractionModels(RSocketInteractionModel...) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
-
- setInterceptor(TcpConnectionInterceptorFactory...) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactoryChain
-
- setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
-
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Set the list of channel interceptors.
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
- setInterceptors(TcpConnectionInterceptorFactory[]) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactoryChain
-
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
-
- setInterceptors(HandshakeInterceptor...) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
-
- setInterceptors(ClientInterceptor...) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setIsFunction(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
Indicates whether a Stored Procedure or a Function is being executed.
- setIterator(boolean) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
-
The
iterator
mode:
true
(default) to return an
Iterator
for splitting
payload
,
false
to return a
List
.
- setJavaMailAuthenticator(Authenticator) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Optional, sets the Authenticator to be used to obtain a session.
- setJavaMailProperties(Properties) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
A new
Session
will be created with these properties (and the JavaMailAuthenticator if provided).
- setJavaMailProperties(Properties) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setJdbcCallOperationsCacheSize(int) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- setJdbcTemplate(JdbcTemplate) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
- setJpaExecutor(JpaExecutor) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- setJpaParameters(List<JpaParameter>) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setJpaQuery(String) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setJsonObjectMapper(JsonObjectMapper<?, ?>) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
-
- setKey(String) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Specifies the key for the Redis store.
- setKeyExpression(Expression) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
-
Configure a SpEL expression to evaluate a cache key at runtime
against a request message.
- setKeyExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Specifies a SpEL Expression to be used to determine the key for the Redis store.
- setKeyExpressionString(String) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
-
Configure an expression in SpEL style to evaluate a cache key at runtime
against a request message.
- setKeyExpressionString(String) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Specifies a SpEL Expression to be used to determine the key for the Redis store.
- setKeyFunction(Function<Message<?>, ?>) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
-
Configure a
Function
to evaluate a cache key at runtime
against a request message.
- setKeyManager(KeyManager) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setKeysGenerated(boolean) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
-
Flag to indicate that the update query is an insert with auto-generated keys,
which will be logged at debug level.
- setKeysGenerated(boolean) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
Flag to indicate that the update query is an insert with auto-generated keys,
which will be logged at debug level.
- setKeyStoreType(String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpSSLContextSupport
-
Set the key store type.
- setKnownHosts(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
- setKnownHostsResource(Resource) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Specifies the filename that will be used for a host key repository.
- setLastModified(long) - Method in interface org.springframework.integration.store.MessageGroup
-
- setLastModified(long) - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- setLastModifiedTime(long) - Method in class org.springframework.integration.mongodb.store.MessageDocument
-
- setLastRead(long) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- setLastReleasedMessageSequenceNumber(int) - Method in interface org.springframework.integration.store.MessageGroup
-
- setLastReleasedMessageSequenceNumber(int) - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- setLastReleasedSequence(int) - Method in class org.springframework.integration.mongodb.store.MessageDocument
-
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in interface org.springframework.integration.store.MessageGroupStore
-
Allows you to set the sequence number of the last released Message.
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- setLazyConnect(boolean) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set to false
to attempt to connect during endpoint start;
default true
, meaning the connection will be attempted
to be established on the arrival of the first message.
- setLazyLoadMessageGroups(boolean) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
- setLazyLoadMessageGroups(boolean) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- setLeaderEventPublisher(LeaderEventPublisher) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- setLeaderEventPublisher(LeaderEventPublisher) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
- setLeaderEventPublisher(LeaderEventPublisher) - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
-
- setLeaveOpen(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
If true, sockets created by this factory will be reused.
- setLeftPush(boolean) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
Specify if PUSH
operation to Redis List should be LPUSH
or RPUSH
.
- setLengthCheck(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
-
- setLengthCheck(boolean) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- setLengthCheck(boolean) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setLevel(LoggingHandler.Level) - Method in class org.springframework.integration.handler.LoggingHandler
-
- setLimitForPeriod(int) - Method in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
-
- setListening(boolean) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setListening(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
- setLoadBalancingStrategy(LoadBalancingStrategy) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
-
- setLobHandler(LobHandler) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Override the
LobHandler
that is used to create and unpack large objects in SQL queries.
- setLobHandler(LobHandler) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
Override the
LobHandler
that is used to create and unpack large objects in SQL queries.
- setLocalAddress(String) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setLocalAddress(String) - Method in interface org.springframework.integration.ip.CommonSocketOptions
-
On a multi-homed system, specifies the ip address of the network interface used to communicate.
- setLocalAddress(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setLocalAddress(String) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
Used on multi-homed systems to enforce the server to listen
on a specific network address instead of all network adapters.
- setLocalAddress(String) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
- setLocalAddress(String) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setLocalDirectory(File) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Specify a directory path where remote files will be transferred to.
- setLocalDirectory(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- setLocalDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Specify a SpEL expression to evaluate the directory path to which remote files will
be transferred.
- setLocalDirectoryExpressionString(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Specify a SpEL expression to evaluate the directory path to which remote files will
be transferred.
- setLocalFilenameGeneratorExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Specify a SpEL expression for local files renaming after downloading.
- setLocalFilenameGeneratorExpression(Expression) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Set an expression used to determine the local file name.
- setLocalFilenameGeneratorExpressionString(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Specify a SpEL expression for local files renaming after downloading.
- setLocalFilenameGeneratorExpressionString(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Set an expression used to determine the local file name.
- setLocalFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
A
FileListFilter
used to determine which files will generate messages
after they have been synchronized.
- setLocker(AbstractFileLockerFilter) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setLocker(FileLocker) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
-
- setLocker(FileLocker) - Method in interface org.springframework.integration.file.DirectoryScanner
-
Sets a custom locker to be used by this scanner.
- setLocker(FileLocker) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
Optional.
- setLockHint(String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
-
Specify a row lock hint for the query in the lock-based operations.
- setLockRegistry(LockRegistry) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setLockRegistry(LockRegistry) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setLockRegistry(LockRegistry) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- setLogExpression(Expression) - Method in class org.springframework.integration.handler.LoggingHandler
-
- setLogExpressionString(String) - Method in class org.springframework.integration.handler.LoggingHandler
-
Set a SpEL expression string to use.
- setLoggerName(String) - Method in class org.springframework.integration.handler.LoggingHandler
-
- setLoggingEnabled(boolean) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
- setLoggingEnabled(boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
- setLoggingEnabled(boolean) - Method in class org.springframework.integration.channel.NullChannel
-
- setLoggingEnabled(boolean) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
-
- setLoggingEnabled(boolean) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- setLoggingEnabled(boolean) - Method in class org.springframework.integration.handler.MessageHandlerSupport
-
- setLoggingEnabled(boolean) - Method in interface org.springframework.integration.support.management.IntegrationManagement
-
Enable logging or not.
- setLookupHost(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setLookupHost(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
If true, DNS reverse lookup is done on the remote ip address.
- setLookupHost(boolean) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setLookupHost(boolean) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setLookupHost(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
-
- setLookupHost(boolean) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- setManagedName(String) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
-
- setManagedName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- setManagedName(String) - Method in class org.springframework.integration.handler.MessageHandlerSupport
-
- setManagedName(String) - Method in interface org.springframework.integration.support.management.IntegrationManagement
-
- setManagedType(String) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
-
- setManagedType(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- setManagedType(String) - Method in class org.springframework.integration.handler.MessageHandlerSupport
-
- setManagedType(String) - Method in interface org.springframework.integration.support.management.IntegrationManagement
-
- setManualAcks(boolean) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
Set the acknowledgment mode to manual.
- setMapInboundDeliveryMode(boolean) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
-
Map the inbound deliveryMode
by using this setter with 'true'.
- setMapInboundExpiration(boolean) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
-
Map the inbound expiration
by using this setter with 'true'.
- setMapInboundPriority(boolean) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
-
Suppress the mapping of inbound priority by using this setter with 'false'.
- setMapKeyExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Sets the expression used as the key for Map and Properties entries.
- setMapKeyExpressionString(String) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Sets the expression used as the key for Map and Properties entries.
- setMapper(MethodArgsMessageMapper) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setMapper(ObjectMapper) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
-
- setMapToPayload(boolean) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
-
- setMarshaller(Marshaller) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
-
- setMaxAge(long) - Method in class org.springframework.integration.http.inbound.CrossOrigin
-
- setMaxAttempts(int) - Method in class org.springframework.integration.handler.DelayHandler
-
Set the maximum number of release attempts for when message release fails.
- setMaxConcurrentConsumers(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMaxConcurrentConsumers(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setMaxDepth(int) - Method in class org.springframework.integration.file.RecursiveDirectoryScanner
-
The maximum number of directory levels to visit.
- setMaxFetchSize(int) - Method in class org.springframework.integration.endpoint.AbstractFetchLimitingMessageSource
-
- setMaxFetchSize(int) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- setMaxFetchSize(int) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setMaxFetchSize(int) - Method in interface org.springframework.integration.support.management.MessageSourceManagement
-
Set the maximum number of objects the source should fetch if it is necessary to
fetch objects.
- setMaxMessageSize(int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
-
The maximum supported message size for this serializer.
- setMaxMessagesPerPoll(long) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setMaxMessagesPerPoll(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
Set the maximum number of messages to receive for each poll.
- setMaxMessagesPerTask(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMaxMessagesPerTask(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setMaxNumberOfResults(int) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Set the max number of results to retrieve from the database.
- setMaxResultsExpression(Expression) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Set the expression for maximum number of results expression.
- setMaxRows(Integer) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
The maximum number of rows to query.
- setMaxRows(int) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
The maximum number of rows to query.
- setMaxSubscribers(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setMaxSubscribers(int) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
-
Specify the maximum number of subscribers supported by the
channel's dispatcher.
- setMaxSubscribers(int) - Method in class org.springframework.integration.channel.DirectChannel
-
Specify the maximum number of subscribers supported by the
channel's dispatcher.
- setMaxSubscribers(int) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
-
Set the maximum subscribers allowed by this dispatcher.
- setMaxSubscribers(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMaxSubscribers(int) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
Specify the maximum number of subscribers supported by the
channel's dispatcher.
- setMaxSubscribers(int) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
Specify the maximum number of subscribers supported by the
channel's dispatcher.
- setMergeWithDefaultConverters(boolean) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Flag which determines if the default converters should be available after
custom converters.
- setMergeWithDefaultConverters(boolean) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
Flag which determines if the default converters should be available after
custom converters.
- setMergeWithDefaultConverters(boolean) - Method in class org.springframework.integration.websocket.outbound.WebSocketOutboundMessageHandler
-
Flag which determines if the default converters should be available after
custom converters.
- setMessage(Message<?>) - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
-
- setMessage(Message<?>) - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
Set the request message (as an alternative to setPayload())
- setMessage(Message<?>) - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
-
- setMessageBuilderFactory(MessageBuilderFactory) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- setMessageBuilderFactory(MessageBuilderFactory) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
-
- setMessageBuilderFactory(MessageBuilderFactory) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setMessageCodec(SockJsMessageCodec) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
-
- setMessageCollectionCallback(MessageCollectionCallback<?>) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Specify the MessageConverter
to convert request and reply to/from Message
.
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
Set a custom MessageConverter
to replace the default
SimpleMessageConverter
.
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Specify the
MessageConverter
to use when trying to convert to
one of this channel's supported datatypes (in order) for a Message whose payload
does not already match.
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Provide a
MessageConverter
implementation to use when
converting between JMS Messages and Spring Integration Messages.
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Provide a
MessageConverter
strategy to use for converting the
Spring Integration request Message into a JMS Message and for converting
the JMS reply Messages back into Spring Integration Messages.
- setMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
-
Set the message converter; must be a RecordMessageConverter
or
BatchMessageConverter
depending on mode.
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
Set the message converter; must be a RecordMessageConverter
or
BatchMessageConverter
depending on mode.
- setMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
-
Set the message converter to replace the default
MessagingMessageConverter
.
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
-
- setMessageConverters(List<HttpMessageConverter<?>>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Set the message body converters to use.
- setMessageConverters(List<HttpMessageConverter<?>>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
- setMessageConverters(List<MessageConverter>) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
Set the message converters to use.
- setMessageConverters(List<MessageConverter>) - Method in class org.springframework.integration.websocket.outbound.WebSocketOutboundMessageHandler
-
Set the message converters to use.
- setMessageFactory(WebServiceMessageFactory) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setMessageGroupFactory(MessageGroupFactory) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
- setMessageGroupFactory(MessageGroupFactory) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
-
- setMessageGroupFactory(MessageGroupFactory) - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
-
- setMessageGroupStore(MessageGroupStore) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
A message group store to expire according the other configurations.
- setMessageHandlingTaskDecorator(MessageHandlingTaskDecorator) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
- setMessageHandlingTaskDecorator(MessageHandlingTaskDecorator) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
-
- setMessageHeadersRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
- setMessageIdEnabled(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMessageKeyExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
- setMessageListener(WebSocketListener) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
-
- setMessageMapper(BytesMessageMapper) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
-
Provide a
BytesMessageMapper
to convert to/from messages when send or receive happens
on the sockets.
- setMessageMapper(InboundMessageMapper<byte[]>) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
-
- setMessageMapper(OutboundMessageMapper<byte[]>) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
-
Provide an
OutboundMessageMapper
to convert a request message into
byte[]
for sending into ZeroMq socket.
- setMessageProcessor(MessageProcessor<T>) - Method in class org.springframework.integration.transformer.HeaderEnricher
-
- setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setMessageRowMapper(MessageRowMapper) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
- setMessageSelector(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMessageSelector(String) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
-
Specify a JMS Message Selector expression to use when receiving Messages.
- setMessageSelector(String) - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- setMessageSender(WebServiceMessageSender) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setMessageSenders(WebServiceMessageSender...) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setMessageStore(MessageGroupStore) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setMessageStore(MessageGroupStore) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setMessageStore(MessageGroupStore) - Method in class org.springframework.integration.handler.DelayHandler
-
Specify the
MessageGroupStore
that should be used to store Messages while
awaiting the delay.
- setMessageTimestampEnabled(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMetadataExpression(Expression) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
-
Specify a SpEL expression to evaluate a metadata for the RSocket request
as Map<Object, MimeType>
against a request message.
- setMetadataMimeType(MimeType) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
-
Configure a
MimeType
for metadata exchanging.
- setMetadataMimeType(MimeType) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
-
- setMetadataStore(MetadataStore) - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
-
- setMetadataStorePrefix(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Specify a prefix for keys in metadata store do not clash with other keys in the shared store.
- setMethod(Method) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
-
- setMethod(RequestMethod...) - Method in class org.springframework.integration.http.inbound.CrossOrigin
-
- setMethodMetadataMap(Map<String, GatewayMethodMetadata>) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setMethodName(String) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setMethodName(String) - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
-
- setMethodName(String) - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
-
- setMethodName(String) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
-
- setMethods(HttpMethod...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
-
- setMinAcksForSuccess(int) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
If acknowledge = true; how many acks needed for success.
- setMinimumTimeoutForEmptyGroups(long) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
By default, when a MessageGroupStoreReaper is configured to expire partial
groups, empty groups are also removed.
- setMinimumTimeoutForEmptyGroups(Long) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setMinSubscribers(int) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
-
- setMinSubscribers(int) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
- setMissingQueuesFatal(Boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
Allows you to provide a custom
MongoConverter
used to assist in deserialization
data read from MongoDb.
- setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
-
Allow you to provide a custom
MongoConverter
used to assist in deserialization
data read from MongoDb.
- setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
-
- setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
-
Allows you to provide custom
MongoConverter
used to assist in serialization
of data written to MongoDb.
- setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
-
Provide a custom
MongoConverter
used to assist in serialization of
data written to MongoDb.
- setMputFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
A
FileListFilter
that runs against the
local file system view when
using
MPUT
command.
- setMultiAccept(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
Set to false to only accept one connection per iteration over the
selector keys.
- setMultipartFileReader(MultipartFileReader<?>) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
-
- setMultipartResolver(MultipartResolver) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
- setMultiSend(boolean) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
If true, and the message payload is an
Iterable
of
Message
, send
the messages in a single invocation of the template (same channel) and optionally
wait for the confirms or die or perform all sends within a transaction (existing or
new).
- setMutableMessageHeadersRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
- setMutableMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
- setMutexTaskExecutor(AsyncTaskExecutor) - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
-
Set an
AsyncTaskExecutor
to use when establishing (and testing) the
connection with Zookeeper.
- setName(String) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setName(String) - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
- setName(String) - Method in class org.springframework.integration.jpa.support.JpaParameter
-
- setName(String) - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
Set the scenario name (optional)
- setNamedQuery(String) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
A named query can either refer to a named JPQL based query or a native SQL
query.
- setNativeOptions(String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setNativeQuery(String) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
You can also use native Sql queries to poll data from the database.
- setNeedClientAuth(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setNeedsTest(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
Set to true to use a temporary listener for just the first incoming message.
- setNetConnectionSupport(TcpNetConnectionSupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setNewFileCallback(BiConsumer<File, Message<?>>) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Set the callback to use when creating new files.
- setNioConnectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setNioHarvestInterval(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
How often we clean up closed NIO connections if soTimeout is 0.
- setNioHarvestInterval(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setNodeMapper(NodeMapper<?>) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
-
Set a
NodeMapper
to use for generating the result object.
- setNoReadErrorOnClose(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- setNotificationMapper(OutboundMessageMapper<Notification>) - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
-
Set a mapper for creating Notifications from a Message.
- setNotificationPublisher(NotificationPublisher) - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler.PublisherDelegate
-
- setNotPropagatedHeaders(String...) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- setNotPropagatedHeaders(String...) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
Set header patterns ("xxx*", "*xxx", "*xxx*" or "xxx*yyy")
that will NOT be copied from the inbound message if
shouldCopyRequestHeaaders
is true.
- setNotPropagatedHeaders(String...) - Method in interface org.springframework.integration.handler.HeaderPropagationAware
-
Set headers that will NOT be copied from the inbound message if
the handler is configured to copy headers.
- setNotPropagatedHeaders(String...) - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
-
Set headers that will NOT be copied from the inbound message if
the handler is configured to copy headers.
- setNullResultHeaderExpressions(Map<String, HeaderValueMessageProcessor<?>>) - Method in class org.springframework.integration.transformer.ContentEnricher
-
- setNullResultPropertyExpressions(Map<String, Expression>) - Method in class org.springframework.integration.transformer.ContentEnricher
-
- setObject(Object) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
-
- setObjectMapper(ObjectMapper) - Method in class org.springframework.integration.json.JsonPropertyAccessor
-
- setObjectName(String) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
-
Specify the String value of the JMX MBean's
ObjectName
.
- setObjectName(ObjectName...) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
Specify the JMX ObjectNames (or patterns)
of the notification publisher
to which this notification listener should be subscribed.
- setObjectName(String) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
-
Specify a default ObjectName to use when no such header is
available on the Message being handled.
- setObjectNameStaticProperties(Map<String, String>) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
Static properties that will be added to all object names.
- setOnFailureExpression(Expression) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
Set the expression to evaluate against the root message after a failed
handler invocation.
- setOnFailureExpressionString(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
Set the expression to evaluate against the root message after a failed
handler invocation.
- setOnPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
-
Specify a
BiConsumer
for seeks management during
ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)
call from the
KafkaMessageListenerContainer
.
- setOnPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
Specify a
BiConsumer
for seeks management during
ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)
call from the
KafkaMessageListenerContainer
.
- setOnSuccessExpression(Expression) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
Set the expression to evaluate against the message after a successful
handler invocation.
- setOnSuccessExpressionString(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
Set the expression to evaluate against the message after a successful
handler invocation.
- setOperationName(String) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
-
Specify an operation name to be invoked when no such
header is available on the Message being handled.
- setOption(AbstractRemoteFileOutboundGateway.Option...) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Specify the array of options for various gateway commands.
- setOptions(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Specify the options for various gateway commands as a space-delimited string.
- setOptions(String) - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
-
- setOptions(ChangeStreamOptions) - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
-
- setOrder(int) - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
-
- setOrder(Integer) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
Set the order in which the handler will be subscribed to its channel
(when subscribable).
- setOrder(int) - Method in interface org.springframework.integration.context.Orderable
-
Set the order for this component.
- setOrder(int) - Method in class org.springframework.integration.handler.MessageHandlerSupport
-
- setOrigin(String...) - Method in class org.springframework.integration.http.inbound.CrossOrigin
-
- setOrigin(String) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
-
- setOutboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setOutboundHeaderNames(String...) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Provide the header names that should be mapped to an HTTP request (for outbound adapters)
or HTTP response (for inbound adapters) from a Spring Integration Message's headers.
- setOutboundHeaderNames(String[]) - Method in class org.springframework.integration.stomp.support.StompHeaderMapper
-
- setOutboundMessageMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
-
- setOutboundPrefix(String) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
-
Specify a prefix to be appended to the JMS property name for any
integration message header that is being mapped into the JMS Message.
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
Set the handler's output channel.
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setOutputChannel(MessageChannel) - Method in interface org.springframework.integration.core.MessageProducer
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setOutputChannelIfPresent(List<Annotation>, AbstractReplyProducingMessageHandler) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- setOutputChannelName(String) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
Set the handler's output channel name.
- setOutputChannelName(String) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setOutputChannelName(String) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setOutputChannelName(String) - Method in interface org.springframework.integration.core.MessageProducer
-
Specify the bean name of the
MessageChannel
to which produced Messages should be sent.
- setOutputChannelName(String) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
Set the output channel name; overrides
outputChannel
if provided.
- setOutputChannelName(String) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- setOutputChannelName(String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setOutputChannelName(String) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
- setOutputChannelName(String) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- setOutputProcessor(MessageGroupProcessor) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setOutputProperties(Properties) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
-
A set of output properties that will be
used to override any of the same properties in affect
for the transformation.
- setOutputProperties(Properties) - Method in class org.springframework.integration.xml.transformer.ResultToStringTransformer
-
- setOverride(Trigger) - Method in class org.springframework.integration.util.CompoundTrigger
-
Set the override trigger; set to null to revert to using the
primary trigger.
- setOverwrite(Boolean) - Method in class org.springframework.integration.transformer.support.AbstractHeaderValueMessageProcessor
-
- setOverwrite(Boolean) - Method in class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
-
- setPacketDeserializer(Deserializer<byte[]>) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
-
A
Deserializer
that will construct the full JSON content from
the stream which is then passed to the JsonObjectMapper.
- setPacketSerializer(Serializer<byte[]>) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
-
A
Serializer
that will delimit the full JSON content in
the stream.
- setParameterExpressions(Map<String, String>) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
-
Optionally maps parameter names to explicit expressions.
- setParameters(List<JpaParameter>) - Method in class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
-
Define the (optional) parameter values.
- setParameterSource(ParameterSource) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Specify the
ParameterSource
that would be used to provide
additional parameters.
- setParameterSourceFactory(ParameterSourceFactory) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setParams(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setParser(RFC5424SyslogParser) - Method in class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
-
- setParserConfiguration(SpelParserConfiguration) - Method in class org.springframework.integration.config.ExpressionFactoryBean
-
- setPartitionIdExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
- setPassword(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setPassword(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
The password to authenticate against the remote host.
- setPassword(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setPath(String) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
- setPathPatterns(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setPattern(String) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
-
- setPattern(Pattern) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
-
- setPatternMatch(boolean) - Method in class org.springframework.integration.transformer.HeaderFilter
-
- setPatternResolver(ResourcePatternResolver) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
-
- setPatterns(String[]) - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
-
- setPayload(Object) - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
set the payload of the request message
- setPayloadAsBytes(boolean) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
True if the converter should not convert the message payload to a String.
- setPayloadExpression(String) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
-
- setPayloadExpression(Expression) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
-
- setPayloadExpression(Expression) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- setPayloadExpression(Expression) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
Specifies a SpEL expression to evaluate in order to generate the Message payload.
- setPayloadExpression(Expression) - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
-
Specify a SpEL expression to evaluate a payload
against an incoming
Message
.
- setPayloadExpressionString(String) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
-
- setPayloadType(Class<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
-
When using a type-aware message converter (such as StringJsonMessageConverter
,
set the payload type the converter should create.
- setPayloadType(Class<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
When using a type-aware message converter (such as StringJsonMessageConverter
,
set the payload type the converter should create.
- setPayloadType(Class<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
-
Set the payload type.
- setPayloadType(Class<?>) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
-
Set the type of the entityClass which is used for the EntityRowMapper
.
- setPayloadType(Class<?>) - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
-
- setPayloadType(JavaType) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
-
- setPayloadType(Class<?>) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
Set the type for target message payload to convert the WebSocket message body to.
- setPermissions(File) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Set permissions on newly written files.
- setPersistence(MqttClientPersistence) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
-
Set the persistence to pass into the client constructor.
- setPersistMode(PersistMode) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setPhase(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
- setPhase(int) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
- setPhase(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
-
Set the phase.
- setPhase(int) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- setPhase(int) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
- setPhase(int) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- setPhase(int) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
-
- setPhase(int) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
-
- setPhase(int) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
-
- setPhase(int) - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
-
- setPhase(int) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
-
- setPipeTimeout(long) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- setPollerMetadata(PollerMetadata) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setPollerMetadata(PollerMetadata) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setPollingDelay(long) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
-
The delay between checks of the file for new content in milliseconds.
- setPoolSize(int) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
-
Modify the target session pool size; the actual pool size will adjust up/down
to this size as and when sessions are requested or retrieved.
- setPoolSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setPoolSize(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setPoolSize(int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
-
Set the pool size for deserialization buffers.
- setPoolSize(int) - Method in class org.springframework.integration.util.SimplePool
-
Adjusts the current pool size.
- setPoolWaitTimeout(long) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
-
Set the pool wait timeout if a pool is configured, default unlimited.
- setPopSequence(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setPopSequence(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setPort(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setPort(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setPort(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Set the port; requires the factory to be stopped.
- setPort(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setPort(int) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
The port over which the SFTP connection shall be established.
- setPort(int) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setPort(int) - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
-
Sets the port on which the adapter listens; default is 514; note that
the RFC does not specify a well known port for TCP; 514 is the well-known
port for UDP.
- setPort(int) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setPostProcessWithinAdvice(boolean) - Method in class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
-
Specify whether the post processing should occur within
the scope of any configured advice classes.
- setPrefetchCount(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setPrefix(String) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
-
Specify the prefix to use for temporary files.
- setPrefix(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Specify the prefix for target data base table used from queries.
- setPrefix(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Specify a prefix to be added to each channel name prior to resolution.
- setPreparedStatementSetter(MessagePreparedStatementSetter) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
-
- setPreparedStatementSetter(ChannelMessageStorePreparedStatementSetter) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
- setPreserveTimestamp(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setPreserveTimestamp(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Set to true to preserve the destination file timestamp.
- setPreserveTimestamp(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Set to true to enable the preservation of the remote file timestamp when
transferring.
- setPreserveWireFeed(boolean) - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
-
Specify a flag to indication if WireFeed
should be preserved in the target SyndFeed
.
- setPreventDuplicates(Boolean) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
-
- setPrimary(Trigger) - Method in class org.springframework.integration.util.CompoundTrigger
-
Set the primary trigger.
- setPrimaryExpression(Expression) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
For expression-based components, set the primary expression.
- setPriority(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setPriority(Integer) - Method in class org.springframework.integration.mongodb.store.MessageDocument
-
- setPriority(boolean) - Method in class org.springframework.integration.store.MessageGroupQueue
-
If true, ensures that the message store supports priority.
- setPriority(Integer) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
- setPriority(Integer) - Method in class org.springframework.integration.support.MessageBuilder
-
- setPriorityEnabled(boolean) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
- setPriorityEnabled(boolean) - Method in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
-
- setPrivateKey(Resource) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Allows you to set a
Resource
, which represents the location of the
private key used for authenticating against the remote host.
- setPrivateKeyPassphrase(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
The password for the private key.
- setProcedureParameters(List<ProcedureParameter>) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
Custom Stored Procedure parameters that may contain static values
or Strings representing an
Expression
.
- setProcessorBean(Object) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setProducerRecordCreator(KafkaProducerMessageHandler.ProducerRecordCreator<K, V>) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
- setProduces(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setProducesReply(boolean) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
-
If set to 'false', this component will act as an Outbound Channel Adapter.
- setProducesReply(boolean) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- setPropagateEvaluationFailures(boolean) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
If true and an onSuccess expression evaluation fails with an exception, the
exception will be thrown to the caller.
- setPropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
Set a custom MessagePropertiesConverter
to replace the default
DefaultMessagePropertiesConverter
.
- setPropertiesPersister(PropertiesPersister) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set the PropertiesPersister to use for parsing properties files.
- setPropertyAccessors(Map<String, PropertyAccessor>) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
-
- setPropertyExpressions(Map<String, Expression>) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Provide the map of expressions to evaluate when enriching the target payload.
- setProt(String) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setProtocol(String) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setProtocol(String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpSSLContextSupport
-
- setProtocol(String) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- setProtocol(String) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setProtocols(String[]) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setProxy(Proxy) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Allows for specifying a JSch-based Proxy
.
- setProxyDefaultMethods(boolean) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Indicate if default
methods on the interface should be proxied as well.
- setProxyExecutor(Executor) - Method in class org.springframework.integration.zeromq.ZeroMqProxy
-
Configure an executor to perform a ZeroMQ proxy loop.
- setPublisherElementType(Class<?>) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
-
Configure a type for a request Publisher
elements.
- setPublisherElementType(Class<?>) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
-
Configure a type for a request Publisher
elements.
- setPublisherElementTypeExpression(Expression) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
-
Configure a SpEL expression to evaluate a request Publisher
elements type at runtime against
a request message.
- setPublisherElementTypeExpression(Expression) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
-
Configure a SpEL expression to evaluate a request Publisher
elements type at runtime against
a request message.
- setPublishFailedEvents(boolean) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
Enable or disable the publishing of failed events to the
specified applicationEventPublisher.
- setPublishPayload(boolean) - Method in class org.springframework.integration.event.outbound.ApplicationEventPublishingMessageHandler
-
Specify if
payload
should be published as is
or the whole
message
must be wrapped to the
MessagingEvent
.
- setPubSub(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setPubSubDomain(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setPubSubNoLocal(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setPushbackBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionSupport
-
The size of the push back buffer; defaults to 1.
- setPushbackCapable(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionSupport
-
Set to true to cause wrapping of the connection's input stream in a
PushbackInputStream
, enabling deserializers to "unread" data.
- setQos(int...) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
-
Set the QoS for each topic; a single value will apply to all topics otherwise
the correct number of qos values must be provided.
- setQosExpression(Expression) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
Set the qos expression; default "headers['mqtt_qos']".
- setQosExpressionString(String) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
Set the qos expression; default "headers['mqtt_qos']".
- setQueryExpression(String) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
-
- setQueryExpression(Expression) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
-
- setQueryExpressionReference(QueryExp) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
-
- setQueryExpressionString(String) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
-
- setQueryName(String) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
-
- setQueryName(String) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
-
- setQueryNameReference(ObjectName) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
-
- setQueryType(R2dbcMessageHandler.Type) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
-
- setQueryTypeExpression(Expression) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
-
- setQueueName(String) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
-
Provide a Queue name to be used.
- setQueueName(String) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
Provide an explicitly configured queue name.
- setQueueName(String) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
Set the Queue name to use.
- setQueueSize(Integer) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setRawBytes(boolean) - Method in class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
-
For messages with byte[]
payloads, if rendered as JSON, Jackson performs
Base64 conversion on the bytes.
- setRawMessageHeader(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
- setRawMessageHeader(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
-
- setReactiveAdapterRegistry(ReactiveAdapterRegistry) - Method in class org.springframework.integration.webflux.inbound.WebFluxInboundEndpoint
-
A registry of adapters to adapt a Reactive Streams Publisher
to/from.
- setReadDelay(long) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setReadDelay(long) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
The delay (in milliseconds) before retrying a read after the previous attempt
failed due to insufficient threads.
- setReadDelay(long) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setReadOffset(ReadOffset) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
Define the offset from which we want to read message.
- setReadOnlyHeaders(String...) - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
-
Specify a list of headers which should be considered as read only and prohibited
from being populated in the message.
- setReadOnlyHeaders(String...) - Method in class org.springframework.integration.support.DefaultMessageBuilderFactory
-
Specify a list of headers which should be considered as a read only
and prohibited from the population to the message.
- setReaperDelay(long) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
Set the reaper delay.
- setReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setReceiveMessageSource(Object) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setReceiveMessageSource(Object) - Method in class org.springframework.integration.endpoint.PollingConsumer
-
- setReceiveMessageSource(Object) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- setReceiveRaw(boolean) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
-
Whether raw
ZMsg
is present as a payload of message to produce or
it is fully converted to a
Message
including
ZeroMqHeaders.TOPIC
header (if any).
- setReceiveTimeout(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setReceiveTimeout(long) - Method in class org.springframework.integration.endpoint.PollingConsumer
-
- setReceiveTimeout(long) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setReceiveTimeout(long) - Method in class org.springframework.integration.jms.DynamicJmsTemplate
-
- setReceiveTimeout(Long) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setReceiveTimeout(long) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the max timeout value for the MessageConsumer's receive call when
waiting for a reply.
- setReceiveTimeout(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- setReceiveTimeout(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- setReceiveTimeout(int) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
-
- setReceiveTimeout(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setRecipientMappings(Map<String, String>) - Method in class org.springframework.integration.router.RecipientListRouter
-
Set the recipients for this router.
- setRecipientMappings(Map<String, String>) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
-
Set recipients.
- setRecipients(List<RecipientListRouter.Recipient>) - Method in class org.springframework.integration.router.RecipientListRouter
-
Set the recipients for this router.
- setReconnectDelay(long) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
The time between connection attempts in milliseconds (default 10 seconds).
- setRecordFilterStrategy(RecordFilterStrategy<K, V>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
Specify a RecordFilterStrategy
to wrap
KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener
into
FilteringMessageListenerAdapter
.
- setRecordMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
Set the message converter to use with a record-based consumer.
- setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
Set a RecoveryCallback
when using retry within the adapter.
- setRecoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Set a RecoveryCallback
when using retry within the gateway.
- setRecoveryCallback(RecoveryCallback<Object>) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
-
A RecoveryCallback
instance for retry operation;
if null, the exception will be thrown to the container after retries are exhausted
(unless an error channel is configured).
- setRecoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
A RecoveryCallback
instance for retry operation;
if null, the exception will be thrown to the container after retries are exhausted
(unless an error channel is configured).
- setRecoveryInterval(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setRecoveryInterval(long) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setRecoveryInterval(Long) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setRecoveryInterval(int) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
The time (ms) to wait between reconnection attempts.
- setRecoveryInterval(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- setRecoveryInterval(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- setRecoveryInterval(int) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
Specify a reconnect interval in milliseconds in case of lost connection.
- setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Configures the provided bean definition builder with a property reference to a bean.
- setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Configures the provided bean definition builder with a property reference to a bean.
- setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- setRefreshSharedInterval(long) - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
When using a shared connection
singleUse
is false,
specify how long to wait before trying to fail back to start from the beginning of
the factory list.
- setRegion(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
A unique grouping identifier for all locks persisted with this store.
- setRegion(String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
-
A unique grouping identifier for all messages persisted with this store.
- setRegion(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
A unique grouping identifier for all messages persisted with this store.
- setRegion(String) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
A unique grouping identifier for all messages persisted with this store.
- setRegistryHost(String) - Method in class org.springframework.integration.rmi.RmiInboundGateway
-
Deprecated.
- setRegistryPort(int) - Method in class org.springframework.integration.rmi.RmiInboundGateway
-
Deprecated.
- setReleaseLockBeforeSend(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
Set to true to release the message group lock before sending any output.
- setReleaseLockBeforeSend(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setReleasePartialSequences(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setReleasePartialSequences(boolean) - Method in class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
-
Flag that determines if partial sequences are allowed.
- setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
-
Set the ReleaseStrategy that should be used when deciding if a group in this barrier may be released.
- setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setReliabilityAttributes(boolean, boolean, String, int, int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setRemoteDirectory(String) - Method in class org.springframework.integration.file.remote.AbstractFileInfo
-
- setRemoteDirectory(String) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
Specify the full path to the remote directory.
- setRemoteDirectory(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Specify the full path to the remote directory.
- setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
Specify an expression that evaluates to the full path to the remote directory.
- setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Set the remote directory expression used to determine the remote directory to which
files will be sent.
- setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
Specify a remote directory path SpEL expression.
- setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
Set the remote directory expression used to determine the remote directory to which
files will be sent.
- setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Specify an expression that evaluates to the full path to the remote directory.
- setRemoteDirectoryExpressionString(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
Specify a remote directory path SpEL expression.
- setRemoteDirectoryExpressionString(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Specify an expression that evaluates to the full path to the remote directory.
- setRemoteFileMetadataStore(MetadataStore) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Configure a
MetadataStore
to hold a remote file info (host, port, remote directory)
to transfer downstream in message headers when local file is pulled.
- setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
Set the remote file separator; default '/'
- setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Set the file separator when dealing with remote files; default '/'.
- setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
Specify a remote file separator symbol.
- setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
Set the file separator when dealing with remote files; default '/'.
- setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- setRemoteInvocationExecutor(RemoteInvocationExecutor) - Method in class org.springframework.integration.rmi.RmiInboundGateway
-
Deprecated.
- setRemoteTimeout(long) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- setRemoteTimeoutExpression(Expression) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- setRemoveBatchSize(int) - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
-
Set the batch size when bulk removing messages from groups for message stores
that support batch removal.
- setRemoveMessage(boolean) - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
-
- setRemoveOnGet(boolean) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- setRenameExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Specify a SpEL expression for files renaming during transfer.
- setRenameExpressionString(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Specify a SpEL expression for files renaming during transfer.
- setReopen(Boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setReopen(boolean) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
-
If true, close and reopen the file between reading chunks;
default false.
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
-
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set the reply channel.
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
Specify the Spring Integration reply channel.
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Specify the Spring Integration reply channel.
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.rmi.RmiOutboundGateway
-
Deprecated.
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.support.MessageBuilder
-
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Sets the content enricher's reply channel.
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setReplyChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
-
- setReplyChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- setReplyChannelName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set the reply channel name.
- setReplyChannelName(String) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
Specify the Spring Integration reply channel name.
- setReplyChannelName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setReplyChannelName(String) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- setReplyChannelName(String) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
- setReplyChannelName(String) - Method in class org.springframework.integration.support.MessageBuilder
-
- setReplyChannelName(String) - Method in class org.springframework.integration.transformer.ContentEnricher
-
- setReplyContainerProperties(JmsOutboundGateway.ReplyContainerProperties) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- setReplyDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Specify the delivery mode for JMS reply Messages.
- setReplyDestination(Destination) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the JMS Destination from which reply Messages should be received.
- setReplyDestinationExpression(Expression) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the SpEL Expression to be used for determining the reply Destination instance
or reply destination name.
- setReplyDestinationName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the name of the JMS Destination from which reply Messages should be received.
- setReplyHeaderNames(String...) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
Provide the header names that should be mapped to a response
from a
MessageHeaders
.
- setReplyHeadersMappedLast(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
When mapping headers for the outbound (reply) message, determine whether the headers are
mapped before the message is converted, or afterwards.
- setReplyKey(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
- setReplyMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Provide an
OutboundMessageMapper
for mapping to objects from
any reply Messages received in receive or sendAndReceive operations.
- setReplyMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set a message converter for gateway replies.
- setReplyPayloadToFlux(boolean) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
-
The boolean flag to identify if the reply payload should be as a Flux
from the response body
or as resolved value from the Mono
of the response body.
- setReplyPayloadType(Type) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
When using a type-aware message converter (such as StringJsonMessageConverter
,
set the payload type the converter should create.
- setReplyPriority(int) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Specify the priority value for JMS reply Messages.
- setReplyPubSubDomain(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Specify whether the reply destination is a Topic.
- setReplySqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
- setReplyTimeout(Long) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
-
- setReplyTimeout(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- setReplyTimeout(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set the timeout value for receiving reply messages.
- setReplyTimeout(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setReplyTimeout(long) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- setReplyTimeout(long) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
Specifies the time the gateway will wait to send the result to the reply channel.
- setReplyTimeout(Long) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Set the timeout value for receiving reply messages.
- setReplyTimeToLive(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Specify the time-to-live property for JMS reply Messages.
- setRequestCallback(WebServiceMessageCallback) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
-
- setRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set the request channel.
- setRequestChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setRequestChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- setRequestChannel(MessageChannel) - Method in class org.springframework.integration.rmi.RmiInboundGateway
-
Deprecated.
Specify the request channel where messages will be sent.
- setRequestChannel(MessageChannel) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Sets the content enricher's request channel.
- setRequestChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
-
- setRequestChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- setRequestChannelName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set the request channel name.
- setRequestChannelName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setRequestChannelName(String) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- setRequestChannelName(String) - Method in class org.springframework.integration.rmi.RmiInboundGateway
-
Deprecated.
- setRequestChannelName(String) - Method in class org.springframework.integration.transformer.ContentEnricher
-
- setRequestDestination(Destination) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the JMS Destination to which request Messages should be sent.
- setRequestDestinationExpression(Expression) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the SpEL Expression to be used for determining the request Destination instance
or request destination name.
- setRequestDestinationName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the name of the JMS Destination to which request Messages should be sent.
- setRequestedContentTypeResolver(RequestedContentTypeResolver) - Method in class org.springframework.integration.webflux.inbound.WebFluxInboundEndpoint
-
A strategy to resolve the requested media types for a ServerWebExchange
.
- setRequestElementClass(Class<?>) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
-
Specify a type of payload to be generated when the inbound RSocket request
content is read by the encoders.
- setRequestElementType(ResolvableType) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
-
Specify the type of payload to be generated when the inbound RSocket request
content is read by the converters/encoders.
- setRequestFactory(ClientHttpRequestFactory) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
- setRequestHeaderNames(String...) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
Provide the header names that should be mapped from a request
to a
MessageHeaders
.
- setRequestMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Provide an
InboundMessageMapper
for creating request Messages
from any object passed in a send or sendAndReceive operation.
- setRequestMapping(RequestMapping) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
Set the
RequestMapping
which allows you to specify a flexible RESTFul-mapping for this endpoint.
- setRequestPayloadExpression(Expression) - Method in class org.springframework.integration.transformer.ContentEnricher
-
By default the original message's payload will be used as the actual payload that
will be send to the request-channel.
- setRequestPayloadType(ResolvableType) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
Specify the type of payload to be generated when the inbound HTTP request
content is read by the converters/encoders.
- setRequestPayloadTypeClass(Class<?>) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
Specify the type of payload to be generated when the inbound HTTP request
content is read by the converters/encoders.
- setRequestPreparedStatementSetter(MessagePreparedStatementSetter) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
- setRequestPubSubDomain(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Specify whether the request destination is a Topic.
- setRequestSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
- setRequestTimeout(Long) - Method in class org.springframework.integration.gateway.GatewayMessageHandler
-
- setRequestTimeout(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- setRequestTimeout(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set the timeout value for sending request messages.
- setRequestTimeout(long) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- setRequestTimeout(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setRequestTimeout(long) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- setRequestTimeout(Long) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Set the timeout value for sending request messages.
- setRequiresReply(Boolean) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
- setRequiresReply(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setRequiresReply(boolean) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
Flag whether a reply is required.
- setRequiresReply(boolean) - Method in class org.springframework.integration.jdbc.StoredProcOutboundGateway
-
- setRequiresReply(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- setRequiresReply(boolean) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- setResolutionRequired(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- setResolutionRequired(boolean) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Specify whether this router should ignore any failure to resolve a channel name to
an actual MessageChannel instance when delegating to the ChannelResolver strategy.
- setResource(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setResourceLoader(ResourceLoader) - Method in class org.springframework.integration.config.IntegrationComponentScanRegistrar
-
- setResourceLoader(ResourceLoader) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set the ResourceLoader to use for loading bundle properties files.
- setResponseValidator(AbstractResponseValidator<?>) - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
Set the response validator
- setResultFactory(ResultFactory) - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
-
- setResultFactory(ResultFactory) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
Sets the ResultFactory.
- setResultFactoryName(String) - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
-
- setResultFactoryName(String) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
- setResultType(String) - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
-
- setResultType(String) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
- setRetainedExpression(Expression) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
Set the retained expression; default "headers['mqtt_retained']".
- setRetainedExpressionString(String) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
Set the retained expression; default "headers['mqtt_retained']".
- setRetryDelay(long) - Method in class org.springframework.integration.handler.DelayHandler
-
Set an additional delay to apply when retrying after a release failure.
- setRetryInterval(long) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
Configure a retry interval.
- setRetryInterval(long) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- setRetryInterval(long) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- setRetryStateGenerator(RetryStateGenerator) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
Set a RetryTemplate
to use for retrying a message delivery within the
adapter.
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Set a RetryTemplate
to use for retrying a message delivery within the
gateway.
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
Set the retry template.
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
-
Specify a RetryTemplate
instance to wrap
KafkaInboundGateway.IntegrationRecordMessageListener
into
RetryingMessageListenerAdapter
.
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
Specify a RetryTemplate
instance to wrap
KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener
into
RetryingMessageListenerAdapter
.
- setReturnChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set the channel to which returned messages are sent.
- setReturned(ReturnedMessage) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint.CorrelationDataWrapper
-
- setReturnedMessage(Message) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint.CorrelationDataWrapper
-
Deprecated.
- setReturnFailureExpressionResult(boolean) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
If true, the result of evaluating the onFailureExpression will
be returned as the result of AbstractReplyProducingMessageHandler.handleRequestMessage(Message).
- setReturningResultSetRowMappers(Map<String, RowMapper<?>>) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
If the Stored Procedure returns ResultSets you may provide a map of
RowMapper
to convert the
ResultSet
to meaningful objects.
- setReturnValueRequired(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
Indicates the procedure's return value should be included in the results
returned.
- setRightPop(boolean) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
Specify if POP
operation from Redis List should be BRPOP
or BLPOP
.
- setRole(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setRole(String) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setRole(String) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
Specify the role for the endpoint.
- setRole(String) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
- setRolledBack(boolean) - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
-
- setRolledBack(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
-
- setRoot(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
-
Root node - store entries are children of this node.
- setRoutingKey(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Configure an AMQP routing key for sending messages.
- setRoutingKeyExpression(Expression) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- setRoutingKeyExpressionString(String) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- setRowMapper(RowMapper<?>) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
- setRowMapper(RowMapper<?>) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
- setRSocketConnector(AbstractRSocketConnector) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
-
- setRSocketStrategies(RSocketStrategies) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
-
- setRSocketStrategies(RSocketStrategies) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
-
- setRSocketStrategies(RSocketStrategies) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
-
- setScanEachPoll(Boolean) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setScanEachPoll(boolean) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
Optional.
- setScanner(DirectoryScanner) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setScanner(DirectoryScanner) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
Optionally specify a custom scanner, for example the
WatchServiceDirectoryScanner
- setScanner(DirectoryScanner) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- setSearchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setSearchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.mail.ImapMailReceiver
-
- setSecondChanceDelay(int) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
When using NIO and the server closes the socket after sending the reply,
an error message representing the close may appear before the reply.
- setSelectorExpression(Expression) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- setSelectorExpression(Expression) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setSelectors(List<MessageSelector>) - Method in class org.springframework.integration.selector.MessageSelectorChain
-
Initialize the selector chain.
- setSelectQuery(String) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
Set the select query.
- setSelectSqlParameterSource(SqlParameterSource) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
A source of parameters for the select query used for polling.
- setSendBufferSizeLimit(int) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
-
- setSendFailureChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set the failure channel.
- setSendFailureChannelName(String) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set the failure channel name.
- setSendingTaskExecutor(Executor) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
Specify an
Executor
used to send messages received by the
adapter.
- setSendPartialResultOnExpiry(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setSendPartialResultOnExpiry(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setSendSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
-
The
Consumer
callback to configure a publishing socket.
- setSendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set the success channel.
- setSendSuccessChannelName(String) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set the Success channel name.
- setSendTimeLimit(int) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
-
- setSendTimeout(Long) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
- setSendTimeout(Long) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setSendTimeout(Long) - Method in class org.springframework.integration.config.ExpressionControlBusFactoryBean
-
- setSendTimeout(long) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setSendTimeout(long) - Method in class org.springframework.integration.core.ErrorMessagePublisher
-
- setSendTimeout(long) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
Configure the default timeout value to use for send operations.
- setSendTimeout(long) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
Specify the maximum time to wait for a Message to be sent to the
output channel.
- setSendTimeout(Long) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setSendTimeout(Long) - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
-
- setSendTimeout(long) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
Set the timeout for sending reply Messages.
- setSendTimeout(long) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- setSendTimeout(long) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
- setSendTimeout(long) - Method in class org.springframework.integration.router.AbstractMessageRouter
-
Set the timeout for sending a message to the resolved channel.
- setSendTimeout(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setSendTimeout(long) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setSendTimeoutExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Specify a SpEL expression to evaluate a timeout in milliseconds for how long this
KafkaProducerMessageHandler
should wait wait for send operation results.
- setSequence(long) - Method in class org.springframework.integration.mongodb.store.MessageDocument
-
- setSequenceNumber(Integer) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
- setSequenceNumber(Integer) - Method in class org.springframework.integration.support.MessageBuilder
-
- setSequenceSize(Integer) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
- setSequenceSize(Integer) - Method in class org.springframework.integration.support.MessageBuilder
-
- setSerializationContext(RedisSerializationContext<String, ?>) - Method in class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
-
- setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setSerializer(Serializer<? super Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
A converter for serializing messages to byte arrays for storage.
- setSerializer(Serializer<? super Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
A converter for serializing messages to byte arrays for storage.
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
-
- setSerializer(Serializer<Object>) - Method in class org.springframework.integration.transformer.PayloadSerializingTransformer
-
- setServer(MBeanServerConnection) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
-
Provide the MBeanServer where the JMX MBean has been registered.
- setServer(MBeanServerConnection) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
-
Provide the MBeanServer where the JMX MBean has been registered.
- setServer(MBeanServerConnection) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
Provide a reference to the MBeanServer where the notification
publishing MBeans are registered.
- setServerAliveCountMax(Integer) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Specifies the number of server-alive messages, which will be sent without
any reply from the server before disconnecting.
- setServerAliveInterval(Integer) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Sets the timeout interval (milliseconds) before a server alive message is
sent, in case no message is received from the server.
- setServerConfigurer(Consumer<RSocketServer>) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
-
Provide a
Consumer
to configure the
RSocketServer
.
- setServiceName(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setSession(Session) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- setSession(Session) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setSessionAcknowledgeMode(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setSessionAcknowledgeMode(String) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
-
- setSessionAcknowledgeMode(String) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
Set the session acknowledge mode on the listener container.
- setSessionAcknowledgeMode(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setSessionAcknowledgeModeName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setSessionConfig(Properties) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Using
Properties
, you can set additional configuration settings on
the underlying JSch
Session
.
- setSessionCookieNeeded(boolean) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
-
- setSessionCreation(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setSessionTransacted(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setSessionTransacted(Boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setSessionWaitTimeout(long) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
-
Sets the limit of how long to wait for a session to become available.
- setSetupData(Object) - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
-
Set the data for the setup payload.
- setSetupMetadata(Map<Object, MimeType>) - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
-
Add metadata to the setup payload.
- setSetupRoute(String) - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
-
Set the route for the setup payload.
- setSetupRouteVariables(Object...) - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
-
Set the variables for route template to expand with.
- setShouldAppendNewLine(boolean) - Method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
-
- setShouldClonePayload(boolean) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Specify whether to clone payload objects to create the target object.
- setShouldDeleteMessages(boolean) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Specify whether mail messages should be deleted after retrieval.
- setShouldDeleteMessages(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setShouldExtractPayload(boolean) - Method in class org.springframework.integration.support.json.JsonOutboundMessageMapper
-
- setShouldFlattenKeys(boolean) - Method in class org.springframework.integration.transformer.ObjectToMapTransformer
-
- setShouldLogFullMessage(boolean) - Method in class org.springframework.integration.handler.LoggingHandler
-
Specify whether to log the full Message.
- setShouldMarkMessagesAsRead(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setShouldMarkMessagesAsRead(Boolean) - Method in class org.springframework.integration.mail.ImapMailReceiver
-
Specify if messages should be marked as read.
- setShouldReconnectAutomatically(boolean) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
Specify whether the IDLE task should reconnect automatically after
catching a
FolderClosedException
while waiting for messages.
- setShouldSkipNulls(boolean) - Method in class org.springframework.integration.transformer.HeaderEnricher
-
Specify whether null
values, such as might be returned from
an expression evaluation, should be skipped.
- setShouldTrack(boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
- setShouldTrack(boolean) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- setShouldTrack(boolean) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
Specify whether this component should be tracked in the Message History.
- setShouldTrack(boolean) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setShouldTrack(boolean) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Specify whether this gateway should be tracked in the Message History
of Messages that originate from its send or sendAndReceive operations.
- setShouldTrack(boolean) - Method in class org.springframework.integration.handler.MessageHandlerSupport
-
- setShouldTrack(boolean) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
-
- setShouldTrack(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setShouldTrack(boolean) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
- setShouldTrack(boolean) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- setShouldTrack(boolean) - Method in interface org.springframework.integration.support.management.TrackableComponent
-
- setShouldTruncate(boolean) - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
-
- setShouldUnbindAtCompletion(boolean) - Method in class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
-
- setShutdownContainerOnStop(boolean) - Method in class org.springframework.integration.jms.JmsInboundGateway
-
Set to false to prevent listener container shutdown when the endpoint is stopped.
- setShutdownContainerOnStop(boolean) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
Set to false to prevent listener container shutdown when the endpoint is stopped.
- setShutdownTimeout(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setSimpleContent(boolean) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- setSimpleContent(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setSingleUse(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSingleUse(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
If true, sockets created by this factory will be used once.
- setSingleUse(boolean) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
Ignored on this factory; connections are always cached in the pool.
- setSkipUndeclaredResults(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
If this variable is set to
true
then all results from a stored
procedure call that don't have a corresponding
SqlOutParameter
declaration will be bypassed.
- setSocket(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- setSocket(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setSocketAttributes(Socket) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Sets socket attributes on the socket.
- setSocketAttributes(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
Sets timeout and receive buffer size; calls the socket customizer.
- setSocketAttributes(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
-
Provide a
Consumer
to configure a socket with arbitrary options, like security.
- setSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
-
Provide a
Consumer
to configure a socket with arbitrary options, like security.
- setSocketCustomizer(SocketCustomizer) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
Set a customizer to further configure the socket after creation.
- setSocketCustomizer(SocketCustomizer) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
Set a customizer to further configure the socket after creation.
- setSocketExpression(Expression) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setSocketExpressionString(String) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setSocketFactory(SocketFactory) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Allows you to pass in a SocketFactory
.
- setSocketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSocketSupport(TcpSocketSupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSockJsServiceOptions(ServerWebSocketContainer.SockJsServiceOptions) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
-
- setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setSoLinger(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSoLinger(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoLinger(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSoLinger(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- setSoReceiveBufferSize(int) - Method in interface org.springframework.integration.ip.CommonSocketOptions
-
- setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- setSoSendBufferSize(int) - Method in interface org.springframework.integration.ip.CommonSocketOptions
-
- setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setSoTimeout(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setSoTimeout(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- setSoTimeout(int) - Method in interface org.springframework.integration.ip.CommonSocketOptions
-
- setSoTimeout(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSoTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSoTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setSoTrafficClass(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSoTrafficClass(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoTrafficClass(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSoTrafficClass(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setSource(MessageSource<?>) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setSource(Object) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
-
Set the configuration source Object
for this manual Integration flow definition.
- setSource(Object) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
-
- setSource(MessageSource<?>) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
Specify the source to be polled for Messages.
- setSourceFactory(SourceFactory) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
-
Provide the SourceFactory to be used.
- setSourceFactory(SourceFactory) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
Sets the SourceFactory.
- setSqlParameters(List<SqlParameter>) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
If you database system is not fully supported by Spring and thus obtaining
parameter definitions from the JDBC Meta-data is not possible, you must define
the
SqlParameter
explicitly.
- setSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
-
- setSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- setSqlParameterTypes(Map<String, Integer>) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
-
Specify sql types for the parameters.
- setSslContextSupport(TcpSSLContextSupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSslHandshakeTimeout(Integer) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
Set the SSL handshake timeout (only used with SSL and NIO).
- setSslHandshakeTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Set the handshake timeout used when waiting for SSL handshake data; only applies
to SSL connections, when using NIO.
- setSslHandshakeTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setStanzaFilter(StanzaFilter) - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
-
Specify a StanzaFilter
to use for the incoming packets.
- setStaticParameters(Map<String, Object>) - Method in class org.springframework.integration.jdbc.BeanPropertySqlParameterSourceFactory
-
If the input is a List or a Map, the output is a map parameter source, and in that case some static parameters
can be added (default is empty).
- setStaticParameters(Map<String, Object>) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
-
Define some static parameter values.
- setStaticParameters(Map<String, Object>) - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSourceFactory
-
If the input is a List or a Map, the output is a map parameter source, and in that case some static parameters
can be added (default is empty).
- setStatusCodeExpression(Expression) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
Specify the
Expression
to resolve a status code for Response to override
the default '200 OK' or '500 Internal Server Error' for a timeout.
- setStatusCodeExpressionString(String) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
Specify the
Expression
to resolve a status code for Response to override
the default '200 OK' or '500 Internal Server Error' for a timeout.
- setStatusCodeIfNeeded(ServerHttpResponse, HttpEntity<?>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
- setStoredProcedureName(String) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
The name of the Stored Procedure or Stored Function to be executed.
- setStoredProcedureNameExpression(Expression) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- setStoreUri(String) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setStreamBytesLimit(int) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
-
- setStreamReceiverOptions(StreamReceiver.StreamReceiverOptions<String, ?>) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
- setStringToBytes(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
Sets whether outbound String payloads are to be converted
to byte[].
- setSubscribeSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
-
The
Consumer
callback to configure a consuming socket.
- setSubscriptionDurable(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setSubscriptionMode(Roster.SubscriptionMode) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
Sets the subscription processing mode, which dictates what action
Smack will take when subscription requests from other users are made.
- setSubscriptionShared(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setSuccessChannel(MessageChannel) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
Set the channel to which to send the
AdviceMessage
after evaluating the
success expression.
- setSuccessChannelName(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
Set the channel name to which to send the
AdviceMessage
after evaluating
the success expression.
- setSuffix(String) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
-
Specify the suffix to use for temporary files.
- setSuffix(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Specify a suffix to be added to each channel name prior to resolution.
- setSupportedEventTypes(EventType...) - Method in class org.springframework.integration.gemfire.inbound.CacheListeningMessageProducer
-
- setSupportedEventTypes(CqEventType...) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
-
- setSupportedProtocols(String...) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
-
- setSupportedProtocols(String...) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
-
- setSuppressCors(boolean) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
-
- setSync(boolean) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
- setSyndFeedInput(SyndFeedInput) - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
-
Specify a parser for Feed XML documents.
- setTableName(String) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
-
Specify a table in the target database to execute the query.
- setTableNameExpression(Expression) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
-
Set a SpEL expression to evaluate a table name at runtime against request message.
- setTablePrefix(String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
-
Public setter for the table prefix property.
- setTablePrefix(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Public setter for the table prefix property.
- setTablePrefix(String) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
Public setter for the table prefix property.
- setTailAttemptsDelay(long) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
The delay in milliseconds between attempts to tail a non-existent file,
or between attempts to execute a process if it fails for any reason.
- setTarget(Object) - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
-
- setTarget(Object) - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
-
- setTargetMethodName(String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
Set the method name for the message handler.
- setTargetObject(Object) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
Set the target POJO for the message handler.
- setTaskExecutor(Executor) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
Specify an
Executor
used for running the message listeners when messages are received.
- setTaskExecutor(Executor) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.config.AggregatorFactoryBean
-
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
Configure a
TaskScheduler
for those components which logic relies
on the scheduled tasks.
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
-
- setTcpNetConnectionSupport(TcpNetConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
-
- setTcpNetConnectionSupport(TcpNetConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
- setTcpNioConnectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
- setTcpNioConnectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
- setTcpSocketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
-
- setTcpSocketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
- setTcpSocketSupport(TcpSocketSupport) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setTcpSocketSupport(TcpSocketSupport) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- setTemplateChannelTransacted(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
By default, every file that is in the process of being transferred will
appear in the file system with an additional suffix, which by default is
".writing".
- setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Set the temporary suffix to use when transferring files to the remote system.
- setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
Set the temporary suffix to use when transferring files to the remote system.
- setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
Set the temporary suffix to use when transferring files to the remote system.
- setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Set a temporary file suffix to be used while transferring files.
- setTemporaryRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Set a temporary remote directory expression; used when transferring files to the remote
system.
- setTemporaryRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
Specify a remote directory path SpEL expression.
- setTemporaryRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
Set a temporary remote directory expression; used when transferring files to the remote
system.
- setTemporaryRemoteDirectoryExpressionString(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
Specify a remote directory path SpEL expression.
- setTestSession(boolean) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
-
Set to true to test the session when checking one out from the cache.
- setTheConnection(TcpConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
- setTheConnection(TcpConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
Sets the underlying connection (or next interceptor)
- setThreadKey(Object) - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
-
- setThreadKey(Message<?>, Object) - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
-
- setThreshold(int) - Method in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
-
- setThrowExceptionOnLateReply(boolean) - Method in class org.springframework.integration.core.MessagingTemplate
-
- setThrowExceptionOnRejection(Boolean) - Method in class org.springframework.integration.config.FilterFactoryBean
-
- setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.filter.MessageFilter
-
- setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
-
- setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
-
- setTimeout(long) - Method in class org.springframework.integration.channel.interceptor.WireTap
-
Specify the timeout value for sending to the intercepting target.
- setTimeout(long) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
-
Specify the timeout value for sending to the discard channel.
- setTimeout(Integer) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
The timeout property is used as the socket timeout parameter, as well as
the default connection timeout.
- setTimeout(long) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
Timeout in milliseconds (default -1).
- setTimeoutBuffer(int) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set a buffer, in milliseconds, added to the configured
delivery.timeout.ms
to determine the minimum time to wait for the send future completion when
sync
is true.
- setTimeoutDuration(Duration) - Method in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
-
- setTimeoutOnIdle(boolean) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
Allows you to override the rule for the timeout calculation.
- setTimestamp(long) - Method in class org.springframework.integration.store.MessageHolder
-
- setTimestamp(long) - Method in class org.springframework.integration.store.MessageMetadata
-
- setTimestampExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Specify a SpEL expression to evaluate a timestamp that will be added in the Kafka record.
- setTimeToLive(int) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
- setTimeToLive(int) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Specify the time (in milliseconds) to expire dead locks.
- setTimeToLive(long) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setTimeToLive(long) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Specify the timeToLive for each sent Message.
- setTimeToLiveExpression(Expression) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
Specify a SpEL expression to evaluate a timeToLive
for the JMS message to send.
- setTimeToLiveExpressionString(String) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
Specify a SpEL expression to evaluate a timeToLive
for the JMS message to send.
- setTopic(String) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- setTopic(String) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
-
Specify a topic the SocketType.PUB
socket is going to use for distributing messages into the
subscriptions.
- setTopicExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
- setTopicExpression(Expression) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
Set the topic expression; default "headers['mqtt_topic']".
- setTopicExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- setTopicExpression(Expression) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
-
Specify a SpEL expression to evaluate a topic a SocketType.PUB
is going to use for distributing messages into the
subscriptions.It is ignored for all other SocketType
s supported.
- setTopicExpressionString(String) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
Set the topic expression; default "headers['mqtt_topic']".
- setTopicPatterns(String...) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- setTopics(String...) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- setTopics(String...) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
-
Specify topics the SocketType.SUB
socket is going to use for subscription.
- setTrackableComponent(TrackableComponent) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
-
- setTransacted(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
Set to true to use a transacted channel for the ack.
- setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setTransactionName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setTransactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setTransactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
- setTransactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setTransactionTimeout(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setTransferCookies(boolean) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Set to true if you wish 'Set-Cookie' headers in responses to be
transferred as 'Cookie' headers in subsequent interactions for
a message.
- setTransportHandlers(TransportHandler...) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
-
- setTrapException(boolean) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
If true, any exception will be caught and null returned.
- setTrigger(Trigger) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setTrigger(Trigger) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setTrustedSpel(boolean) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Set to true if you trust the source of SpEL expressions used to evaluate URI
variables.
- setTrustManager(TrustManager) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setTrustStoreType(String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpSSLContextSupport
-
Set the trust store type.
- setType(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setTypeConverter(TypeConverter) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setTypeExpression(Expression) - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
-
Set the expression to evaluate against the message to determine the type.
- setTypeExpression(Expression) - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
-
Set the expression to evaluate against the message to determine the value
for the
AvroHeaders.TYPE
header.
- setTypeExpressionString(String) - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
-
Set the expression to evaluate against the message to determine the type id.
- setTypeExpressionString(String) - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
-
Set the expression to evaluate against the message to determine the value
for the
AvroHeaders.TYPE
header.
- setTypeLocator(TypeLocator) - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
-
- setUdpAdapter(UnicastReceivingChannelAdapter) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setUdpAdapter(UnicastReceivingChannelAdapter) - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
-
- setUnmarshaller(Unmarshaller) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
-
- setUnsolicitedMessageChannel(MessageChannel) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
Set the channel for unsolicited incoming messages, or late replies.
- setUnsolicitedMessageChannelName(String) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
Set the channel name for unsolicited incoming messages, or late replies.
- setUp() - Method in class org.springframework.integration.test.support.AbstractRequestResponseScenarioTests
-
- setupCustomPostProcessors() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
-
- setUpdatePerRow(boolean) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
- setUpdateSql(String) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
- setUpdateSql(String) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
-
- setUpdateSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
- setupDefaultInboundMapper(DefaultHttpHeaderMapper) - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Subclasses can call this from a static inboundMapper() method to set up
standard header mappings for an inbound mapper.
- setupDefaultOutboundMapper(DefaultHttpHeaderMapper) - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Subclasses can call this from a static outboundMapper() method to set up
standard header mappings for an outbound mapper.
- setupResponseAndConvertReply(ServletServerHttpResponse, Message<?>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
- setUriVariableExpressions(Map<String, Expression>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Set the Map of URI variable expressions to evaluate against the outbound message
when replacing the variable placeholders in a URI template.
- setUriVariableExpressions(Map<String, Expression>) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
Set the Map of URI variable expressions to evaluate against the outbound message
when replacing the variable placeholders in a URI template.
- setUriVariablesExpression(Expression) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Set the
Expression
to evaluate against the outbound message; the expression
must evaluate to a Map of URI variable expressions to evaluate against the outbound message
when replacing the variable placeholders in a URI template.
- setUseBroker(boolean) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
- setUseClientMode(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setUsePayloadAsParameterSource(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
If set to 'true', the payload of the Message will be used as a source for
providing parameters.
- setUsePayloadAsParameterSource(Boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setUser(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
The remote user to use.
- setUser(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setUserDefinedHeaderPrefix(String) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Sets the prefix to use with user-defined (non-standard) headers.
- setUseReplyContainer(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- setUserFlag(String) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- setUserFlag(String) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setUserInfo(UserInfo) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Provide a UserInfo
which exposes control over dealing with new keys or key
changes.
- setUsername(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setUseSpelInvoker(boolean) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
-
- setUseSpelInvoker(boolean) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
-
- setUseSpelInvoker(boolean) - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
-
- setUseTemporaryFileName(boolean) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Set whether a temporary file name is used when sending files to the remote system.
- setUseTemporaryFileName(boolean) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
A boolean
flag to use temporary files names or not.
- setUseTemporaryFileName(boolean) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
Set whether a temporary file name is used when sending files to the remote system.
- setUseWatchService(boolean) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setUseWatchService(boolean) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
- setUseWatchService(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
When set to true, connections created by this factory attempt
to use direct buffers where possible.
- setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
If true, connection will attempt to use direct buffers where possible.
- setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
- setUsingIdCache(boolean) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Consider using this property when polling the database transactionally
using multiple parallel threads, meaning when the configured poller is configured
using a task executor.
- setUsingNio(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setUuidRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
Set the registration id for
UUID
.
- setValidator(Validator) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
-
Specify a
Validator
to validate a converted payload from request.
- setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
-
- setValue(Object, Object) - Method in class org.springframework.integration.expression.DynamicExpression
-
- setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.DynamicExpression
-
- setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.FunctionExpression
-
- setValue(Object, Object) - Method in class org.springframework.integration.expression.FunctionExpression
-
- setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.FunctionExpression
-
- setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.SupplierExpression
-
- setValue(Object, Object) - Method in class org.springframework.integration.expression.SupplierExpression
-
- setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.SupplierExpression
-
- setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
-
- setValue(Object, Object) - Method in class org.springframework.integration.expression.ValueExpression
-
- setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.ValueExpression
-
- setValue(Object) - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
- setValue(Object) - Method in class org.springframework.integration.jpa.support.JpaParameter
-
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Configures the provided bean definition builder with a property value corresponding to the attribute whose name
is provided if that attribute is defined in the given element.
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Configures the provided bean definition builder with a property value corresponding to the attribute whose name
is provided if that attribute is defined in the given element.
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Configures the provided bean definition builder with a property value corresponding to the attribute whose name
is provided if that attribute is defined in the given element.
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Configures the provided bean definition builder with a property value corresponding to the attribute whose name
is provided if that attribute is defined in the given element.
- setValues(PreparedStatement, Message<?>) - Method in interface org.springframework.integration.jdbc.MessagePreparedStatementSetter
-
- setValues(PreparedStatement, Message<?>, Object, String, boolean) - Method in class org.springframework.integration.jdbc.store.channel.ChannelMessageStorePreparedStatementSetter
-
Perform a preparedStatement parameters population according provided arguments.
- setValueSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
-
- setValueSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.store.RedisMessageStore
-
- setValuesExpression(Expression) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
-
Set a SpEL expression to evaluate a
Map
for name-value pairs to bind as parameters
into a query.
- setValueTypeExpression(Expression) - Method in class org.springframework.integration.json.JsonToObjectTransformer
-
- setValueTypeExpressionString(String) - Method in class org.springframework.integration.json.JsonToObjectTransformer
-
Configure a SpEL expression to evaluate a
ResolvableType
to instantiate the payload from the incoming JSON.
- setViewExpression(Expression) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
Specifies a SpEL expression to evaluate in order to generate the view name.
- setViewName(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
Specify the view name.
- setVotingStrategy(MessageSelectorChain.VotingStrategy) - Method in class org.springframework.integration.selector.MessageSelectorChain
-
Specify the voting strategy for this selector chain.
- setWaitForConfirm(boolean) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
Set to true if you want to block the calling thread until a publisher confirm has
been received.
- setWaitTimeout(long) - Method in class org.springframework.integration.util.SimplePool
-
Adjusts the wait timeout - the time for which getItem() will wait if no idle
entries are available.
- setWantsClientAuth(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setWatchEvents(FileReadingMessageSource.WatchEventType...) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setWatchEvents(FileReadingMessageSource.WatchEventType...) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
- setWebServiceTemplate(WebServiceTemplate) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setWebSocketEnabled(boolean) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
-
- setWindowConfigurer(Function<Flux<Message<?>>, Flux<Flux<Message<?>>>>) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
Configure a
Function
to apply a transformation into the grouping
Flux
for any arbitrary
Flux.window(int)
options not covered by the simple options.
- setWindowSize(int) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
Specify a size for windows to close.
- setWindowSizeFunction(Function<Message<?>, Integer>) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
Specify a
Function
to determine a size for windows to close against the first message in group.
- setWindowTimespan(Duration) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
Configure a Duration
for closing windows periodically.
- setWorkingDirExpression(Expression) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
-
Specify an
Expression
to evaluate FTP client working directory
against request message.
- setWorkingDirExpressionString(String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
-
Specify a SpEL
Expression
to evaluate FTP client working directory
against request message.
- setWrapped(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
Set to true if intercepted.
- setWrapper(TcpConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
Set the wrapper.
- setXmlPayloadConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
-
- setXslParameterMappings(Map<String, Expression>) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
- setXsltParamHeaders(String...) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
- setZeroMqProxy(ZeroMqProxy) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
-
Specify a reference to a
ZeroMqProxy
instance in the same application
to rely on its ports configuration and make a natural lifecycle dependency without guessing
when the proxy is started.
- setZsetIncrementExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Set the expression used as the INCR flag for the ZADD command in case of ZSet collection.
- setZsetIncrementExpressionString(String) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Set the expression used as the INCR flag for the ZADD command in case of ZSet collection.
- SEVERITY - Static variable in class org.springframework.integration.syslog.SyslogHeaders
-
- SEVERITY - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
-
- SEVERITY_TEXT - Static variable in class org.springframework.integration.syslog.SyslogHeaders
-
- Sftp - Class in org.springframework.integration.sftp.dsl
-
The factory for SFTP components.
- SftpFileInfo - Class in org.springframework.integration.sftp.session
-
- SftpFileInfo(ChannelSftp.LsEntry) - Constructor for class org.springframework.integration.sftp.session.SftpFileInfo
-
- SftpInboundChannelAdapterParser - Class in org.springframework.integration.sftp.config
-
Parser for 'sftp:inbound-channel-adapter'
- SftpInboundChannelAdapterParser() - Constructor for class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
-
- SftpInboundChannelAdapterSpec - Class in org.springframework.integration.sftp.dsl
-
- SftpInboundChannelAdapterSpec(SessionFactory<ChannelSftp.LsEntry>, Comparator<File>) - Constructor for class org.springframework.integration.sftp.dsl.SftpInboundChannelAdapterSpec
-
- SftpInboundFileSynchronizer - Class in org.springframework.integration.sftp.inbound
-
Handles the synchronization between a remote SFTP directory and a local mount.
- SftpInboundFileSynchronizer(SessionFactory<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
-
Create a synchronizer with the SessionFactory
used to acquire Session
instances.
- SftpInboundFileSynchronizingMessageSource - Class in org.springframework.integration.sftp.inbound
-
A
MessageSource
implementation for SFTP
that delegates to an InboundFileSynchronizer.
- SftpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
-
- SftpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<ChannelSftp.LsEntry>, Comparator<File>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
-
- SftpMessageHandler - Class in org.springframework.integration.sftp.outbound
-
- SftpMessageHandler(SftpRemoteFileTemplate) - Constructor for class org.springframework.integration.sftp.outbound.SftpMessageHandler
-
- SftpMessageHandler(SftpRemoteFileTemplate, FileExistsMode) - Constructor for class org.springframework.integration.sftp.outbound.SftpMessageHandler
-
- SftpMessageHandler(SessionFactory<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.outbound.SftpMessageHandler
-
- SftpMessageHandlerSpec - Class in org.springframework.integration.sftp.dsl
-
- SftpMessageHandlerSpec(SessionFactory<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.dsl.SftpMessageHandlerSpec
-
- SftpMessageHandlerSpec(RemoteFileTemplate<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.dsl.SftpMessageHandlerSpec
-
Deprecated.
- SftpMessageHandlerSpec(RemoteFileTemplate<ChannelSftp.LsEntry>, FileExistsMode) - Constructor for class org.springframework.integration.sftp.dsl.SftpMessageHandlerSpec
-
Deprecated.
- SftpMessageHandlerSpec(SftpRemoteFileTemplate) - Constructor for class org.springframework.integration.sftp.dsl.SftpMessageHandlerSpec
-
- SftpMessageHandlerSpec(SftpRemoteFileTemplate, FileExistsMode) - Constructor for class org.springframework.integration.sftp.dsl.SftpMessageHandlerSpec
-
- SftpNamespaceHandler - Class in org.springframework.integration.sftp.config
-
Provides namespace support for using SFTP.
- SftpNamespaceHandler() - Constructor for class org.springframework.integration.sftp.config.SftpNamespaceHandler
-
- SftpOutboundChannelAdapterParser - Class in org.springframework.integration.sftp.config
-
Parser for SFTP Outbound Channel Adapters.
- SftpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.sftp.config.SftpOutboundChannelAdapterParser
-
- SftpOutboundGateway - Class in org.springframework.integration.sftp.gateway
-
Outbound Gateway for performing remote file operations via SFTP.
- SftpOutboundGateway(SessionFactory<ChannelSftp.LsEntry>, MessageSessionCallback<ChannelSftp.LsEntry, ?>) - Constructor for class org.springframework.integration.sftp.gateway.SftpOutboundGateway
-
Construct an instance using the provided session factory and callback for
performing operations on the session.
- SftpOutboundGateway(RemoteFileTemplate<ChannelSftp.LsEntry>, MessageSessionCallback<ChannelSftp.LsEntry, ?>) - Constructor for class org.springframework.integration.sftp.gateway.SftpOutboundGateway
-
Construct an instance with the supplied remote file template and callback
for performing operations on the session.
- SftpOutboundGateway(SessionFactory<ChannelSftp.LsEntry>, String, String) - Constructor for class org.springframework.integration.sftp.gateway.SftpOutboundGateway
-
Construct an instance with the supplied session factory, a command ('ls', 'get'
etc), and an expression to determine the filename.
- SftpOutboundGateway(RemoteFileTemplate<ChannelSftp.LsEntry>, String, String) - Constructor for class org.springframework.integration.sftp.gateway.SftpOutboundGateway
-
Construct an instance with the supplied remote file template, a command ('ls',
'get' etc), and an expression to determine the filename.
- SftpOutboundGatewayParser - Class in org.springframework.integration.sftp.config
-
- SftpOutboundGatewayParser() - Constructor for class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
-
- SftpOutboundGatewaySpec - Class in org.springframework.integration.sftp.dsl
-
- SftpOutboundGatewaySpec(AbstractRemoteFileOutboundGateway<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.dsl.SftpOutboundGatewaySpec
-
- SftpPersistentAcceptOnceFileListFilter - Class in org.springframework.integration.sftp.filters
-
Persistent file list filter using the server's file timestamp to detect if we've already
'seen' this file.
- SftpPersistentAcceptOnceFileListFilter(ConcurrentMetadataStore, String) - Constructor for class org.springframework.integration.sftp.filters.SftpPersistentAcceptOnceFileListFilter
-
- SftpRegexPatternFileListFilter - Class in org.springframework.integration.sftp.filters
-
- SftpRegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
-
- SftpRegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
-
- SftpRemoteFileTemplate - Class in org.springframework.integration.sftp.session
-
SFTP version of RemoteFileTemplate
providing type-safe access to
the underlying ChannelSftp object.
- SftpRemoteFileTemplate(SessionFactory<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.session.SftpRemoteFileTemplate
-
- SftpSession - Class in org.springframework.integration.sftp.session
-
Default SFTP
Session
implementation.
- SftpSession(Session) - Constructor for class org.springframework.integration.sftp.session.SftpSession
-
- SftpSession(JSchSessionWrapper) - Constructor for class org.springframework.integration.sftp.session.SftpSession
-
- SftpSimplePatternFileListFilter - Class in org.springframework.integration.sftp.filters
-
- SftpSimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.sftp.filters.SftpSimplePatternFileListFilter
-
- SftpStreamingInboundChannelAdapterParser - Class in org.springframework.integration.sftp.config
-
- SftpStreamingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.sftp.config.SftpStreamingInboundChannelAdapterParser
-
- SftpStreamingInboundChannelAdapterSpec - Class in org.springframework.integration.sftp.dsl
-
- SftpStreamingInboundChannelAdapterSpec(RemoteFileTemplate<ChannelSftp.LsEntry>, Comparator<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.dsl.SftpStreamingInboundChannelAdapterSpec
-
- SftpStreamingMessageSource - Class in org.springframework.integration.sftp.inbound
-
Message source for streaming SFTP remote file contents.
- SftpStreamingMessageSource(RemoteFileTemplate<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
-
Construct an instance with the supplied template.
- SftpStreamingMessageSource(RemoteFileTemplate<ChannelSftp.LsEntry>, Comparator<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
-
Construct an instance with the supplied template and comparator.
- SftpSystemMarkerFilePresentFileListFilter - Class in org.springframework.integration.sftp.filters
-
- SftpSystemMarkerFilePresentFileListFilter(FileListFilter<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
-
- SftpSystemMarkerFilePresentFileListFilter(FileListFilter<ChannelSftp.LsEntry>, String) - Constructor for class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
-
- SftpSystemMarkerFilePresentFileListFilter(FileListFilter<ChannelSftp.LsEntry>, Function<String, String>) - Constructor for class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
-
- SftpSystemMarkerFilePresentFileListFilter(Map<FileListFilter<ChannelSftp.LsEntry>, Function<String, String>>) - Constructor for class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
-
- SharedSessionCapable - Interface in org.springframework.integration.file.remote.session
-
A
SessionFactory
that implements this interface is capable of supporting a shared session.
- shouldClonePayload(boolean) - Method in class org.springframework.integration.dsl.EnricherSpec
-
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
-
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.filter.MessageFilter
-
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
Subclasses may override this.
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.BridgeHandler
-
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.DelayHandler
-
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
-
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
-
- shouldCreateEndpoint(Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- shouldCreateEndpoint(Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
-
- shouldCreateEndpoint(Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeToAnnotationPostProcessor
-
- shouldCreateEndpoint(Method, List<Annotation>) - Method in interface org.springframework.integration.config.annotation.MethodAnnotationPostProcessor
-
Determine if the provided
method
and its
annotations
are eligible
to create an
AbstractEndpoint
.
- shouldDeleteMessages() - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Indicates whether the mail messages should be deleted after being received.
- shouldDeleteMessages(boolean) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
- shouldDeleteMessages(boolean) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
-
A flag to specify if messages should be deleted after receive.
- shouldFireEvents() - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
-
- shouldFireEvents() - Method in class org.springframework.integration.config.xml.IdempotentReceiverInterceptorParser
-
- shouldFireEvents() - Method in class org.springframework.integration.config.xml.IntegrationManagementParser
-
- shouldFlush(String, long, long) - Method in interface org.springframework.integration.file.FileWritingMessageHandler.FlushPredicate
-
Return true to cause the file to be flushed and closed.
- shouldFlush(String, long, long, Message<?>) - Method in interface org.springframework.integration.file.FileWritingMessageHandler.MessageFlushPredicate
-
Return true to cause the file to be flushed and closed.
- shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.JdbcMessageHandlerParser
-
- shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.JdbcPollingChannelAdapterParser
-
- shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.StoredProcMessageHandlerParser
-
- shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.StoredProcPollingChannelAdapterParser
-
- shouldGenerateId() - Method in class org.springframework.integration.jms.config.JmsInboundChannelAdapterParser
-
- shouldGenerateId() - Method in class org.springframework.integration.jpa.config.xml.JpaOutboundChannelAdapterParser
-
- shouldGenerateId() - Method in class org.springframework.integration.mqtt.config.xml.MqttOutboundChannelAdapterParser
-
- shouldGenerateId() - Method in class org.springframework.integration.security.config.SecuredChannelsParser
-
- shouldGenerateId() - Method in class org.springframework.integration.xml.config.XPathExpressionParser
-
- shouldGenerateId() - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.config.xml.IdempotentReceiverInterceptorParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.JdbcMessageHandlerParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.JdbcPollingChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.StoredProcMessageHandlerParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.StoredProcPollingChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jms.config.JmsInboundChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.AttributePollingChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.MBeanTreePollingChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.NotificationPublishingChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.OperationInvokingChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jpa.config.xml.JpaOutboundChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.kafka.config.xml.KafkaOutboundGatewayParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.mqtt.config.xml.MqttOutboundChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.scripting.config.AbstractScriptParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.websocket.config.ClientWebSocketContainerParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.websocket.config.ServerWebSocketContainerParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xml.config.XPathExpressionParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xmpp.config.XmppConnectionParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.zookeeper.config.xml.LeaderListenerParser
-
- shouldIntercept(String, InterceptableChannel) - Method in interface org.springframework.integration.channel.interceptor.VetoCapableInterceptor
-
- shouldIntercept(String, InterceptableChannel) - Method in class org.springframework.integration.channel.interceptor.WireTap
-
- shouldMapInboundHeader(String) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- shouldMarkMessagesAsRead(boolean) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
- shouldMarkMessagesAsRead(boolean) - Method in class org.springframework.integration.mail.dsl.ImapMailInboundChannelAdapterSpec
-
A flag to determine if message should be marked as read.
- shouldReconnectAutomatically(boolean) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
- shouldSkipNulls(boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- shouldSplitOutput(Iterable<?>) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
- shouldTrack(boolean) - Method in class org.springframework.integration.dsl.MessageProducerSpec
-
Whether component should be tracked or not by message history.
- shouldTrack(boolean) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
-
Whether component should be tracked or not by message history.
- shouldTrack() - Method in class org.springframework.integration.handler.MessageHandlerSupport
-
- shouldUnbindAtCompletion() - Method in class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
-
- shutdownContainerOnStop(boolean) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
-
Set to false to prevent listener container shutdown when the endpoint is stopped.
- shutdownContainerOnStop(boolean) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec
-
Set to false to prevent listener container shutdown when the endpoint is stopped.
- shutdownInput() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
Set the connection's input stream to end of stream.
- shutdownInput() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
-
Set the socket's input stream to end of stream.
- shutdownInput() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
Set the socket's input stream to end of stream.
- shutdownOutput() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
Disable the socket's output stream.
- shutdownOutput() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
-
Disable the socket's output stream.
- shutdownOutput() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
Disable the socket's output stream.
- shutdownTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
- shutdownTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
- shutdownTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
-
Set the timeout for shutting down the container.
- SIMPLE_CALLBACK - Static variable in class org.springframework.integration.expression.ExpressionEvalMap
-
- SimpleAcknowledgment - Interface in org.springframework.integration.acks
-
Opaque object for manually acknowledging.
- SimpleActiveIdleMessageSourceAdvice - Class in org.springframework.integration.aop
-
- SimpleActiveIdleMessageSourceAdvice(DynamicPeriodicTrigger) - Constructor for class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
-
Deprecated.
- SimpleActiveIdleReceiveMessageAdvice - Class in org.springframework.integration.aop
-
A simple advice that polls at one rate when messages exist and another when
there are no messages.
- SimpleActiveIdleReceiveMessageAdvice(DynamicPeriodicTrigger) - Constructor for class org.springframework.integration.aop.SimpleActiveIdleReceiveMessageAdvice
-
- simpleContent(boolean) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
-
Determine how the content is rendered.
- SimpleFromAvroTransformer - Class in org.springframework.integration.transformer
-
An Apache Avro transformer to create generated SpecificRecord
objects
from byte[]
.
- SimpleFromAvroTransformer(Class<? extends SpecificRecord>) - Constructor for class org.springframework.integration.transformer.SimpleFromAvroTransformer
-
Construct an instance with the supplied default type to create.
- simpleInboundGateway() - Static method in class org.springframework.integration.ws.dsl.Ws
-
Create an instance.
- SimpleIncrementingIdGenerator() - Constructor for class org.springframework.integration.support.IdGenerators.SimpleIncrementingIdGenerator
-
- SimpleJsonSerializer - Class in org.springframework.integration.json
-
Extremely simple JSON serializer.
- SimpleMessageConverter - Class in org.springframework.integration.support.converter
-
- SimpleMessageConverter() - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
-
- SimpleMessageConverter(InboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
-
- SimpleMessageConverter(OutboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
-
- SimpleMessageConverter(InboundMessageMapper<?>, OutboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
-
- SimpleMessageGroup - Class in org.springframework.integration.store
-
Represents a mutable group of correlated messages that is bound to a certain
MessageStore
and group id.
- SimpleMessageGroup(Object) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
-
- SimpleMessageGroup(Collection<? extends Message<?>>, Object) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
-
- SimpleMessageGroup(MessageGroup) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
-
- SimpleMessageGroup(Collection<? extends Message<?>>, Object, long, boolean) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
-
- SimpleMessageGroup(Collection<Message<?>>, Collection<? extends Message<?>>, Object, long, boolean, boolean) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
-
- SimpleMessageGroupFactory - Class in org.springframework.integration.store
-
- SimpleMessageGroupFactory() - Constructor for class org.springframework.integration.store.SimpleMessageGroupFactory
-
- SimpleMessageGroupFactory(SimpleMessageGroupFactory.GroupType) - Constructor for class org.springframework.integration.store.SimpleMessageGroupFactory
-
- SimpleMessageGroupFactory.GroupType - Enum in org.springframework.integration.store
-
- SimpleMessageGroupProcessor - Class in org.springframework.integration.aggregator
-
- SimpleMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.SimpleMessageGroupProcessor
-
- SimpleMessageListenerContainerSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for a SimpleMessageListenerContainer
.
- SimpleMessageListenerContainerSpec(SimpleMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-
- SimpleMessageStore - Class in org.springframework.integration.store
-
- SimpleMessageStore(int, int) - Constructor for class org.springframework.integration.store.SimpleMessageStore
-
Creates a SimpleMessageStore with a maximum size limited by the given capacity, or unlimited size if the given
capacity is less than 1.
- SimpleMessageStore(int, int, long) - Constructor for class org.springframework.integration.store.SimpleMessageStore
-
Creates a SimpleMessageStore with a maximum size limited by the given capacity and the timeout in millisecond
to wait for the empty slot in the store.
- SimpleMessageStore(int, int, LockRegistry) - Constructor for class org.springframework.integration.store.SimpleMessageStore
-
Creates a SimpleMessageStore with a maximum size limited by the given capacity and LockRegistry
for the message group operations concurrency.
- SimpleMessageStore(int, int, long, LockRegistry) - Constructor for class org.springframework.integration.store.SimpleMessageStore
-
Creates a SimpleMessageStore with a maximum size limited by the given capacity,
the timeout in millisecond to wait for the empty slot in the store and LockRegistry
for the message group operations concurrency.
- SimpleMessageStore(int) - Constructor for class org.springframework.integration.store.SimpleMessageStore
-
Creates a SimpleMessageStore with the same capacity for individual and grouped messages.
- SimpleMessageStore() - Constructor for class org.springframework.integration.store.SimpleMessageStore
-
Creates a SimpleMessageStore with unlimited capacity
- SimpleMetadataStore - Class in org.springframework.integration.metadata
-
- SimpleMetadataStore() - Constructor for class org.springframework.integration.metadata.SimpleMetadataStore
-
- SimpleMetadataStore(ConcurrentMap<String, String>) - Constructor for class org.springframework.integration.metadata.SimpleMetadataStore
-
- SimpleMultipartFileReader - Class in org.springframework.integration.http.multipart
-
- SimpleMultipartFileReader() - Constructor for class org.springframework.integration.http.multipart.SimpleMultipartFileReader
-
- simpleOutboundGateway() - Static method in class org.springframework.integration.ws.dsl.Ws
-
Create an instance.
- simpleOutboundGateway(WebServiceTemplate) - Static method in class org.springframework.integration.ws.dsl.Ws
-
- SimplePatternFileListFilter - Class in org.springframework.integration.file.filters
-
Filter that supports ant style path expressions, which are less powerful but more readable than regular expressions.
- SimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.SimplePatternFileListFilter
-
- SimplePollSkipStrategy - Class in org.springframework.integration.scheduling
-
- SimplePollSkipStrategy() - Constructor for class org.springframework.integration.scheduling.SimplePollSkipStrategy
-
- SimplePool<T> - Class in org.springframework.integration.util
-
Implementation of
Pool
supporting dynamic resizing and a variable
timeout when attempting to obtain an item from the pool.
- SimplePool(int, SimplePool.PoolItemCallback<T>) - Constructor for class org.springframework.integration.util.SimplePool
-
Creates a SimplePool with a specific limit.
- SimplePool.PoolItemCallback<T> - Interface in org.springframework.integration.util
-
User of the pool provide an implementation of this interface; called during
various pool operations.
- SimplePublisherMetadataSource - Class in org.springframework.integration.aop
-
Simple implementation of PublisherMetadataSource
that allows for
configuration of a single channel name, payload expression, and
array of header key=value expressions.
- SimplePublisherMetadataSource() - Constructor for class org.springframework.integration.aop.SimplePublisherMetadataSource
-
- SimpleSequenceSizeReleaseStrategy - Class in org.springframework.integration.aggregator
-
An implementation of
ReleaseStrategy
that simply compares the current size of
the message list to the expected 'sequenceSize'.
- SimpleSequenceSizeReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.SimpleSequenceSizeReleaseStrategy
-
- SimpleToAvroTransformer - Class in org.springframework.integration.transformer
-
An Apache Avro transformer for generated SpecificRecord
objects.
- SimpleToAvroTransformer() - Constructor for class org.springframework.integration.transformer.SimpleToAvroTransformer
-
- SimpleWebServiceInboundGateway - Class in org.springframework.integration.ws
-
- SimpleWebServiceInboundGateway() - Constructor for class org.springframework.integration.ws.SimpleWebServiceInboundGateway
-
- SimpleWebServiceOutboundGateway - Class in org.springframework.integration.ws
-
An outbound Messaging Gateway for invoking a Web Service.
- SimpleWebServiceOutboundGateway(DestinationProvider) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
-
- SimpleWebServiceOutboundGateway(DestinationProvider, SourceExtractor<?>) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
-
- SimpleWebServiceOutboundGateway(DestinationProvider, SourceExtractor<?>, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
-
- SimpleWebServiceOutboundGateway(String) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
-
- SimpleWebServiceOutboundGateway(String, SourceExtractor<?>) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
-
- SimpleWebServiceOutboundGateway(String, SourceExtractor<?>, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
-
- SimpleWsInboundGatewaySpec - Class in org.springframework.integration.ws.dsl
-
- SimpleWsInboundGatewaySpec() - Constructor for class org.springframework.integration.ws.dsl.SimpleWsInboundGatewaySpec
-
- SimpleWsOutboundGatewayNoTemplateSpec() - Constructor for class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
-
- SimpleWsOutboundGatewaySpec - Class in org.springframework.integration.ws.dsl
-
- SimpleWsOutboundGatewaySpec(WebServiceTemplate) - Constructor for class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
-
- SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec - Class in org.springframework.integration.ws.dsl
-
- SinglePatternBasedHeaderMatcher(String) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
-
- SinglePatternBasedHeaderMatcher(String, boolean) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
-
- SingleRequestResponseScenarioTests - Class in org.springframework.integration.test.support
-
- SingleRequestResponseScenarioTests() - Constructor for class org.springframework.integration.test.support.SingleRequestResponseScenarioTests
-
- singleTerminator(byte) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
-
Return a serializer with the default max message size for deserialization.
- singleTerminator(byte, int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
-
Return a serializer with the provided max message size for deserialization.
- singleUseConnections(boolean) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
-
This connection factory uses a new connection for each operation.
- size() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- size() - Method in class org.springframework.integration.expression.ExpressionEvalMap
-
- size() - Method in class org.springframework.integration.history.MessageHistory
-
- size() - Method in class org.springframework.integration.json.JsonPropertyAccessor.ArrayNodeAsList
-
- SIZE - Static variable in class org.springframework.integration.mail.MailHeaders
-
- size() - Method in interface org.springframework.integration.store.MessageGroup
-
- size() - Method in class org.springframework.integration.store.MessageGroupMetadata
-
- size() - Method in class org.springframework.integration.store.MessageGroupQueue
-
- size() - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- size() - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
-
- skipPoll() - Method in interface org.springframework.integration.scheduling.PollSkipStrategy
-
Return true if this poll should be skipped.
- skipPoll() - Method in class org.springframework.integration.scheduling.SimplePollSkipStrategy
-
- skipPolls() - Method in class org.springframework.integration.scheduling.SimplePollSkipStrategy
-
Skip future polls.
- skipTo(char) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
-
- SmartLifecycleRoleController - Class in org.springframework.integration.support
-
- SmartLifecycleRoleController(List<String>, List<SmartLifecycle>) - Constructor for class org.springframework.integration.support.SmartLifecycleRoleController
-
Construct an instance with the provided lists of roles and lifecycles, which must be of equal length.
- SmartLifecycleRoleController(MultiValueMap<String, SmartLifecycle>) - Constructor for class org.springframework.integration.support.SmartLifecycleRoleController
-
Construct an instance with the provided map of roles/instances.
- smartMatch(String, String...) - Static method in class org.springframework.integration.support.utils.PatternMatchUtils
-
Pattern match against the supplied patterns; also supports negated ('!')
patterns.
- smartMatchIgnoreCase(String, String...) - Static method in class org.springframework.integration.support.utils.PatternMatchUtils
-
Pattern match against the supplied patterns ignoring case; also supports negated ('!')
patterns.
- smtp(int) - Static method in class org.springframework.integration.test.mail.TestMailServer
-
- SOAP_ACTION - Static variable in class org.springframework.integration.ws.WebServiceHeaders
-
- SoapHeaderMapper - Interface in org.springframework.integration.ws
-
- socket(DatagramSocket) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
-
- socket - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
-
- SOCKET_FACTORY_SUPPORT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- SOCKET_SUPPORT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- socketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
-
Provide a
Consumer
to configure a socket with arbitrary options, like security.
- socketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
-
Provide a
Consumer
to configure a socket with arbitrary options, like security.
- SocketCustomizer - Interface in org.springframework.integration.ip.udp
-
Configures a socket.
- socketExpression(String) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
-
- socketFunction(Function<Message<?>, DatagramSocket>) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
-
- SocketInfo - Class in org.springframework.integration.ip.tcp.connection
-
Simple wrapper around
Socket
providing access to getters (except
input/output streams).
- SocketInfo(Socket) - Constructor for class org.springframework.integration.ip.tcp.connection.SocketInfo
-
- SockJsServiceOptions() - Constructor for class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
-
- SoftEndOfStreamException - Exception in org.springframework.integration.ip.tcp.serializer
-
Used to communicate that a stream has closed, but between logical
messages.
- SoftEndOfStreamException() - Constructor for exception org.springframework.integration.ip.tcp.serializer.SoftEndOfStreamException
-
Default constructor.
- SoftEndOfStreamException(String) - Constructor for exception org.springframework.integration.ip.tcp.serializer.SoftEndOfStreamException
-
Construct an instance with the message.
- SoftEndOfStreamException(String, Throwable) - Constructor for exception org.springframework.integration.ip.tcp.serializer.SoftEndOfStreamException
-
Construct an instance with the message and cause.
- soKeepAlive(boolean) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
-
- soLinger(int) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
-
- soReceiveBufferSize(int) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
-
- soReceiveBufferSize(int) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
-
- soReceiveBufferSize(int) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
-
- soSendBufferSize(int) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
-
- soSendBufferSize(int) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
-
- soSendBufferSize(int) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
-
- soTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
-
- soTimeout(int) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
-
- soTimeout(int) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
-
- soTimeout(int) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
-
- soTrafficClass(int) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
-
- SOURCE - Static variable in class org.springframework.integration.syslog.SyslogHeaders
-
- SOURCE_DATA - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
-
Raw source message.
- SOURCE_TYPE - Static variable in class org.springframework.integration.syslog.SyslogHeaders
-
- SourceCreatingTransformer - Class in org.springframework.integration.xml.transformer
-
- SourceCreatingTransformer() - Constructor for class org.springframework.integration.xml.transformer.SourceCreatingTransformer
-
- SourceCreatingTransformer(SourceFactory) - Constructor for class org.springframework.integration.xml.transformer.SourceCreatingTransformer
-
- sourceExtractor - Variable in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
-
- sourceExtractor(SourceExtractor<?>) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
-
- sourceExtractor - Variable in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
-
- sourceExtractor(SourceExtractor<?>) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
-
- SourceFactory - Interface in org.springframework.integration.xml.source
-
Factory to create a
Source
possibly taking into account
the provided message payload instance.
- SourcePollingChannelAdapter - Class in org.springframework.integration.endpoint
-
- SourcePollingChannelAdapter() - Constructor for class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- SourcePollingChannelAdapterFactoryBean - Class in org.springframework.integration.config
-
FactoryBean for creating a SourcePollingChannelAdapter instance.
- SourcePollingChannelAdapterFactoryBean() - Constructor for class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- SourcePollingChannelAdapterSpec - Class in org.springframework.integration.dsl
-
- SourcePollingChannelAdapterSpec(MessageSource<?>) - Constructor for class org.springframework.integration.dsl.SourcePollingChannelAdapterSpec
-
- SPACE - Static variable in class org.springframework.integration.syslog.RFC5424SyslogParser
-
- SPEL_PROPERTY_ACCESSOR_REGISTRAR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
-
- SpelExpressionRetryStateGenerator - Class in org.springframework.integration.handler.advice
-
Creates a DefaultRetryState from a
Message
.
- SpelExpressionRetryStateGenerator(String) - Constructor for class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
-
- SpelExpressionRetryStateGenerator(String, String) - Constructor for class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
-
- SpelFunctionFactoryBean - Class in org.springframework.integration.config
-
- SpelFunctionFactoryBean(Class<?>, String) - Constructor for class org.springframework.integration.config.SpelFunctionFactoryBean
-
- SpelFunctionParser - Class in org.springframework.integration.config.xml
-
Parser for the <spel-function> element.
- SpelFunctionParser() - Constructor for class org.springframework.integration.config.xml.SpelFunctionParser
-
- SpelPropertyAccessorRegistrar - Class in org.springframework.integration.expression
-
Utility class that keeps track of a Set of SpEL
PropertyAccessor
s
in order to register them with the "integrationEvaluationContext" upon initialization.
- SpelPropertyAccessorRegistrar() - Constructor for class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
-
- SpelPropertyAccessorRegistrar(PropertyAccessor...) - Constructor for class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
-
Create an instance with the provided property accessors.
- SpelPropertyAccessorRegistrar(Map<String, PropertyAccessor>) - Constructor for class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
-
Create an instance with the provided named property accessors.
- SpelPropertyAccessorsParser - Class in org.springframework.integration.config.xml
-
Parser for the <spel-property-accessors> element.
- SpelPropertyAccessorsParser() - Constructor for class org.springframework.integration.config.xml.SpelPropertyAccessorsParser
-
- split() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(Consumer<SplitterEndpointSpec<DefaultMessageSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(String, Consumer<SplitterEndpointSpec<ExpressionEvaluatingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(Object, String, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(String, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(String, String, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(MessageProcessorSpec<?>, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(Class<P>, Function<P, ?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(Class<P>, Function<P, ?>, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(MessageHandlerSpec<?, S>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(MessageHandlerSpec<?, S>, Consumer<SplitterEndpointSpec<S>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(AbstractMessageSplitter) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(S, Consumer<SplitterEndpointSpec<S>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
- split(Function<P, ?>, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
-
- splitMessage(Message<?>) - Method in class org.springframework.integration.file.splitter.FileSplitter
-
- splitMessage(Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
-
Subclasses must override this method to split the received Message.
- splitMessage(Message<?>) - Method in class org.springframework.integration.splitter.DefaultMessageSplitter
-
- splitMessage(Message<?>) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
-
- Splitter - Annotation Type in org.springframework.integration.annotation
-
Indicates that a method is capable of splitting a single message or message
payload to produce multiple messages or payloads.
- splitter() - Static method in class org.springframework.integration.file.dsl.Files
-
- splitter(boolean) - Static method in class org.springframework.integration.file.dsl.Files
-
- splitter(boolean, boolean) - Static method in class org.springframework.integration.file.dsl.Files
-
The
FileSplitterSpec
builder factory method with
iterator
and
markers
flags specified.
- SplitterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
-
Post-processor for Methods annotated with
@Splitter
.
- SplitterAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.SplitterAnnotationPostProcessor
-
- SplitterEndpointSpec<S extends AbstractMessageSplitter> - Class in org.springframework.integration.dsl
-
- SplitterEndpointSpec(S) - Constructor for class org.springframework.integration.dsl.SplitterEndpointSpec
-
- SplitterFactoryBean - Class in org.springframework.integration.config
-
Factory bean for creating a Message Splitter.
- SplitterFactoryBean() - Constructor for class org.springframework.integration.config.SplitterFactoryBean
-
- SplitterParser - Class in org.springframework.integration.config.xml
-
Parser for the <splitter/> element.
- SplitterParser() - Constructor for class org.springframework.integration.config.xml.SplitterParser
-
- SpringIntegrationTest - Annotation Type in org.springframework.integration.test.context
-
Annotation that can be specified on a test class that runs Spring Integration based tests.
- SqlParameterSourceFactory - Interface in org.springframework.integration.jdbc
-
Collaborator for JDBC adapters which allows creation of
instances of
SqlParameterSource
for use in update operations.
- SqlServerChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
-
Channel message store query provider for Microsoft SQL Server / Azure SQL database.
- SqlServerChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.SqlServerChannelMessageStoreQueryProvider
-
- SSL_CONTEXT_SUPPORT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- SSL_HANDSHAKE_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- StackTraceUtils - Class in org.springframework.integration.util
-
Utility methods for analyzing stack traces.
- STANDARD_HEADER_NAMES - Static variable in class org.springframework.integration.ws.DefaultSoapHeaderMapper
-
- STANDARD_REPLY_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.mapping.AbstractHeaderMapper
-
A special pattern that only matches standard reply headers.
- STANDARD_REQUEST_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.mapping.AbstractHeaderMapper
-
A special pattern that only matches standard request headers.
- StandardHeaderEnricherParser - Class in org.springframework.integration.config.xml
-
Parser for the <header-enricher> element within the core integration
namespace.
- StandardHeaderEnricherParser() - Constructor for class org.springframework.integration.config.xml.StandardHeaderEnricherParser
-
- StandardIntegrationFlow - Class in org.springframework.integration.dsl
-
The standard implementation of the
IntegrationFlow
interface instantiated
by the Framework.
- StandardIntegrationFlowContext - Class in org.springframework.integration.dsl.context
-
- StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder - Class in org.springframework.integration.dsl.context
-
A Builder pattern implementation for the options to register
IntegrationFlow
in the application context.
- StandardRotationPolicy - Class in org.springframework.integration.file.remote.aop
-
Standard rotation policy; iterates over key/directory pairs; when the end is reached,
starts again at the beginning.
- StandardRotationPolicy(DelegatingSessionFactory<?>, List<RotationPolicy.KeyDirectory>, boolean) - Constructor for class org.springframework.integration.file.remote.aop.StandardRotationPolicy
-
- start() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- start() - Method in class org.springframework.integration.aggregator.DelegatingMessageGroupProcessor
-
- start() - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
- start() - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
-
- start() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
-
- start() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
-
- start() - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
-
- start() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- start() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- start() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- start() - Method in class org.springframework.integration.channel.interceptor.WireTap
-
Restart the wire tap if it has been stopped.
- start() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- start() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- start() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
-
Start the registration.
- start() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
-
- start() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
-
- start() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
-
- start() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
- start() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
-
- start() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- start() - Method in class org.springframework.integration.file.FileReadingMessageSource
-
- start() - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
- start() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
- start() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- start() - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
-
- start() - Method in class org.springframework.integration.filter.MessageFilter
-
- start() - Method in class org.springframework.integration.gateway.GatewayMessageHandler
-
- start() - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- start() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
-
- start() - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
-
- start() - Method in class org.springframework.integration.handler.ReplyProducingMessageHandlerWrapper
-
- start() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
-
- start() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
-
- start() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
- start() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- start() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- start() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- start() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- start() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- start() - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- start() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
- start() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
-
- start() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
-
- start() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
- start() - Method in class org.springframework.integration.monitor.ManagedEndpoint
-
Deprecated.
- start() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
- start() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- start() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
-
- start() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
-
- start() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- start() - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
-
- start() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
- start() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- start() - Method in interface org.springframework.integration.support.management.ManageableLifecycle
-
- start() - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor
-
Start a sample collection.
- start() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
-
- start() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- start() - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
-
- start() - Method in class org.springframework.integration.transformer.ContentEnricher
-
Lifecycle implementation.
- start() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
-
- start() - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
-
- start() - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
-
- start() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- start() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
-
- start() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
-
- start() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
- start() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
-
- start() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
-
- startAckThread() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- startConsumerMinInterval(long) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-
- startLifecyclesInRole(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
- statefulRetryFatalWithNullMessageId(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set whether a message with a null messageId is fatal for the consumer
when using stateful retry.
- StaticHeaderValueMessageProcessor<T> - Class in org.springframework.integration.transformer.support
-
- StaticHeaderValueMessageProcessor(T) - Constructor for class org.springframework.integration.transformer.support.StaticHeaderValueMessageProcessor
-
- StaticMessageHeaderAccessor - Class in org.springframework.integration
-
Lightweight type-safe header accessor avoiding object
creation just to access a header.
- STATUS_CODE - Static variable in class org.springframework.integration.http.HttpHeaders
-
- statusCodeExpression(String) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
-
Specify the
Expression
to resolve a status code for Response to override
the default '200 OK' or '500 Internal Server Error' for a timeout.
- statusCodeExpression(Expression) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
-
Specify the
Expression
to resolve a status code for Response to override
the default '200 OK' or '500 Internal Server Error' for a timeout.
- statusCodeFunction(Function<RequestEntity<?>, ?>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
-
Specify the
Function
to resolve a status code for Response to override
the default '200 OK' or '500 Internal Server Error' for a timeout.
- stderr() - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
-
Factory method that creates a target for stderr (System.err) with the
default charset encoding.
- stderr(String) - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
-
Factory method that creates a target for stderr (System.err) with the
specified charset encoding.
- stdin() - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
- stdin(String) - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
- stdinPipe() - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
- stdinPipe(String) - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
- stdout() - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
-
Factory method that creates a target for stdout (System.out) with the
default charset encoding.
- stdout(String) - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
-
Factory method that creates a target for stdout (System.out) with the
specified charset encoding.
- STOMP_INBOUND_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.stomp.support.StompHeaderMapper
-
- STOMP_OUTBOUND_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.stomp.support.StompHeaderMapper
-
- stompClient - Variable in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- StompConnectionFailedEvent - Class in org.springframework.integration.stomp.event
-
- StompConnectionFailedEvent(Object, Throwable) - Constructor for class org.springframework.integration.stomp.event.StompConnectionFailedEvent
-
- StompExceptionEvent - Class in org.springframework.integration.stomp.event
-
- StompExceptionEvent(Object, Throwable) - Constructor for class org.springframework.integration.stomp.event.StompExceptionEvent
-
- StompHeaderMapper - Class in org.springframework.integration.stomp.support
-
- StompHeaderMapper() - Constructor for class org.springframework.integration.stomp.support.StompHeaderMapper
-
- StompInboundChannelAdapter - Class in org.springframework.integration.stomp.inbound
-
The
MessageProducerSupport
for STOMP protocol to handle STOMP frames from
provided destination and send messages to the
outputChannel
.
- StompInboundChannelAdapter(StompSessionManager, String...) - Constructor for class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
-
- StompInboundChannelAdapterParser - Class in org.springframework.integration.stomp.config
-
- StompInboundChannelAdapterParser() - Constructor for class org.springframework.integration.stomp.config.StompInboundChannelAdapterParser
-
- StompIntegrationEvent - Class in org.springframework.integration.stomp.event
-
- StompIntegrationEvent(Object) - Constructor for class org.springframework.integration.stomp.event.StompIntegrationEvent
-
- StompIntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.stomp.event.StompIntegrationEvent
-
- StompMessageHandler - Class in org.springframework.integration.stomp.outbound
-
- StompMessageHandler(StompSessionManager) - Constructor for class org.springframework.integration.stomp.outbound.StompMessageHandler
-
- StompNamespaceHandler - Class in org.springframework.integration.stomp.config
-
- StompNamespaceHandler() - Constructor for class org.springframework.integration.stomp.config.StompNamespaceHandler
-
- StompOutboundChannelAdapterParser - Class in org.springframework.integration.stomp.config
-
- StompOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.stomp.config.StompOutboundChannelAdapterParser
-
- StompReceiptEvent - Class in org.springframework.integration.stomp.event
-
- StompReceiptEvent(Object, String, String, StompCommand, boolean) - Constructor for class org.springframework.integration.stomp.event.StompReceiptEvent
-
- StompSessionConnectedEvent - Class in org.springframework.integration.stomp.event
-
- StompSessionConnectedEvent(Object) - Constructor for class org.springframework.integration.stomp.event.StompSessionConnectedEvent
-
- StompSessionManager - Interface in org.springframework.integration.stomp
-
An abstraction to manage the STOMP Session and connection/disconnection
for
StompSessionHandler
.
- stop() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- stop() - Method in class org.springframework.integration.aggregator.DelegatingMessageGroupProcessor
-
- stop() - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
- stop() - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
-
- stop() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
-
- stop() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
-
- stop() - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
-
- stop() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- stop() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- stop() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- stop(Runnable) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- stop() - Method in class org.springframework.integration.channel.interceptor.WireTap
-
Stop the wire tap.
- stop() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- stop() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- stop() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
-
Stop the registration.
- stop() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
-
- stop(Runnable) - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
-
- stop(Runnable) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
-
- stop() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
-
- stop(Runnable) - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
-
- stop() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
-
- stop() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
- stop(Runnable) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
- stop() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
-
- stop() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- stop() - Method in class org.springframework.integration.file.FileReadingMessageSource
-
- stop() - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
- stop() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
- stop() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- stop() - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
-
- stop() - Method in class org.springframework.integration.filter.MessageFilter
-
- stop() - Method in class org.springframework.integration.gateway.GatewayMessageHandler
-
- stop() - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- stop(Runnable) - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- stop() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
-
- stop() - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
-
- stop() - Method in class org.springframework.integration.handler.ReplyProducingMessageHandlerWrapper
-
- stop() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
-
- stop() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
-
- stop() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
- stop() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- stop() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- stop() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Stops the server.
- stop() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- stop() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
- stop() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
- stop() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
- stop() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
- stop() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
-
- stop() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- stop() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- stop() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- stop() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- stop() - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- stop() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
- stop(Runnable) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
- stop() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
-
- stop(Runnable) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
-
- stop() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
-
- stop() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
- stop() - Method in class org.springframework.integration.monitor.ManagedEndpoint
-
Deprecated.
- stop() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
- stop() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- stop(Runnable) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- stop() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
-
- stop() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
-
- stop() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- stop() - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
-
- stop() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
- stop() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- stop() - Method in interface org.springframework.integration.support.management.ManageableLifecycle
-
- stop(TimerFacade) - Method in interface org.springframework.integration.support.management.metrics.SampleFacade
-
- stop() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- stop() - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
-
- stop() - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
-
- stop() - Method in class org.springframework.integration.transformer.ContentEnricher
-
Lifecycle implementation.
- stop() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
-
- stop() - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
-
- stop(Runnable) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
-
- stop() - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
-
- stop(Runnable) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
-
- stop() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- stop() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
-
- stop() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
-
- stop() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
- stop() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
-
- stop() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
-
- stopActiveChannels() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- stopActiveComponents(long) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
Shutdown active components.
- stopConsumerMinInterval(long) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-
- stopInboundMessageProducers() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- stopLifecyclesInRole(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
- stopMessageSources() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
Stops all message sources - may cause interrupts.
- stopped - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer.MailHandler
-
- store(Object, Message<?>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- store - Variable in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
-
- StoredProcExecutor - Class in org.springframework.integration.jdbc
-
This class is used by all Stored Procedure (Stored Function) components and
provides the core functionality to execute those.
- StoredProcExecutor(DataSource) - Constructor for class org.springframework.integration.jdbc.StoredProcExecutor
-
Constructor taking
DataSource
from which the DB Connection can be
obtained.
- StoredProcMessageHandler - Class in org.springframework.integration.jdbc
-
A message handler that executes Stored Procedures for update purposes.
- StoredProcMessageHandler(StoredProcExecutor) - Constructor for class org.springframework.integration.jdbc.StoredProcMessageHandler
-
- StoredProcMessageHandlerParser - Class in org.springframework.integration.jdbc.config
-
- StoredProcMessageHandlerParser() - Constructor for class org.springframework.integration.jdbc.config.StoredProcMessageHandlerParser
-
- StoredProcOutboundGateway - Class in org.springframework.integration.jdbc
-
- StoredProcOutboundGateway(StoredProcExecutor) - Constructor for class org.springframework.integration.jdbc.StoredProcOutboundGateway
-
- StoredProcOutboundGatewayParser - Class in org.springframework.integration.jdbc.config
-
- StoredProcOutboundGatewayParser() - Constructor for class org.springframework.integration.jdbc.config.StoredProcOutboundGatewayParser
-
- StoredProcParserUtils - Class in org.springframework.integration.jdbc.config
-
- StoredProcPollingChannelAdapter - Class in org.springframework.integration.jdbc
-
A polling channel adapter that creates messages from the payload returned by
executing a stored procedure or Sql function.
- StoredProcPollingChannelAdapter(StoredProcExecutor) - Constructor for class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
-
- StoredProcPollingChannelAdapterParser - Class in org.springframework.integration.jdbc.config
-
- StoredProcPollingChannelAdapterParser() - Constructor for class org.springframework.integration.jdbc.config.StoredProcPollingChannelAdapterParser
-
- storeLock(Lock) - Method in class org.springframework.integration.dsl.QueueChannelSpec.MessageStoreSpec
-
- STREAM_KEY - Static variable in class org.springframework.integration.redis.support.RedisHeaders
-
- STREAM_MESSAGE_ID - Static variable in class org.springframework.integration.redis.support.RedisHeaders
-
- StreamClosedEvent - Class in org.springframework.integration.stream
-
Application event published when EOF is detected on a stream.
- StreamClosedEvent(Object) - Constructor for class org.springframework.integration.stream.StreamClosedEvent
-
- StreamNamespaceHandler - Class in org.springframework.integration.stream.config
-
- StreamNamespaceHandler() - Constructor for class org.springframework.integration.stream.config.StreamNamespaceHandler
-
- StreamTransformer - Class in org.springframework.integration.transformer
-
Transforms an InputStream payload to a byte[] or String (if a
charset is provided).
- StreamTransformer() - Constructor for class org.springframework.integration.transformer.StreamTransformer
-
Construct an instance to transform an
InputStream
to
a
byte[]
.
- StreamTransformer(String) - Constructor for class org.springframework.integration.transformer.StreamTransformer
-
Construct an instance with the charset to convert the stream to a
String; if null a byte[]
will be produced instead.
- StreamTransformerParser - Class in org.springframework.integration.config.xml
-
Parser for <stream-transformer/>
element.
- StreamTransformerParser() - Constructor for class org.springframework.integration.config.xml.StreamTransformerParser
-
- STRING - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
-
- STRING_RESULT - Static variable in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
-
- StringObjectMapBuilder - Class in org.springframework.integration.support
-
A map builder creating a map with String keys and values.
- StringObjectMapBuilder() - Constructor for class org.springframework.integration.support.StringObjectMapBuilder
-
- StringResultFactory - Class in org.springframework.integration.xml.result
-
- StringResultFactory() - Constructor for class org.springframework.integration.xml.result.StringResultFactory
-
- StringSourceFactory - Class in org.springframework.integration.xml.source
-
- StringSourceFactory() - Constructor for class org.springframework.integration.xml.source.StringSourceFactory
-
- StringSourceFactory(TransformerFactory) - Constructor for class org.springframework.integration.xml.source.StringSourceFactory
-
- StringStringMapBuilder - Class in org.springframework.integration.support
-
A map builder creating a map with String keys and values.
- StringStringMapBuilder() - Constructor for class org.springframework.integration.support.StringStringMapBuilder
-
- stringToBytes(String, String) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
-
Utility method for null-safe conversion from String to byte[]
- StringValueTestXPathMessageSelector - Class in org.springframework.integration.xml.selector
-
- StringValueTestXPathMessageSelector(String, Map<String, String>, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
-
Create a selector which tests for the given value and supports multiple namespaces.
- StringValueTestXPathMessageSelector(String, String, String, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
-
Creates a single namespace Xpath selector.
- StringValueTestXPathMessageSelector(String, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
-
Creates a non-namespaced testing selector.
- StringValueTestXPathMessageSelector(XPathExpression, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
-
- STRUCTURED_DATA - Static variable in class org.springframework.integration.syslog.SyslogHeaders
-
- STX - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
-
- stxetx() - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
-
Return a serializer with the default max message size for deserialization.
- stxetx(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
-
Return a serializer with the provided max message size for deserialization.
- subFlowMapping(K, IntegrationFlow) - Method in class org.springframework.integration.dsl.RouterSpec
-
- subject(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the subject.
- SUBJECT - Static variable in class org.springframework.integration.mail.MailHeaders
-
- SUBJECT - Static variable in class org.springframework.integration.xmpp.XmppHeaders
-
- subjectExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the expression that will be evaluated to determine th subject.
- subjectFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set a function that will be invoked to return the subject based on the message.
- subList(int, int) - Method in class org.springframework.integration.history.MessageHistory
-
- SubProtocolHandlerRegistry - Class in org.springframework.integration.websocket.support
-
The utility class to encapsulate search algorithms for a set of provided
SubProtocolHandler
s.
- SubProtocolHandlerRegistry(List<SubProtocolHandler>) - Constructor for class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
-
- SubProtocolHandlerRegistry(SubProtocolHandler) - Constructor for class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
-
- SubProtocolHandlerRegistry(List<SubProtocolHandler>, SubProtocolHandler) - Constructor for class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
-
- SubscribableChannelManagement - Interface in org.springframework.integration.support.management
-
Metrics for subscribable channels.
- SubscribableJmsChannel - Class in org.springframework.integration.jms
-
- SubscribableJmsChannel(AbstractMessageListenerContainer, JmsTemplate) - Constructor for class org.springframework.integration.jms.SubscribableJmsChannel
-
- SubscribableKafkaChannel - Class in org.springframework.integration.kafka.channel
-
Subscribable channel backed by a Kafka topic.
- SubscribableKafkaChannel(KafkaOperations<?, ?>, KafkaListenerContainerFactory<?>, String) - Constructor for class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
-
Construct an instance with the provided parameters.
- SubscribableRedisChannel - Class in org.springframework.integration.redis.channel
-
- SubscribableRedisChannel(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- subscribe(MessageHandler) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
-
- subscribe(MessageHandler) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
-
- subscribe(Subscriber<? super Message<?>>) - Method in class org.springframework.integration.channel.FluxMessageChannel
-
- subscribe(IntegrationFlow) - Method in class org.springframework.integration.dsl.BroadcastPublishSubscribeSpec
-
- subscribe(IntegrationFlow) - Method in class org.springframework.integration.dsl.PublishSubscribeSpec
-
- subscribe(MessageHandler) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
- subscribe(MessageHandler) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
-
- subscribe(MessageHandler) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- subscribe(MessageHandler) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
-
- subscribeSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
-
The
Consumer
callback to configure a consuming socket.
- subscribeTo(Publisher<? extends Message<?>>) - Method in class org.springframework.integration.channel.FluxMessageChannel
-
- subscribeTo(Publisher<? extends Message<?>>) - Method in interface org.springframework.integration.channel.ReactiveStreamsSubscribableChannel
-
- subscribeToPublisher(Publisher<? extends Message<?>>) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- subscribeToTopics(String...) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
-
- SUBSCRIPTION - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
-
- subscriptionDurable(boolean) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
-
- subscriptionDurable(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPublishSubscribeMessageChannelSpec
-
- subscriptionShared(boolean) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
-
Set whether to make the subscription shared.
- subscriptionShared(boolean) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
-
- substituteMessageHandlerFor(String, MessageHandler) - Method in class org.springframework.integration.test.context.MockIntegrationContext
-
- substituteMessageHandlerFor(String, MessageHandler, boolean) - Method in class org.springframework.integration.test.context.MockIntegrationContext
-
- substituteMessageSourceFor(String, MessageSource<?>) - Method in class org.springframework.integration.test.context.MockIntegrationContext
-
- substituteMessageSourceFor(String, MessageSource<?>, boolean) - Method in class org.springframework.integration.test.context.MockIntegrationContext
-
- suffix(String) - Method in class org.springframework.integration.dsl.RouterSpec
-
- suggestedClassName() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
-
- SUPPLIER_GET_METHOD - Static variable in class org.springframework.integration.util.ClassUtils
-
The Supplier.get()
method object.
- SupplierExpression<T> - Class in org.springframework.integration.expression
-
- SupplierExpression(Supplier<T>) - Constructor for class org.springframework.integration.expression.SupplierExpression
-
- supplyCustomHeaders(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
Override to provide additional headers.
- SUPPORTED_JSON_TYPES - Static variable in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
-
- supports(Class<?>) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
-
- supports(Class<?>) - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
-
- supports(HandlerResult) - Method in class org.springframework.integration.webflux.inbound.IntegrationHandlerResultHandler
-
- supportsEventType(ResolvableType) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- supportsParameter(MethodParameter) - Method in class org.springframework.integration.handler.support.CollectionArgumentResolver
-
- supportsParameter(MethodParameter) - Method in class org.springframework.integration.handler.support.MapArgumentResolver
-
- supportsParameter(MethodParameter) - Method in class org.springframework.integration.handler.support.PayloadExpressionArgumentResolver
-
- supportsParameter(MethodParameter) - Method in class org.springframework.integration.handler.support.PayloadsArgumentResolver
-
- supportsSingleFileFiltering() - Method in class org.springframework.integration.file.filters.AbstractFileListFilter
-
- supportsSingleFileFiltering() - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
-
- supportsSingleFileFiltering() - Method in interface org.springframework.integration.file.filters.FileListFilter
-
Indicates that this filter supports filtering a single file.
- supportsSingleFileFiltering() - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
-
- supportsSourceType(Class<?>) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- sync(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
- syncCommits(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
-
Set whether or not to call consumer.commitSync() or commitAsync() when the
container is responsible for commits.
- synchronizer - Variable in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
-
- synchronizeToLocalDirectory(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- synchronizeToLocalDirectory(File, int) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- synchronizeToLocalDirectory(File) - Method in interface org.springframework.integration.file.remote.synchronizer.InboundFileSynchronizer
-
Synchronize all available files to the local directory;
- synchronizeToLocalDirectory(File, int) - Method in interface org.springframework.integration.file.remote.synchronizer.InboundFileSynchronizer
-
Synchronize up to maxFetchSize files to the local directory;
- syndFeedInput(SyndFeedInput) - Method in class org.springframework.integration.feed.dsl.FeedEntryMessageSourceSpec
-
- SYSLOG_PAYLOAD_ENTRIES - Static variable in class org.springframework.integration.syslog.DefaultMessageConverter
-
- SyslogHeaders - Class in org.springframework.integration.syslog
-
- SyslogInboundChannelAdapterParser - Class in org.springframework.integration.syslog.config
-
Parses a <int-syslog:inbound-channel-adapter/>
.
- SyslogInboundChannelAdapterParser() - Constructor for class org.springframework.integration.syslog.config.SyslogInboundChannelAdapterParser
-
- SyslogNamespaceHandler - Class in org.springframework.integration.syslog.config
-
Namspace handler for spring-integration-syslog.
- SyslogNamespaceHandler() - Constructor for class org.springframework.integration.syslog.config.SyslogNamespaceHandler
-
- SyslogReceivingChannelAdapterFactoryBean - Class in org.springframework.integration.syslog.config
-
Factory bean to create syslog inbound adapters (UDP or TCP).
- SyslogReceivingChannelAdapterFactoryBean(SyslogReceivingChannelAdapterFactoryBean.Protocol) - Constructor for class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- SyslogReceivingChannelAdapterFactoryBean.Protocol - Enum in org.springframework.integration.syslog.config
-
- SyslogReceivingChannelAdapterSupport - Class in org.springframework.integration.syslog.inbound
-
Base support class for inbound channel adapters.
- SyslogReceivingChannelAdapterSupport() - Constructor for class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
-
- syslogToMap() - Static method in class org.springframework.integration.dsl.Transformers
-
- SyslogToMapTransformer - Class in org.springframework.integration.transformer
-
Transforms a packet in Syslog (RFC3164) format to a Map.
- SyslogToMapTransformer() - Constructor for class org.springframework.integration.transformer.SyslogToMapTransformer
-
- SyslogToMapTransformerParser - Class in org.springframework.integration.config.xml
-
- SyslogToMapTransformerParser() - Constructor for class org.springframework.integration.config.xml.SyslogToMapTransformerParser
-