Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
S
- sameExceptIgnorableHeaders(Message<P>, String...) - Static method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
- SampleFacade - Interface in org.springframework.integration.support.management.metrics
- 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.
- scatter_gather - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- scatterGather(Consumer<RecipientListRouterSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
ScatterGatherHandler
to the current integration flow position based on the providedRecipientListRouterSpec
for scattering function and defaultAggregatorSpec
for gathering function. - scatterGather(Consumer<RecipientListRouterSpec>, Consumer<AggregatorSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
ScatterGatherHandler
to the current integration flow position based on the providedRecipientListRouterSpec
for scattering function andAggregatorSpec
for gathering function. - scatterGather(Consumer<RecipientListRouterSpec>, Consumer<AggregatorSpec>, Consumer<ScatterGatherSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
ScatterGatherHandler
to the current integration flow position based on the providedRecipientListRouterSpec
for scattering function andAggregatorSpec
for gathering function. - scatterGather(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
ScatterGatherHandler
to the current integration flow position based on the providedMessageChannel
for scattering function and defaultAggregatorSpec
for gathering function. - scatterGather(MessageChannel, Consumer<AggregatorSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
ScatterGatherHandler
to the current integration flow position based on the providedMessageChannel
for scattering function andAggregatorSpec
for gathering function. - scatterGather(MessageChannel, Consumer<AggregatorSpec>, Consumer<ScatterGatherSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
ScatterGatherHandler
to the current integration flow position based on the providedMessageChannel
for scattering function andAggregatorSpec
for gathering function. - ScatterGatherHandler - Class in org.springframework.integration.scattergather
-
The
MessageHandler
implementation for the Scatter-Gather EIP pattern. - ScatterGatherHandler(MessageChannel, MessageHandler) - Constructor for class org.springframework.integration.scattergather.ScatterGatherHandler
- ScatterGatherHandler(MessageHandler, 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
-
A
GenericEndpointSpec
extension for theScatterGatherHandler
. - 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
-
An
AbstractScriptExecutingMessageProcessor
implementation for evaluating scripts from the providedScriptSource
in the providedScriptExecutor
against an optional bindingvariables
. - ScriptExecutingMessageProcessor(ScriptSource, ScriptExecutor) - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
-
Create a processor for the
ScriptSource
using the providedScriptExecutor
using the DefaultScriptVariableGenerator - ScriptExecutingMessageProcessor(ScriptSource, ScriptExecutor, Map<String, Object>) - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
-
Create a processor for the
ScriptSource
using the providedScriptExecutor
using the DefaultScriptVariableGenerator - ScriptExecutingMessageProcessor(ScriptSource, ScriptVariableGenerator, ScriptExecutor) - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
-
Create a processor for the
ScriptSource
using the providedScriptExecutor
- ScriptExecutingMessageSource - Class in org.springframework.integration.scripting
-
The
MessageSource
strategy implementation to produce aMessage
from underlying ScriptExecutingMessageSource.scriptMessageProcessor for polling endpoints. - ScriptExecutingMessageSource(AbstractScriptExecutingMessageProcessor<?>) - Constructor for class org.springframework.integration.scripting.ScriptExecutingMessageSource
- ScriptExecutingProcessorFactory - Class in org.springframework.integration.scripting.config
-
The factory to create
AbstractScriptExecutingMessageProcessor
instances for provided arguments. - 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 bindingvariables
. - 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
-
The
MessageSourceSpec
for Dynamic Language Scripts. - ScriptMessageSourceSpec(String) - Constructor for class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
- ScriptMessageSourceSpec(Resource) - 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
-
An
AbstractScriptParser
parser extension for the<int-script:script>
tag. - 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
-
The
MessageProcessorSpec
implementation for theDslScriptExecutingMessageProcessor
. - 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
-
A
SearchTermStrategy
to use. - SearchTermStrategy - Interface in org.springframework.integration.mail
-
Strategy to be used to generate a
SearchTerm
. - SecuredChannel - Annotation Interface in org.springframework.integration.security.channel
-
Deprecated.
- SecuredChannelsParser - Class in org.springframework.integration.security.config
-
Deprecated.since 6.0 in favor of literally
new AuthorizationChannelInterceptor(AuthorityAuthorizationManager.hasAnyRole())
- SecuredChannelsParser() - Constructor for class org.springframework.integration.security.config.SecuredChannelsParser
-
Deprecated.
- SecurityContextPropagationChannelInterceptor - Class in org.springframework.integration.security.channel
-
The
ExecutorChannelInterceptor
implementation responsible for theSecurityContext
propagation from one message flow's thread to another through theMessageChannel
s involved in the flow. - SecurityContextPropagationChannelInterceptor() - Constructor for class org.springframework.integration.security.channel.SecurityContextPropagationChannelInterceptor
- SecurityIntegrationConfigurationInitializer - Class in org.springframework.integration.security.config
-
Deprecated, for removal: This API element is subject to removal in a future version.since 6.0 in favor of literally
new AuthorizationChannelInterceptor(AuthorityAuthorizationManager.hasAnyRole())
- SecurityIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.security.config.SecurityIntegrationConfigurationInitializer
-
Deprecated.
- selectImports(AnnotationMetadata) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptorImportSelector
- selector(String) - 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(Expression) - Method in class org.springframework.integration.dsl.WireTapSpec
-
Specify an
Expression
for selector. - selector(MessageSelector) - Method in class org.springframework.integration.dsl.WireTapSpec
- 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(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.ImapIdleChannelAdapterSpec
-
Configure an
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(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- send(String) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
- send(Message<?>) - 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<?>) - Method in class org.springframework.integration.channel.NullChannel
- send(Message<?>) - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
- send(Message<?>) - Method in class org.springframework.integration.dsl.support.MessageChannelReference
- 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(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Send a message on this channel.
- send(Message<?>, long) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
- send(Message<?>, long) - Method in class org.springframework.integration.channel.NullChannel
- send(Message<?>, long) - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
- send(Message<?>, long) - Method in class org.springframework.integration.dsl.support.MessageChannelReference
- 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<?>, String, FileExistsMode...) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
- 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<?>, FileExistsMode...) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
- SEND_TIMEOUT_ATTRIBUTE - Static variable in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- SEND_TIMER_NAME - Static variable in interface org.springframework.integration.support.management.IntegrationManagement
- sendAccess() - Element in annotation interface org.springframework.integration.security.channel.SecuredChannel
-
Deprecated.
- sendAck(Message<byte[]>) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
- sendAndReceive(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- sendAndReceive(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.MessagingTemplate
- 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(String) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Set the failure channel.
- sendFailureChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Set the channel to which failed send results are sent.
- sendFailureChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Set the failure channel.
- sendFailureChannel(MessageChannel) - 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
-
Deprecated, for removal: This API element is subject to removal in a future version.since 6.1 in favor of async hands-off downstream in the flow, e.g.
ExecutorChannel
. - sendMessage(E, InetSocketAddress, CacheListeningPolicyType) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer.AbstractHazelcastEventListener
- 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
- sendPartialResultsOnExpiry() - Element in annotation interface org.springframework.integration.annotation.Aggregator
-
Specify whether messages that expired should be aggregated and sent to the
Aggregator.outputChannel()
orreplyChannel
from message headers. - sendSocketConfigurer(Consumer<ZMQ.Socket>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
-
The
Consumer
callback to configure a publishing socket. - sendSuccessChannel(String) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Set the success channel.
- sendSuccessChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Set the channel to which successful send results are sent.
- sendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Set the success channel.
- sendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Set the channel to which successful send results are sent.
- sendTimeout() - Element in annotation interface org.springframework.integration.annotation.Aggregator
-
Specify the maximum amount of time in milliseconds to wait when sending a reply
Message
to theAggregator.outputChannel()
. - sendTimeout() - Element in annotation interface org.springframework.integration.annotation.Filter
-
Specify the maximum amount of time in milliseconds to wait when sending a reply
Message
to theFilter.outputChannel()
. - sendTimeout() - Element in annotation interface org.springframework.integration.annotation.Router
-
Specify the maximum amount of time in milliseconds to wait when sending a reply
Message
to theoutputChannel
. - sendTimeout() - Element in annotation interface org.springframework.integration.annotation.ServiceActivator
-
Specify the maximum amount of time in milliseconds to wait when sending a reply
Message
to theoutputChannel
. - sendTimeout() - Element in annotation interface org.springframework.integration.annotation.Splitter
-
Specify the maximum amount of time in milliseconds to wait when sending a reply
Message
to theoutputChannel
. - sendTimeout() - Element in annotation interface org.springframework.integration.annotation.Transformer
-
Specify the maximum amount of time in milliseconds to wait when sending a reply
Message
to theoutputChannel
. - 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.file.dsl.TailAdapterSpec
- sendTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Specify a timeout in milliseconds how long
KafkaProducerMessageHandler
should wait for send operation results. - 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(Supplier<SendTimers>) - Method in interface org.springframework.integration.graph.SendTimersAware
- SendTimers - Class in org.springframework.integration.graph
-
Success and failure timer stats.
- SendTimers(TimerStats, TimerStats) - Constructor for class org.springframework.integration.graph.SendTimers
- 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<?>) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
- serializer(Serializer<Object>) - Static method in class org.springframework.integration.dsl.Transformers
- 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
-
An
HttpMessageConverter
implementation forSerializable
instances. - SerializingHttpMessageConverter() - Constructor for class org.springframework.integration.http.converter.SerializingHttpMessageConverter
-
Creates a new instance of the
SerializingHttpMessageConverter
. - server() - Element in annotation interface org.springframework.integration.jmx.config.EnableIntegrationMBeanExport
-
The bean name of the MBeanServer to which MBeans should be exported.
- SERVER - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
- ServerRSocketConnector - Class in org.springframework.integration.rsocket
-
A server
AbstractRSocketConnector
extension to accept and manage client RSocket connections. - ServerRSocketConnector(ServerTransport<CloseableChannel>) - Constructor for class org.springframework.integration.rsocket.ServerRSocketConnector
-
Instantiate a server connector based on the provided
ServerTransport
. - ServerRSocketConnector(String, int) - Constructor for class org.springframework.integration.rsocket.ServerRSocketConnector
-
Instantiate a server connector based on the
TcpServerTransport
. - 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(HttpServer) - Constructor for class org.springframework.integration.rsocket.ServerRSocketConnector
-
Instantiate a server connector based on the
WebsocketServerTransport
. - ServerRSocketMessageHandler - Class in org.springframework.integration.rsocket
-
An
IntegrationRSocketMessageHandler
extension for RSocket service side. - ServerRSocketMessageHandler() - Constructor for class org.springframework.integration.rsocket.ServerRSocketMessageHandler
-
Create an service side RSocket message handler instance for delegating to
IntegrationRSocketEndpoint
beans and collectRSocketRequester
s from client connections. - ServerRSocketMessageHandler(boolean) - Constructor for class org.springframework.integration.rsocket.ServerRSocketMessageHandler
-
Create an service side RSocket message handler instance for delegating to
IntegrationRSocketEndpoint
beans and collectRSocketRequester
s from client connections. - 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
-
The
AbstractSingleBeanDefinitionParser
implementation for the<websocket:server-container/>
element. - ServerWebSocketContainerParser() - Constructor for class org.springframework.integration.websocket.config.ServerWebSocketContainerParser
- service_activator - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- 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 Interface 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
-
Post-processor for Methods annotated with
@ServiceActivator
. - ServiceActivatorAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.ServiceActivatorAnnotationPostProcessor
- ServiceActivatorFactoryBean - Class in org.springframework.integration.config
-
FactoryBean for creating
ServiceActivatingHandler
instances. - 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
- ServiceActivators - Annotation Interface in org.springframework.integration.annotation
-
The repeatable container for
ServiceActivator
annotations. - 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(Session) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
A Java Mail
Session
to use. - session(Session) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
-
Provide the Java Mail
Session
to use. - Session<F> - Interface in org.springframework.integration.file.remote.session
-
Common abstraction for a Session with a remote File system.
- 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(int) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
- sessionAcknowledgeMode(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
- 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 - Class in org.springframework.integration.sftp.server
-
An event emitted when a session is closed.
- SessionClosedEvent(FtpSession) - Constructor for class org.springframework.integration.ftp.server.SessionClosedEvent
- SessionClosedEvent(ServerSession) - Constructor for class org.springframework.integration.sftp.server.SessionClosedEvent
- sessionFactory - Variable in class org.springframework.integration.file.remote.RemoteFileTemplate
-
The
SessionFactory
for acquiring remote file Sessions. - 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
-
A factory returning a
SessionFactory
based on some key. - SessionFactoryMapBuilder<T> - Class in org.springframework.integration.file.remote.session
-
A
MapBuilder
to producer a map that maps objects toSessionFactory
s. - 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 - Class in org.springframework.integration.sftp.server
-
An event emitted when a session is opened.
- SessionOpenedEvent(FtpSession) - Constructor for class org.springframework.integration.ftp.server.SessionOpenedEvent
- 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.JmsPollableMessageChannelSpec
-
Configure transactional sessions for both the
JmsTemplate
(sends and polled receives) andDefaultMessageListenerContainer
(message-driven receives). - sessionTransacted(Boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
- set(int, Properties) - Method in class org.springframework.integration.history.MessageHistory
- set(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
- 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 ifFilteringMessageListenerAdapter
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.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
-
Specify a callback
Function
to be called against eachNamedComponent
to populate additional properties to the targetIntegrationNode
. - setAdmin(AmqpAdmin) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
Set the advice chain to be configured within an
AbstractReplyProducingMessageHandler
to advise just this local endpoint. - 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
-
Configure a list of
Advice
s to proxy aAbstractReplyProducingMessageHandler.handleRequestMessage(Message)
method. - setAdviceChain(List<Advice>) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.scheduling.PollerMetadata
- setAdviceChain(Advice[]) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setAdviceMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
Set the registration id for
AdviceMessage
. - 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) - 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, 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.
- 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
-
When using a
AllowListDeserializingConverter
(the default) add patterns for packages/classes that are allowed to be deserialized. - setAllowUnknownKeys(boolean) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
When no
DefaultSftpSessionFactory.knownHosts
has been provided, set to true to unconditionally allow connecting to an unknown host or when a host's key has changed (seeknownHosts
). - 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.
- 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.
- 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
-
If true always delegate to the
SourceFactory
. - 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.FileWritingMessageHandler
-
If 'true' will append a new-line after each write.
- setAppendNewLine(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
- 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.jdbc.lock.DefaultLockRepository
- 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.AbstractMongoDbMessageSource
- 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.hazelcast.leader.LeaderInitiator
- 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.core.AbstractMqttClientManager
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
- 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.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.
- setApplySequence(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
- 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.
- setAssignmentDuration(Duration) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set the time to wait for partition assignment, when used as a gateway, to determine the default reply-to topic/partition.
- 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.
- setAsync(boolean) - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
-
Set to true if you don't want to block when sending messages.
- setAsync(Boolean) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
Currently only exposed on the service activator namespace.
- setAsyncEvents(boolean) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
When
MqttPahoMessageHandler.setAsync(boolean)
is true, setting this to true enables publication ofMqttMessageSentEvent
andMqttMessageDeliveredEvent
to be emitted. - setAsyncEvents(boolean) - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
-
When
Mqttv5PahoMessageHandler.setAsync(boolean)
is true, setting this to true enables publication ofMqttMessageSentEvent
andMqttMessageDeliveredEvent
to be emitted. - setAsyncExecutor(Executor) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set the executor for use when the gateway method returns
Future
orListenableFuture
. - setAttributeName(String) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
-
Specify the name of the attribute to be retrieved.
- setAttributeVariablesExpression(Expression) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
-
Configure expression to evaluate request attribute which will be added to webclient request attribute.
- 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
-
Configure a
boolean
flag to close the folder automatically after a fetch (default) or populate an additionalIntegrationMessageHeaderAccessor.CLOSEABLE_RESOURCE
message header instead. - setAutoCloseFolder(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
- setAutoCreate(boolean) - Method in class org.springframework.integration.config.ChannelInitializer
- 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.
- setAutoCreateDirectory(Boolean) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
- setAutoCreateDirectory(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
- 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.endpoint.AbstractEndpoint
- setAutoStartup(boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
- setAutoStartup(boolean) - Method in class org.springframework.integration.hazelcast.leader.LeaderInitiator
- 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
- setAutoStartup(Boolean) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
- setAutoStartup(Boolean) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
- 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(int) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
Configure a batch size for the COUNT option during reading.
- 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.jdbc.store.JdbcMessageStore
- 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.AbstractMethodAnnotationPostProcessor
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.ChannelInitializer
- 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.aggregator.FileAggregator
- 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.IntegrationMessageHandlerMethodFactory
- 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
-
Allows to set the optional
BeanFactory
which is used to add aBeanResolver
to theStandardEvaluationContext
. - 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.support.json.Jackson2JsonMessageParser
- 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.dsl.StandardIntegrationFlow
- 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.mqtt.core.AbstractMqttClientManager
- 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
-
Set to true to bind the source message in the header named
IntegrationMessageHeaderAccessor.SOURCE_DATA
. - setBindSourceMessage(boolean) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Set to true to bind the source message in the header named
IntegrationMessageHeaderAccessor.SOURCE_DATA
. - setBindSourceRecord(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
-
Set to true to bind the source consumer record in the header named
IntegrationMessageHeaderAccessor.SOURCE_DATA
. - setBindSourceRecord(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
Set to true to bind the source consumer record in the header named
IntegrationMessageHeaderAccessor.SOURCE_DATA
. - setBodyExtractor(BodyExtractor<?, ? super ClientHttpResponse>) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
-
Specify a
BodyExtractor
as an alternative to theexpectedResponseType
to allow to get low-level access to the receivedClientHttpResponse
. - setBoundaryTrigger(Predicate<Message<?>>) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
Configure a
Predicate
for messages to determine a window boundary in theFlux.windowUntil(java.util.function.Predicate<T>)
operator. - 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
- setBufferSize(Integer) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
- setBusyWaitMillis(long) - Method in class org.springframework.integration.hazelcast.leader.LeaderInitiator
-
Time in milliseconds to wait in between attempts to acquire the lock, if it is not held.
- setBusyWaitMillis(long) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
- setBytesMessageMapper(BytesMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
Set a
BytesMessageMapper
to use when mapping byte[]. - setBytesMessageMapper(BytesMessageMapper) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Set a
BytesMessageMapper
to use when mapping byte[]. - setBytesPerMessage(int) - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
- setCacheCapacity(int) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
-
Set the capacity of cached locks.
- setCacheCapacity(int) - Method in class org.springframework.integration.redis.util.RedisLockRegistry
-
Set the capacity of cached locks.
- setCacheCapacity(int) - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
-
Set the capacity of cached locks.
- setCacheEventTypes(String) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer
- setCacheExpression(Expression) - Method in class org.springframework.integration.hazelcast.outbound.HazelcastCacheWritingMessageHandler
- 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
- setCacheListeningPolicy(CacheListeningPolicyType) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer
- setCacheManager(CacheManager) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
-
Configure a common
CacheManager
if someCacheOperation
comes without it. - setCacheOperations(CacheOperation...) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
-
Configure a set of
CacheOperation
which are going to be applied to theAbstractReplyProducingMessageHandler.RequestHandler#handleRequestMessage(Message)
method viaCacheRequestHandlerAdvice.IntegrationCacheAspect
. - setCacheResolver(CacheResolver) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
-
Configure a common
CacheResolver
if someCacheOperation
comes without it. - 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
-
Configure a
Candidate
for leader election. - 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
- 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
-
Set the database specific
ChannelMessageStoreQueryProvider
to use. - 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
-
Specify the
DestinationResolver
strategy to use. - setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
Specify the
DestinationResolver
strategy to use. - setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
Specify the
DestinationResolver
strategy to use. - 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.
- setChannelsAutoCreate(boolean) - Method in class org.springframework.integration.context.IntegrationProperties
-
Configure a value for
IntegrationProperties.CHANNELS_AUTOCREATE
option. - setChannelsMaxBroadcastSubscribers(int) - Method in class org.springframework.integration.context.IntegrationProperties
-
Configure a value for
IntegrationProperties.CHANNELS_MAX_BROADCAST_SUBSCRIBERS
option. - setChannelsMaxUnicastSubscribers(int) - Method in class org.springframework.integration.context.IntegrationProperties
-
Configure a value for
IntegrationProperties.CHANNELS_MAX_UNICAST_SUBSCRIBERS
option. - 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(String) - Method in class org.springframework.integration.file.transformer.FileToStringTransformer
-
Set the charset name to use when copying the File to a String.
- 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
- 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(Charset) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
-
Sets the character set used for writing form data.
- 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.
- setChmod(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
- 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
-
If set to
true
theEntityManager.clear()
will be called, and only if theEntityManager.flush()
was called after performing persistence operations. - setClient(CuratorFramework) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
- setClient(T) - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
- setClientId(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
- setClientLibraryUrl(String) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
- 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
- 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. - setClientRSocketConnector(ClientRSocketConnector) - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
-
Configure a
ClientRSocketConnector
for client side requests based on the connection provided by theClientRSocketConnector.getRequester()
. - 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
-
Configure a
BiFunction
to extract a key for mapping connectedRSocketRequester
s. - 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
-
A
ServerCodecConfigurer
for the request readers and response writers. - 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.AbstractMongoDbMessageSource
-
Set the SpEL
Expression
that should resolve to a collection name used by theQuery
. - setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
- setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
-
Set the SpEL
Expression
that should resolve to a collection name used byMongoOperations
to store data - setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
-
Set a SpEL
Expression
that should resolve to a collection name used byReactiveMongoOperations
to store data - 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
-
Sets the collection type for this handler as per
RedisCollectionFactoryBean.CollectionType
. - setCombineFunction(Function<Flux<Message<?>>, Mono<Message<?>>>) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
Configure a transformation
Function
to apply for aFlux
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<? extends 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. - setComparator(Comparator<File>) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
- 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 theGroovyClassLoader
's compiler should be customised for theCompileStatic
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.core.AbstractMqttClientManager
-
Set the completion timeout for operations.
- setCompletionTimeout(long) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
-
Set the completion timeout for operations.
- setCompletionTimeout(long) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
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
- 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
- setCondition(String) - Method in class org.springframework.integration.mongodb.store.MessageDocument
- setCondition(String) - Method in interface org.springframework.integration.store.MessageGroup
-
Add a condition statement to this group which can be consulted later on, e.g.
- setCondition(String) - Method in class org.springframework.integration.store.MessageGroupMetadata
- setCondition(String) - Method in class org.springframework.integration.store.SimpleMessageGroup
- 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.
- setConfirmTimeout(long) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Set the confirm timeout.
- 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.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(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(AbstractClientConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
- setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- 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(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
-
Deprecated.since 5.5.17 in favor of standard
MqttConnectOptions.setCleanSession(boolean)
. Will be removed in 6.1.0. - 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
-
Set the content type header value to add to inbound messages when
addContentTypeHeader
is true. - setContentType(String) - Method in class org.springframework.integration.json.ObjectToJsonTransformer
-
Set 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
-
Specify the
ConversionService
to use when trying to convert to requested type. - setConversionService(ConversionService) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
- setConversionService(ConversionService) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
- setConverter(Converter<T, U>) - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
-
Specify the converter to use.
- setConverter(MqttMessageConverter) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
- setConverter(MqttMessageConverter) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- setConverter(MessageConverter) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
- setConverter(MessageConverter) - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
-
A
MessageConverter
to convert the byte array payload of the underlying UDP/TCP message to a Spring Integration message with decoded payload and headers; default isDefaultMessageConverter
. - 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. - 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.
- 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
-
Set as false to disable copying the group in
SimpleMessageStore.getMessageGroup(Object)
. - 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
-
Configure a
CorrelationStrategy
to determine a group key from the incoming messages. - 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
- setCreateIndexes(boolean) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
Define the option to auto create indexes or not.
- 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
-
Configure a set of converters to use in the
MappingMongoConverter
. - setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
- setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
-
Sets a
GroovyObjectCustomizer
for this processor. - setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
Sets a
GroovyObjectCustomizer
for this processor. - 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.AbstractMappingMessageRouter
-
Set the default channel where Messages should be sent if channel resolution fails to return any channels.
- 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.AbstractMappingMessageRouter
-
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.router.AbstractMessageRouter
- setDefaultOverwrite(boolean) - Method in class org.springframework.integration.transformer.HeaderEnricher
- setDefaultPriority(int) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Specify the default JMS priority to use when sending request Messages with no
IntegrationMessageHeaderAccessor.PRIORITY
header. - setDefaultQos(int) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
Set the qos for messages if the
qosExpression
evaluates to null. - 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 - 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
-
Set the retained boolean for messages if the
retainedExpression
evaluates to null. - 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 adviseDelayHandler.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.FileWritingMessageHandler
-
Specify whether to delete source Files after writing to the destination directory.
- setDeleteSourceFiles(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
- 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 message.
- 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.core.AbstractMqttClientManager
-
Set the completion timeout when disconnecting.
- setDisconnectCompletionTimeout(long) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
-
Set the completion timeout when disconnecting.
- setDisconnectCompletionTimeout(long) - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
Set the completion timeout when disconnecting.
- setDisconnectDelay(long) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
- setDispatcherExecutor(Executor) - Method in class org.springframework.integration.jdbc.channel.PostgresSubscribableChannel
-
Set the executor to use for dispatching newly received messages.
- setDistributedObject(DistributedObject) - Method in class org.springframework.integration.hazelcast.outbound.HazelcastCacheWritingMessageHandler
- setDocumentBuilder(DocumentBuilderFactory) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
- setDomain(String) - Method in class org.springframework.integration.smb.session.SmbConfig
- setDomainType(Class<?>) - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
-
Specify an object type to convert an event body to.
- 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
- setEmbeddedPartsAsBytes(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
- 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.
- 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.tail.ApacheCommonsFileTailingMessageProducer
-
If true, tail from the end of the file, otherwise include all lines from the beginning.
- setEnd(Boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
- setEndpoints(IntegrationRSocketEndpoint...) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
-
Configure
IntegrationRSocketEndpoint
instances for mapping and handling requests. - setEndpointUri(String) - Method in class org.springframework.integration.camel.outbound.CamelMessageHandler
-
Set Camel route endpoint uri to send a message.
- setEndpointUriExpression(Expression) - Method in class org.springframework.integration.camel.outbound.CamelMessageHandler
-
Set Camel route endpoint uri to send a message.
- setEntityClass(Class<?>) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Set the class type which is being used for retrieving entities from the database.
- setEntityClass(Class<?>) - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
-
Set the type of the entityClass that will be passed to the find MongoDb template operation.
- setEntityClass(Class<?>) - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
- setEntityManager(EntityManager) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
- setEntityManagerFactory(EntityManagerFactory) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
- 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 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.
- setErrorChannelIgnoreFailures(boolean) - Method in class org.springframework.integration.context.IntegrationProperties
-
Configure a value for
IntegrationProperties.ERROR_CHANNEL_IGNORE_FAILURES
option. - 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
-
Specify a
MessageChannel
bean name for async error processing. - 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
- setErrorChannelRequireSubscribers(boolean) - Method in class org.springframework.integration.context.IntegrationProperties
-
Configure a value for
IntegrationProperties.ERROR_CHANNEL_REQUIRE_SUBSCRIBERS
option. - 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(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(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(ErrorHandler) - Method in class org.springframework.integration.jdbc.channel.PostgresSubscribableChannel
-
Set a
ErrorHandler
for messages which cannot be dispatched by this channel. - setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.scheduling.PollerMetadata
- setErrorHandler(ResponseErrorHandler) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Set the
ResponseErrorHandler
for the underlyingRestTemplate
. - setErrorMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
Set the registration id for
ErrorMessage
. - 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
-
Set an
ErrorMessageStrategy
to use to build an error message when a exception occurs. - setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
- setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set an
ErrorMessageStrategy
to use to build an error message when a exception occurs. - 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 aMessageTimeoutException
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
-
Specify the expected
XPathEvaluationType
. - 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
- setExchangePattern(ExchangePattern) - Method in class org.springframework.integration.camel.outbound.CamelMessageHandler
- setExchangePatternExpression(Expression) - Method in class org.springframework.integration.camel.outbound.CamelMessageHandler
- setExchangeProperties(Map<String, Object>) - Method in class org.springframework.integration.camel.outbound.CamelMessageHandler
- setExchangePropertiesExpression(Expression) - Method in class org.springframework.integration.camel.outbound.CamelMessageHandler
-
Set a SpEL expression to evaluate
Exchange
properties as aMap
. - 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.
- setExecutionIdExpression(Expression) - Method in class org.springframework.integration.graphql.outbound.GraphQlMessageHandler
-
Set a SpEL expression to evaluate Execution Id for GraphQL Operation Request to execute.
- 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. - setExecutor(ExecutorService) - Method in class org.springframework.integration.jdbc.channel.PostgresChannelMessageTableSubscriber
-
Define an executor to use for listening for new messages.
- 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
-
Specify an
FtpRemoteFileTemplate.ExistsMode
forFtpRemoteFileTemplate.exists(String)
operation. - setExpectedResponseType(Class<?>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Specify the expected response type for the REST request.
- 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 ofClass
orString
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.
- 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.AbstractMongoDbMessageSource
-
Manage which find* method to invoke.
- 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(Long) - Method in class org.springframework.integration.support.MessageBuilder
- setExpirationDate(Date) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
- 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. - 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
- 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(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
- setExpression(Expression) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
Set a SpEL expression to use.
- 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 anExtensionElement
for theStanza.addExtension(ExtensionElement)
instead ofbody
. - setExtractBody(boolean) - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
-
Configure this channel adapter to build a
Message
to produce with a payload based on aChangeStreamEvent.getBody()
(by default) or use a wholeChangeStreamEvent
as a payload. - 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.hazelcast.outbound.HazelcastCacheWritingMessageHandler
- 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 asMessage
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
-
A flag to return the whole
WebServiceMessage
or buildpayload
based onWebServiceMessage
and populated headers accordingheaderMapper
configuration. - setExtractPayload(boolean) - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
-
Specify whether the source Message's payload should be extracted prior to marshalling.
- setExtractPayload(Boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- 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.
- setExtractResponseBody(boolean) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
The flag to extract a body of the
ResponseEntity
for reply message payload. - 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
-
Set the name of the properties file in
PropertiesPersistingMetadataStore.setBaseDirectory(String)
. - 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
-
Set the file name expression to determine the full path to the remote file when retrieving a file using the
RemoteFileTemplate.get(Message, InputStreamCallback)
method, with the message being the root object of the evaluation. - 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(NotificationFilter) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
Specify a
NotificationFilter
to be passed to the server when registering this listener. - 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
-
Set a
FileListFilter
to filter remote files. - 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(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
-
Set a
FileListFilter
. - setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.HeadDirectoryScanner
- setFilter(CollectionFilter<Resource>) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
- setFilterHeadersInToMessage(boolean) - Method in class org.springframework.integration.support.converter.MapMessageConverter
-
By default all headers on Map passed to
MapMessageConverter.toMessage(Object, MessageHeaders)
will be mapped. - setFilterInRetry(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
The
boolean
flag to specify the order in which the filter and retry operations are performed. - 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
-
If set to
true
theEntityManager.flush()
will be called after persistence operation. - 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
-
Set the frequency to flush buffers when
FileExistsMode.APPEND_NO_FLUSH
is being used. - 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
-
Set a
FileWritingMessageHandler.MessageFlushPredicate
to use when flushing files whenFileExistsMode.APPEND_NO_FLUSH
is being used. - setFlushSize(int) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
If the provided value is greater than
0
, thenEntityManager.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
-
Specify the
JpaOutboundGateway
mode. - 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
-
Set the registration id for
GenericMessage
. - setGlobalMethodMetadata(GatewayMethodMetadata) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
- setGroupCondition(Object, String) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- setGroupCondition(Object, String) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- setGroupCondition(Object, String) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- setGroupCondition(Object, String) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
- setGroupCondition(Object, String) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- setGroupCondition(Object, String) - Method in interface org.springframework.integration.store.MessageGroupStore
-
Add a condition sentence into the group.
- setGroupCondition(Object, String) - Method in class org.springframework.integration.store.SimpleMessageStore
- setGroupConditionSupplier(BiFunction<Message<?>, String, String>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
Configure a
BiFunction
to supply a group condition from a message to be added to the group. - setGroupConditionSupplier(BiFunction<Message<?>, String, String>) - Method in class org.springframework.integration.config.AggregatorFactoryBean
- setGroupCreatedTime(long) - Method in class org.springframework.integration.mongodb.store.MessageDocument
- setGroupId(Object) - 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.
- 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
-
(Optional) Set the
HashMapper
used to createReactiveRedisStreamMessageHandler.reactiveStreamOperations
. - setHashMapRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
Set the registration id for
HashMap
. - setHazelcastRegisteredEventListenerId(UUID) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer
- 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
-
Provide the map of
HeaderValueMessageProcessor
to evaluate when enriching the target MessageHeaders. - 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
-
Set a custom
AmqpHeaderMapper
to replace the defaultDefaultAmqpHeaderMapper.inboundMapper()
. - setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Set a custom
AmqpHeaderMapper
for mapping request and reply headers. - setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Set a custom
AmqpHeaderMapper
for mapping request and reply headers. - 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(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 theMimeMessage
content. - setHeaderMapper(HeaderMapper<MimeMessage>) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
- setHeaderMapper(HeaderMapper<Message>) - Method in class org.springframework.integration.camel.outbound.CamelMessageHandler
-
Set a
HeaderMapper
to map request message headers into Apache Camel message headers and back if request-reply exchange pattern is used. - setHeaderMapper(HeaderMapper<MqttProperties>) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- setHeaderMapper(HeaderMapper<MqttProperties>) - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- 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(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
- setHeaderMapper(KafkaHeaderMapper) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set the header mapper to use.
- 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
-
Headers to be converted in
MapMessageConverter.fromMessage(Message, Class)
. - 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
-
Specify a
Function
to mapMessageGroup
into composed headers for output message. - 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 afterward.
- 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.
- setHeadersMappedLast(boolean) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
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.hazelcast.leader.LeaderInitiator
-
Time in milliseconds to wait in between attempts to re-acquire the lock, once it is held.
- 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 to connect to.
- setHost(String) - Method in class org.springframework.integration.smb.session.SmbConfig
- setHost(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
- setHostConfig(HostConfigEntry) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Provide a
HostConfigEntry
as an alternative for the user/host/port options. - setHttpMessageCacheSize(int) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
- setHttpMethod(HttpMethod) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Specify the
HttpMethod
for requests. - setHttpMethodExpression(Expression) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
-
Specify the SpEL
Expression
to determineHttpMethod
at runtime. - setIdExpression(Expression) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Set the expression that will be evaluated to get the
primaryKey
forEntityManager.find(Class, Object)
. - 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
-
How often to emit
FileTailingMessageProducerSupport.FileTailingIdleEvent
s in milliseconds. - 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
-
Specify whether
Exceptions
thrown byDelayHandler.delayExpression
evaluation should be ignored (only logged). - 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.router.AbstractMessageRouter
-
Specify whether send failures for one or more of the recipients should be ignored.
- setIgnoreSendFailures(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
- 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.camel.support.CamelHeaderMapper
-
Provide a list of patterns to map Apache Camel message headers into Spring Integration message.
- 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.mqtt.support.MqttHeaderMapper
-
Provide a list of patterns to map MQTT message properties into message 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.
- setIncludeValue(boolean) - Method in class org.springframework.integration.hazelcast.inbound.HazelcastContinuousQueryMessageProducer
- 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.
- setIngestQuery(String) - Method in class org.springframework.integration.cassandra.outbound.CassandraMessageHandler
- setInitialDuration(Duration) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
-
Specify the delay for the initial execution.
- setInitialized(boolean) - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
- 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
-
Configure an
RSocketInteractionModel
for the RSocket request type. - 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
-
Configure a set of
RSocketInteractionModel
this endpoint is mapped onto. - 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(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(TcpConnectionInterceptorFactory[]) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactoryChain
- 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.
- setIterationType(DistributedSQLIterationType) - Method in class org.springframework.integration.hazelcast.inbound.HazelcastDistributedSQLMessageSource
- setIterator(boolean) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
- 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
-
Defines the maximum number of
SimpleJdbcCallOperations
A value of zero will disable the cache. - setJdbcTemplate(JdbcTemplate) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
The
JdbcOperations
to use when interacting with the database. - 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
-
An
JsonObjectMapper
to be used for the conversion to/from JSON. - 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.hazelcast.outbound.HazelcastCacheWritingMessageHandler
- 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.
- setKnownHostsResource(Resource) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Specifies a
Resource
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.MessageGroupMetadata
- 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.MessageGroupMetadata
- 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; defaulttrue
, 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
-
Specify if the result of the
BasicMessageGroupStore.getMessageGroup(Object)
should be wrapped to thePersistentMessageGroup
- a lazy-load proxy for messages in group Defaults totrue
. - setLazyLoadMessageGroups(boolean) - Method in class org.springframework.integration.store.SimpleMessageStore
- setLeaderEventPublisher(LeaderEventPublisher) - Method in class org.springframework.integration.hazelcast.leader.LeaderInitiator
-
Sets the
LeaderEventPublisher
. - setLeaderEventPublisher(LeaderEventPublisher) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
Set the
LeaderEventPublisher
. - setLeaderEventPublisher(LeaderEventPublisher) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
A
LeaderEventPublisher
option for events from theLeaderInitiator
. - setLeaderEventPublisher(LeaderEventPublisher) - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
-
Sets the
LeaderEventPublisher
. - 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 beLPUSH
orRPUSH
. - 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
-
Set the logging
LoggingHandler.Level
to change the behavior at runtime. - setLimitForPeriod(int) - Method in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
-
Change the
limitForPeriod
option of theRateLimiterRequestHandlerAdvice.rateLimiter
. - 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
-
Provide a
LoadBalancingStrategy
for this dispatcher. - 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.
- setLocale(Locale) - Method in class org.springframework.integration.graphql.outbound.GraphQlMessageHandler
-
Set a Locale for GraphQL Operation to execute.
- 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(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
-
Set a
FileLocker
to be used to guard files against duplicate processing. - setLocker(AbstractFileLockerFilter) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
- 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
-
Set an
Expression
to evaluate a log entry at runtime against the requestMessage
. - 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
-
If true, DNS reverse lookup is done on the remote ip address.
- 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.core.AbstractMqttClientManager
- setManualAcks(boolean) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
-
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(ObjectMapper) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
- 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
- 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
-
Specify the maximum number of Messages to fetch per call to
AbstractMailReceiver.receive()
. - 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
-
Configure a cap for messages to poll from the source per scheduling cycle.
- 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(int) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
The maximum number of rows to query.
- setMaxRows(Integer) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
The maximum number of rows to query.
- setMaxSubscribers(int) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
-
Specify the maximum number of subscribers supported by the channel's dispatcher (if it is an
AbstractDispatcher
). - 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
-
Specify a
MessageCollectionCallback
to perform against MongoDB collection in the request message context. - 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/fromMessage
. - setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
-
Set a custom
MessageConverter
to replace the defaultSimpleMessageConverter
. - 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(MessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
Set the message converter; must be a
RecordMessageConverter
orBatchMessageConverter
depending on mode. - setMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
-
Set the
RecordMessageConverter
to the listener. - setMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
-
Set the message converter; must be a
RecordMessageConverter
orBatchMessageConverter
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.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.handler.support.IntegrationMessageHandlerMethodFactory
- 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
-
Provide a
MessageConverter
(as an alternative toZeroMqMessageProducer.messageMapper
) for converting a consumed data into a message to produce. - setMessageConverter(MessageConverter) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
-
Provide a
MessageConverter
(as an alternative toZeroMqMessageHandler.messageMapper
) for converting a request message intobyte[]
for sending into ZeroMq socket. - setMessageConverter(SmartMessageConverter) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- 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
-
Set a list of
HttpMessageConverter
s to be used by the underlyingRestTemplate
. - 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
-
Specify the
MessageGroupFactory
to createMessageGroup
object where it is necessary. - setMessageGroupFactory(MessageGroupFactory) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
-
Specify the
MessageGroupFactory
to createMessageGroup
object where it is necessary. - setMessageGroupFactory(MessageGroupFactory) - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
-
Specify the
MessageGroupFactory
to createMessageGroup
object where it is necessary. - 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
-
Set the registration id for
MessageHeaders
. - 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
-
Provide an
InboundMessageMapper
to convert a consumed data into a message to produce. - setMessageMapper(OutboundMessageMapper<byte[]>) - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
-
Provide an
OutboundMessageMapper
to convert a request message intobyte[]
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
- setMessageRecoverer(MessageRecoverer) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
Configure a
MessageRecoverer
for retry operations. - setMessageRecoverer(MessageRecoverer) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
Configure a
MessageRecoverer
for retry operations. - setMessageRowMapper(MessageRowMapper) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Allow for passing in a custom
MessageRowMapper
. - 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
- 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
- setMessagingTemplateThrowExceptionOnLateReply(boolean) - Method in class org.springframework.integration.context.IntegrationProperties
-
Configure a value for
IntegrationProperties.THROW_EXCEPTION_ON_LATE_REPLY
option. - 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
- setMethodNames(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
Configure a set of supported HTTP methods from their string representations.
- setMethods(HttpMethod...) - Method in class org.springframework.integration.http.inbound.RequestMapping
- setMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
- setMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
- 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
-
If at least this number of subscribers receive the message,
AbstractMessageChannel.send(org.springframework.messaging.Message)
will return true. - setMinSubscribers(int) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
If at least this number of subscribers receive the message,
BroadcastingDispatcher.dispatch(Message)
will return true. - setMissingQueuesFatal(Boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
-
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
-
Allow providing 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. - setMonitorEventTypes(String) - Method in class org.springframework.integration.hazelcast.inbound.HazelcastClusterMonitorMessageProducer
- setMputFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
A
FileListFilter
that runs against the local file system view when usingMPUT
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
-
Specify the
MultipartFileReader
to use when readingMultipartFile
content. - setMultipartResolver(MultipartResolver) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Specify the
MultipartResolver
to use when checking requests. - setMultiSend(boolean) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- setMutableMessageHeadersRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
Set the registration id for
MutableMessageHeaders
. - setMutableMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
-
Set the registration id for
MutableMessage
. - 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
- setNoAutoStartupEndpoints(String...) - Method in class org.springframework.integration.context.IntegrationProperties
-
Configure a value for
IntegrationProperties.ENDPOINTS_NO_AUTO_STARTUP
option. - 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
- setObjectMapper(HashMapper<?, ?, ?>) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
Configure a hash mapper.
- setObjectName(String) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
-
Specify the String value of the JMX MBean's
ObjectName
. - 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.
- 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.
- setObjectNameStaticProperties(Map<String, String>) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
Static properties that will be added to all object names.
- setObservationConvention(MessageReceiverObservationConvention) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
Set a custom
MessageReceiverObservationConvention
forIntegrationObservation.HANDLER
. - setObservationConvention(MessageReceiverObservationConvention) - Method in class org.springframework.integration.handler.AbstractMessageHandler
-
Set a custom
MessageReceiverObservationConvention
forIntegrationObservation.HANDLER
. - setObservationConvention(MessageReceiverObservationConvention) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
- setObservationConvention(MessageRequestReplyReceiverObservationConvention) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- setObservationConvention(MessageRequestReplyReceiverObservationConvention) - Method in class org.springframework.integration.jms.JmsInboundGateway
- setObservationConvention(MessageSenderObservationConvention) - Method in class org.springframework.integration.channel.AbstractMessageChannel
- setObservationPatterns(String...) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
-
Set simple patterns for component names matching which has to be instrumented with a
ObservationRegistry
. - setObservationRegistry(ObservationRegistry) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
-
Set an
ObservationRegistry
to populate to theIntegrationManagement
components in the application context. - setObservationRegistry(ObservationRegistry) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
- setOnErrorResume(Function<? super Throwable, ? extends Publisher<Void>>) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
Configure a resume Function to resume the main sequence when polling the stream fails.
- 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 duringConsumerSeekAware.onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)
call from theKafkaMessageListenerContainer
. - setOnPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
Specify a
BiConsumer
for seeks management duringConsumerSeekAware.onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)
call from theKafkaMessageListenerContainer
. - 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.
- setOperation(String) - Method in class org.springframework.integration.graphql.outbound.GraphQlMessageHandler
-
Specify a GraphQL Operation.
- setOperationExpression(Expression) - Method in class org.springframework.integration.graphql.outbound.GraphQlMessageHandler
-
Specify a SpEL expression to evaluate a GraphQL Operation
- setOperationName(String) - Method in class org.springframework.integration.graphql.outbound.GraphQlMessageHandler
-
Set a GraphQL Operation Name to execute.
- 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.
- setOperationNameExpression(Expression) - Method in class org.springframework.integration.graphql.outbound.GraphQlMessageHandler
-
Set a SpEL expression to evaluate a GraphQL Operation Name to execute.
- 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
-
Specify a
ChangeStreamOptions
. - setOrder(int) - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
- 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
- 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).
- setOrigin(String) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
- setOrigin(String...) - Method in class org.springframework.integration.http.inbound.CrossOrigin
- setOutboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setOutboundHeaderNames(String...) - Method in class org.springframework.integration.camel.support.CamelHeaderMapper
-
Provide a list of patterns to map Spring Integration message headers into an Apache Camel message.
- 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.mqtt.support.MqttHeaderMapper
-
Provide a list of patterns to map header into a PUBLISH MQTT message.
- 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
-
Specify the
MessageChannel
to which produced Messages should be sent. - setOutputChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
Specify the
MessageChannel
where Messages should be sent. - 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>, AbstractMessageProducingHandler) - Static method in class org.springframework.integration.config.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
-
Specify a
MessageGroupProcessor
for the output function. - 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.
- setParameterExpressions(Map<String, Expression>) - Method in class org.springframework.integration.cassandra.outbound.CassandraMessageHandler
- 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.smb.session.SmbConfig
- 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 incomingMessage
. - setPayloadExpressionString(String) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
- setPayloadType(JavaType) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
- 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.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
-
Set the type of the target message payload to produce after conversion from MQTT message.
- 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(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.
- setPersistence(MqttClientPersistence) - Method in class org.springframework.integration.mqtt.core.Mqttv3ClientManager
-
Set the
MqttClientPersistence
for a client. - setPersistence(MqttClientPersistence) - Method in class org.springframework.integration.mqtt.core.Mqttv5ClientManager
-
Set the
MqttClientPersistence
for a client. - setPersistence(MqttClientPersistence) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- setPersistence(MqttClientPersistence) - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- 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.hazelcast.leader.LeaderInitiator
- 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.mqtt.core.AbstractMqttClientManager
-
Set the phase of component autostart in
SmartLifecycle
. - 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.
- setPollTimeout(Duration) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
Configure a poll timeout for the BLOCK option during reading.
- 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
-
Adjust 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
-
Perform a
MessageBuilder.popSequenceDetails()
for output message or not. - 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.smb.session.SmbConfig
- 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.config.RouterFactoryBean
- 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 database 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
-
Specify a
MessagePreparedStatementSetter
to populate parameters on thePreparedStatement
with theMessage
context. - setPreparedStatementSetter(ChannelMessageStorePreparedStatementSetter) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Set a
ChannelMessageStorePreparedStatementSetter
to insert message into the database. - 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.
- setPreserveTimestamp(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
- setPreserveWireFeed(boolean) - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
-
Specify a flag to indication if
WireFeed
should be preserved in the targetSyndFeed
. - 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(boolean) - Method in class org.springframework.integration.store.MessageGroupQueue
-
If true, ensures that the message store supports priority.
- setPriority(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
- setPriority(Integer) - Method in class org.springframework.integration.mongodb.store.MessageDocument
- 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
-
Enable a priority handling in this store.
- 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
-
Set a
KafkaProducerMessageHandler.ProducerRecordCreator
to create theProducerRecord
. - setProduces(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
- setProducesReply(boolean) - Method in class org.springframework.integration.cassandra.outbound.CassandraMessageHandler
- 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 defaultDefaultMessagePropertiesConverter
. - 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.
- setPropertyReference(String) - Method in record class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor.BeanDefinitionPropertiesMapper
- setPropertyReference(String, String) - Method in record class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor.BeanDefinitionPropertiesMapper
- setPropertyValue(String) - Method in record class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor.BeanDefinitionPropertiesMapper
- setPropertyValue(String, String) - Method in record class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor.BeanDefinitionPropertiesMapper
- 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
-
The protocol used in
SSLContext.getInstance(String)
; default "TLS". - 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
- 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 wholemessage
must be wrapped to theMessagingEvent
. - 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']".
- setQuery(String) - Method in class org.springframework.integration.cassandra.outbound.CassandraMessageHandler
- 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.jmx.MBeanTreePollingMessageSource
- setQueryNameReference(ObjectName) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
- setQueryType(R2dbcMessageHandler.Type) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
-
Set a
R2dbcMessageHandler.Type
for query to execute. - setQueryTypeExpression(Expression) - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
-
Set a SpEL expression to evaluate a
R2dbcMessageHandler.Type
for query to execute. - 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
-
Set to true to include the raw spring-amqp message as a header with key
AmqpMessageHeaderErrorMessageStrategy.AMQP_RAW_MESSAGE
, enabling callers to have access to the message to process errors. - setRawMessageHeader(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
-
Set to true to include the raw
ConsumerRecord
as headers with keysKafkaHeaders.RAW_DATA
andIntegrationMessageHeaderAccessor.SOURCE_DATA
. - setReactiveAdapterRegistry(ReactiveAdapterRegistry) - Method in class org.springframework.integration.webflux.inbound.WebFluxInboundEndpoint
-
A registry of adapters to adapt a Reactive Streams
Publisher
to/from. - setReactiveCustomizer(Function<? super Flux<Message<?>>, ? extends Publisher<Message<?>>>) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
- setReactiveCustomizer(Function<? super Flux<Message<?>>, ? extends Publisher<Message<?>>>) - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
- 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.context.IntegrationProperties
-
Configure a value for
IntegrationProperties.READ_ONLY_HEADERS
option. - 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 aMessage
includingZeroMqHeaders.TOPIC
header (if any). - setReceiverObservationConvention(MessageReceiverObservationConvention) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- setReceiverObservationConvention(MessageReceiverObservationConvention) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
- setReceiveTimeout(int) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
- 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
-
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
-
This timeout (milliseconds) is used when retrieving elements from the queue specified by
RedisQueueInboundGateway.boundListOperations
. - setReceiveTimeout(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
This timeout (milliseconds) is used when retrieving elements from the queue specified by
RedisQueueMessageDrivenEndpoint.boundListOperations
. - setReceiveTimeout(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
- setReceiveTimeout(Long) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
- 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 wrapKafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener
intoFilteringMessageListenerAdapter
. - 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<?>) - 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<?>) - 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). - 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
- setRecoveryInterval(int) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
Specify a reconnect interval in milliseconds in case of lost connection.
- 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.redis.inbound.RedisQueueInboundGateway
- setRecoveryInterval(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
- setRecoveryInterval(Long) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
- setRedisLockType(RedisLockRegistry.RedisLockType) - Method in class org.springframework.integration.redis.util.RedisLockRegistry
-
Set
RedisLockRegistry.RedisLockType
mode to work in. - 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
- 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
- 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.
- 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
-
Set
releasePartialSequences
on an underlying defaultSequenceSizeReleaseStrategy
. - 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
- 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
-
Set to true to immediately remove the channel mapping when
DefaultHeaderChannelRegistry.channelNameToChannel(String)
is invoked. - 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.tail.ApacheCommonsFileTailingMessageProducer
-
If true, close and reopen the file between reading chunks; default false.
- setReopen(Boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
- 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.support.AbstractIntegrationMessageBuilder
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.support.MessageBuilder
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Set the content enricher 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
-
Specify the key to be used when adding the reply Message or payload to the core map (will be payload only unless the value of
BaseHttpInboundEndpoint.setExtractReplyPayload(boolean)
isfalse
). - 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 theMono
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
-
/** Set a
SqlParameterSourceFactory
for select query. - 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.gateway.GatewayMessageHandler
- setReplyTimeout(Long) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Set the timeout value for receiving reply messages.
- setReplyTimeout(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
- 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.transformer.ContentEnricher
-
Set the content enricher 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.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
-
Set the
ClientHttpRequestFactory
for the underlyingRestTemplate
. - 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 asend
orsendAndReceive
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
-
Set a
MessagePreparedStatementSetter
for update query. - setRequestPubSubDomain(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Specify whether the request destination is a Topic.
- setRequestReplyObservationConvention(MessageRequestReplyReceiverObservationConvention) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
- setRequestSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
Set a
SqlParameterSourceFactory
for update query. - 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.gateway.GatewayMessageHandler
- setRequestTimeout(Long) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Set the timeout value for sending request messages.
- setRequestTimeout(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
- 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
- setRequiresReply(Boolean) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
- setRequiresReply(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
- 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.
- setResolutionRequired(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
- 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.jdbc.channel.PostgresSubscribableChannel
-
Set the retry template to use for retries in case of exception in downstream processing
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
-
Specify a
RetryTemplate
instance to use for retrying deliveries. - setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
-
Specify a
RetryTemplate
instance to use for retrying deliveries. - 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
- 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
- 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 beBRPOP
orBLPOP
. - 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
-
Configure a role for
DefaultCandidate
. - 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.
- setRoute(LambdaRouteBuilder) - Method in class org.springframework.integration.camel.outbound.CamelMessageHandler
-
Set a
LambdaRouteBuilder
to add an inline Camel route definition. - 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
-
Set a select result
RowMapper
. - setRowMapper(RowMapper<?>) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
Set a
RowMapper
. - setRSocketConnector(AbstractRSocketConnector) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
-
Provide an
AbstractRSocketConnector
reference for an explicit endpoint mapping. - setRSocketStrategies(RSocketStrategies) - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
-
Configure a
RSocketStrategies
for data encoding/decoding. - setRSocketStrategies(RSocketStrategies) - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
-
Configure an
RSocketStrategies
instead of a default one. - setRSocketStrategies(RSocketStrategies) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
- setScanEachPoll(boolean) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
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.
- setScanEachPoll(Boolean) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
- 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
FileReadingMessageSource.WatchServiceDirectoryScanner
. - setScanner(DirectoryScanner) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
Switch the local
FileReadingMessageSource
to use a customDirectoryScanner
. - setSearchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
- setSearchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.mail.ImapMailReceiver
-
Provides a way to set custom
SearchTermStrategy
to compile aSearchTerm
to be applied when retrieving mail. - 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.
- setSendBufferOverflowStrategy(ConcurrentWebSocketSessionDecorator.OverflowStrategy) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
-
Set the send buffer overflow strategy.
- setSendBufferSizeLimit(int) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
- setSendFailureChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Set the failure channel.
- setSendFailureChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set the failure channel.
- setSendFailureChannelName(String) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Set the failure channel name.
- 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
-
Deprecated, for removal: This API element is subject to removal in a future version.since 6.0.5 in favor of async hands-off downstream in the flow, e.g.
ExecutorChannel
. - 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.amqp.outbound.RabbitStreamMessageHandler
-
Set the success channel.
- setSendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set the success channel.
- setSendSuccessChannelName(String) - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
-
Set the Success channel name.
- 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.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.FileTailInboundChannelAdapterFactoryBean
- 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
-
Specify a timeout in milliseconds for how long this
KafkaProducerMessageHandler
should wait for send operation results. - 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
- 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.file.config.FileWritingMessageHandlerFactoryBean
- setSendTimeout(Long) - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
- 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 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(Serializer<Object>) - Method in class org.springframework.integration.transformer.PayloadSerializingTransformer
- setSerializer(RedisSerializationContext.SerializationPair<?>) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
Configure a key, hash key and hash value serializer.
- 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
- 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.
- setServerConfigurer(Consumer<RSocketServer>) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
-
Provide a
Consumer
to configure theRSocketServer
. - setServiceName(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
- setSession(Session) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Set the
Session
. - setSession(Session) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
- setSessionAcknowledgeMode(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
- setSessionAcknowledgeMode(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
- 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.
- setSessionAcknowledgeModeName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
- 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.
- setSftpVersionSelector(SftpVersionSelector) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
- setShareAndDir(String) - Method in class org.springframework.integration.smb.session.SmbConfig
- 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.file.config.FileTailInboundChannelAdapterFactoryBean
- 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
-
Specify if the
IntegrationResourceHolderSynchronization.resourceHolder
should be unbound from the Thread Local store at transaction completion or not. - 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
-
MimeMessage.getContent()
returns just the email body. - 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 correspondingSqlOutParameter
declaration will be bypassed. - setSmbMaxVersion(DialectVersion) - Method in class org.springframework.integration.smb.session.SmbConfig
-
Sets the desired maximum SMB version value for what the Windows server will allow during protocol transport negotiation.
- setSmbMinVersion(DialectVersion) - Method in class org.springframework.integration.smb.session.SmbConfig
-
Sets the desired minimum SMB version value for what the Windows server will allow during protocol transport negotiation.
- setSocket(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
- setSocket(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- 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
- setSocketAttributes(Socket) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Sets socket attributes on the socket.
- 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
- 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
- setSockJsTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
-
Configure a
TaskScheduler
for SockJS fallback service. - 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(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.config.SourcePollingChannelAdapterFactoryBean
- 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
-
Configure an
SqlParameterSourceFactory
. - setSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
Provides the ability to set a custom
SqlParameterSourceFactory
. - 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(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
- setSslHandshakeTimeout(Integer) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
Set the SSL handshake timeout (only used with SSL and NIO).
- setStanzaFilter(StanzaFilter) - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
-
Specify a
StanzaFilter
to use for the incoming packets. - setStatementExpression(Expression) - Method in class org.springframework.integration.cassandra.outbound.CassandraMessageHandler
- setStatementExpressionString(String) - Method in class org.springframework.integration.cassandra.outbound.CassandraMessageHandler
- setStatementProcessor(MessageProcessor<Statement<?>>) - Method in class org.springframework.integration.cassandra.outbound.CassandraMessageHandler
- 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
-
Using the
StoredProcExecutor.storedProcedureNameExpression
theMessage
can be used as source for the name of the Stored Procedure or Stored Function. - 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
-
Set
ReactiveStreamOperations
used to customize theStreamReceiver
. - setStrictOrder(boolean) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
The flag indicating if the local cache has to be fully clear on failure to preserve a processing order of remote files on the next
AbstractMessageSource.receive()
attempt. - 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.config.RouterFactoryBean
- 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.
- 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.amqp.outbound.RabbitStreamMessageHandler
-
Set to true to wait for a confirmation.
- setSync(boolean) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
A
boolean
indicating if theKafkaProducerMessageHandler
should wait for the send operation results or not. - 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.
- setTargetType(Class<?>) - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
-
Configure a hash target type.
- setTaskExecutor(Executor) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- setTaskExecutor(Executor) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
- 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
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
A task executor; default is a
SimpleAsyncTaskExecutor
. - 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
- setTaskSchedulerPoolSize(int) - Method in class org.springframework.integration.context.IntegrationProperties
-
Configure a value for
IntegrationProperties.TASK_SCHEDULER_POOL_SIZE
option. - setTcpNetConnectionSupport(TcpNetConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
-
Set the
TcpNetConnectionSupport
to use to create connection objects. - setTcpNetConnectionSupport(TcpNetConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
Set the
TcpNetConnectionSupport
to use to create connection objects. - setTcpNioConnectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
- setTcpNioConnectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
Set the
TcpNioConnectionSupport
to use. - setTcpSocketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
-
Set the
TcpSocketFactorySupport
used to create server sockets. - setTcpSocketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
Set the
TcpSocketFactorySupport
used to create server sockets. - 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
-
Set the underlying connection (or next interceptor).
- setThreadKey(Object) - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
-
Set a key to be used for
DelegatingSessionFactory.getSession()
on this thread. - setThreadKey(Message<?>, Object) - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
-
Messaging-friendly version of
DelegatingSessionFactory.setThreadKey(Object)
that can be invoked from a service activator. - 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.filter.MessageFilter
-
Specify whether this filter should throw a
MessageRejectedException
when its selector does not accept a Message. - setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
-
Specify whether this interceptor should throw a
MessageRejectedException
when its selector does not accept a Message. - setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
- setThrowExceptionOnRejection(Boolean) - Method in class org.springframework.integration.config.FilterFactoryBean
- 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(long) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
Timeout in milliseconds (default -1).
- 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.
- 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 whensync
is true. - setTimeoutDuration(Duration) - Method in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
-
Change the
timeoutDuration
option of theRateLimiterRequestHandlerAdvice.rateLimiter
. - 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.MessageGroupMetadata
- 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
-
Set the underlying
MulticastSocket
time to live property. - 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 otherSocketType
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.jdbc.channel.PostgresSubscribableChannel
-
Set the transaction manager to use for message processing.
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Set a
PlatformTransactionManager
for operations. - 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.MessagingAnnotationPostProcessor
- setUpdateExpression(Expression) - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
-
Specify an optional
update
for just polled records from the collection. - setUpdatePerRow(boolean) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
Set a flag to update per record or not.
- setUpdateSql(String) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
Set an update query.
- setUpdateSql(String) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
-
Set an update query that will be passed to the
DatabaseClient.sql(String)
method. - setUpdateSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
Set an
SqlParameterSourceFactory
for update query. - 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.
- setupMessageProcessor(MessageProcessor<?>) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
- setupResponseAndConvertReply(ServletServerHttpResponse, Message<?>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Converts the reply message to the appropriate HTTP reply object and sets up the
ServletServerHttpResponse
. - 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. - setUrl(String) - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
- setUseBroker(boolean) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
Specify if this adapter should use an existing single
AbstractBrokerMessageHandler
bean fornon-MESSAGE
WebSocketMessage
s and to route messages with broker destinations. - 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
-
Set the name of the flag to use to flag messages when the server does not support \Recent but supports user flags; default "spring-integration-mail-adapter".
- setUserFlag(String) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
- setUserInteraction(UserInteraction) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Provide a
UserInteraction
which exposes control over dealing with new keys or key changes. - setUsername(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
- setUsername(String) - Method in class org.springframework.integration.smb.session.SmbConfig
- setUseSpelInvoker(boolean) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
-
A
boolean
flag to use SpEL Expression evaluation orInvocableHandlerMethod
for target method invocation. - setUseSpelInvoker(boolean) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
-
A
boolean
flag to use SpEL Expression evaluation orInvocableHandlerMethod
for target method invocation. - setUseSpelInvoker(boolean) - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
-
A
boolean
flag to use SpEL Expression evaluation orInvocableHandlerMethod
for target method invocation. - setUseTemplateConverter(boolean) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
-
Set to true to use the template's message converter to create the
ProducerRecord
instead of theproducerRecordCreator
. - 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
-
Switch this
FileReadingMessageSource
to use its internalFileReadingMessageSource.WatchServiceDirectoryScanner
. - setUseWatchService(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
Switch the local
FileReadingMessageSource
to use its internalFileReadingMessageSource.WatchServiceDirectoryScanner
. - 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
-
Set to true to use direct buffers.
- 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(Object) - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
- setValue(Object) - Method in class org.springframework.integration.jpa.support.JpaParameter
- setValue(Object, Object) - Method in class org.springframework.integration.expression.DynamicExpression
- setValue(Object, Object) - Method in class org.springframework.integration.expression.FunctionExpression
- setValue(Object, Object) - Method in class org.springframework.integration.expression.SupplierExpression
- setValue(Object, Object) - Method in class org.springframework.integration.expression.ValueExpression
- setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
- setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.FunctionExpression
- setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.SupplierExpression
- setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
- setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.DynamicExpression
- setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.FunctionExpression
- setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.SupplierExpression
- setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.ValueExpression
- 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, 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, 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.
- setValues(PreparedStatement, Message<?>) - Method in interface org.springframework.integration.jdbc.MessagePreparedStatementSetter
-
Set parameter values on the given
PreparedStatement
and message context. - 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
-
Use a different serializer (default
JdkSerializationRedisSerializer
for theMessage
. - 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
-
Configure a SpEL
Expression
to evaluate aResolvableType
to instantiate the payload from the incoming JSON. - 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. - setVariablesExpression(Expression) - Method in class org.springframework.integration.graphql.outbound.GraphQlMessageHandler
-
Set a SpEL expression to evaluate Variables for GraphQL Operation to execute.
- 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
-
Adjust 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
-
The
WatchService
event types. - setWebServiceTemplate(WebServiceTemplate) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
- setWebSocketEnabled(boolean) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer.SockJsServiceOptions
- setWebSocketHandler(WebSocketHandler) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
-
Replace the default
WebSocketHandler
with the one provided here, e.g. - setWindowConfigurer(Function<Flux<Message<?>>, Flux<Flux<Message<?>>>>) - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
-
Configure a
Function
to apply a transformation into the groupingFlux
for any arbitraryFlux.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.
- setWriteOptions(WriteOptions) - Method in class org.springframework.integration.cassandra.outbound.CassandraMessageHandler
- 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
-
A
FileInfo
implementation for SFTP. - SftpFileInfo(SftpClient.DirEntry) - 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<SftpClient.DirEntry>, 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<SftpClient.DirEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
-
Create a synchronizer with the
SessionFactory
used to acquireSession
instances. - SftpInboundFileSynchronizingMessageSource - Class in org.springframework.integration.sftp.inbound
-
A
MessageSource
implementation for SFTP that delegates to an InboundFileSynchronizer. - SftpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<SftpClient.DirEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
- SftpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<SftpClient.DirEntry>, Comparator<File>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
- SftpMessageHandler - Class in org.springframework.integration.sftp.outbound
-
Subclass of
FileTransferringMessageHandler
for SFTP. - SftpMessageHandler(SessionFactory<SftpClient.DirEntry>) - Constructor for class org.springframework.integration.sftp.outbound.SftpMessageHandler
- SftpMessageHandler(SftpRemoteFileTemplate) - Constructor for class org.springframework.integration.sftp.outbound.SftpMessageHandler
- SftpMessageHandler(SftpRemoteFileTemplate, FileExistsMode) - Constructor for class org.springframework.integration.sftp.outbound.SftpMessageHandler
- SftpMessageHandlerSpec - Class in org.springframework.integration.sftp.dsl
- SftpMessageHandlerSpec(SessionFactory<SftpClient.DirEntry>) - Constructor for class org.springframework.integration.sftp.dsl.SftpMessageHandlerSpec
- 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(RemoteFileTemplate<SftpClient.DirEntry>, 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.
- SftpOutboundGateway(RemoteFileTemplate<SftpClient.DirEntry>, MessageSessionCallback<SftpClient.DirEntry, ?>) - 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<SftpClient.DirEntry>, 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(SessionFactory<SftpClient.DirEntry>, MessageSessionCallback<SftpClient.DirEntry, ?>) - 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.
- 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<SftpClient.DirEntry>) - 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
-
Implementation of
AbstractRegexPatternFileListFilter
for SFTP. - 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<SftpClient.DirEntry>) - Constructor for class org.springframework.integration.sftp.session.SftpRemoteFileTemplate
- SftpSession - Class in org.springframework.integration.sftp.session
-
Default SFTP
Session
implementation. - SftpSession(SftpClient) - Constructor for class org.springframework.integration.sftp.session.SftpSession
- SftpSimplePatternFileListFilter - Class in org.springframework.integration.sftp.filters
-
Implementation of
AbstractSimplePatternFileListFilter
for SFTP. - 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<SftpClient.DirEntry>, Comparator<SftpClient.DirEntry>) - 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<SftpClient.DirEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
-
Construct an instance with the supplied template.
- SftpStreamingMessageSource(RemoteFileTemplate<SftpClient.DirEntry>, Comparator<SftpClient.DirEntry>) - 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
-
SFTP implementation of
AbstractMarkerFilePresentFileListFilter
. - SftpSystemMarkerFilePresentFileListFilter(Map<FileListFilter<SftpClient.DirEntry>, Function<String, String>>) - Constructor for class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
- SftpSystemMarkerFilePresentFileListFilter(FileListFilter<SftpClient.DirEntry>) - Constructor for class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
- SftpSystemMarkerFilePresentFileListFilter(FileListFilter<SftpClient.DirEntry>, String) - Constructor for class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
- SftpSystemMarkerFilePresentFileListFilter(FileListFilter<SftpClient.DirEntry>, 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 interface org.springframework.integration.config.annotation.MethodAnnotationPostProcessor
- shouldCreateEndpoint(MergedAnnotations, List<Annotation>) - Method in interface org.springframework.integration.config.annotation.MethodAnnotationPostProcessor
- shouldCreateEndpoint(MergedAnnotations, List<Annotation>) - Method in class org.springframework.integration.config.BridgeFromAnnotationPostProcessor
- shouldCreateEndpoint(MergedAnnotations, List<Annotation>) - Method in class org.springframework.integration.config.BridgeToAnnotationPostProcessor
- 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.amqp.config.AmqpInboundChannelAdapterParser
- 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
-
Deprecated.
- 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.amqp.config.AmqpInboundChannelAdapterParser
- 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.
- shouldMarkSessionAsDirty(Exception) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
Determine whether
Session.dirty()
should be called in theRemoteFileTemplate.execute(SessionCallback)
when an exception is thrown from the callback. - shouldMarkSessionAsDirty(Exception) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
- shouldMarkSessionAsDirty(Exception) - Method in class org.springframework.integration.sftp.session.SftpRemoteFileTemplate
- shouldMarkSessionAsDirty(Exception) - Method in class org.springframework.integration.smb.session.SmbRemoteFileTemplate
- 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.aggregator.AggregatingMessageHandler
-
Check an
Iterable
result for split possibility on the output production: the items of the collection have to be instances ofMessage
orAbstractIntegrationMessageBuilder
andAbstractCorrelatingMessageHandler.getOutputProcessor()
has to be aSimpleMessageGroupProcessor
. - shouldSplitOutput(Iterable<?>) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
- shouldTrack() - Method in class org.springframework.integration.handler.MessageHandlerSupport
- 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(boolean) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
- 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.
- 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.ImapIdleChannelAdapterSpec
-
Determine how the content is rendered.
- 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 frombyte[]
. - 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(InboundMessageMapper<?>, OutboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
- SimpleMessageConverter(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(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
- SimpleMessageGroup(MessageGroup) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
- SimpleMessageGroupFactory - Class in org.springframework.integration.store
-
The
MessageGroupFactory
implementation to produceSimpleMessageGroup
instances. - SimpleMessageGroupFactory() - Constructor for class org.springframework.integration.store.SimpleMessageGroupFactory
- SimpleMessageGroupFactory(SimpleMessageGroupFactory.GroupType) - Constructor for class org.springframework.integration.store.SimpleMessageGroupFactory
- SimpleMessageGroupFactory.GroupType - Enum Class in org.springframework.integration.store
- SimpleMessageGroupProcessor - Class in org.springframework.integration.aggregator
-
A
MessageGroupProcessor
that simply returns the messages in the group. - 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
-
Map-based in-memory implementation of
MessageStore
andMessageGroupStore
. - SimpleMessageStore() - Constructor for class org.springframework.integration.store.SimpleMessageStore
-
Create a SimpleMessageStore with unlimited capacity.
- SimpleMessageStore(int) - Constructor for class org.springframework.integration.store.SimpleMessageStore
-
Creates a SimpleMessageStore with the same capacity for individual and grouped messages.
- 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
-
Create 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, 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, 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.
- SimpleMetadataStore - Class in org.springframework.integration.metadata
-
Simple implementation of
MetadataStore
that uses aConcurrentMap
for the data store. - SimpleMetadataStore() - Constructor for class org.springframework.integration.metadata.SimpleMetadataStore
-
Instantiate a
SimpleMetadataStore
using an in-memoryConcurrentHashMap
. - SimpleMetadataStore(ConcurrentMap<String, String>) - Constructor for class org.springframework.integration.metadata.SimpleMetadataStore
-
Instantiate a
SimpleMetadataStore
using the providedConcurrentMap
. - SimpleMultipartFileReader - Class in org.springframework.integration.http.multipart
-
MultipartFileReader
implementation that does not maintain metadata from the originalMultipartFile
instance. - 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
-
Create an instance with the provided
WebServiceTemplate
. - 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
-
A simple
PollSkipStrategy
to be used with aPollSkipAdvice
. - 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
-
Create 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(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
- 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
- SimpleWsInboundGatewaySpec - Class in org.springframework.integration.ws.dsl
-
The spec for a
SimpleWebServiceInboundGateway
. - 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
-
The spec for a
SimpleWebServiceOutboundGateway
. - SimpleWsOutboundGatewaySpec(WebServiceTemplate) - Constructor for class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
- SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec - Class in org.springframework.integration.ws.dsl
-
Spec for a
SimpleWebServiceOutboundGateway
where an externalWebServiceTemplate
is not provided. - SINGLE - Enum constant in enum class org.springframework.integration.hazelcast.CacheListeningPolicyType
-
Only the local Hazelcast node can accept event.
- 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
-
Convenience class for a single
RequestResponseScenario
test - 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 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
- SIZE - Static variable in class org.springframework.integration.mail.MailHeaders
- 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
- SMALLINT - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- SmartLifecycleRoleController - Class in org.springframework.integration.support
-
Bulk start/stop
SmartLifecycle
in a particular role in phase order. - SmartLifecycleRoleController() - Constructor for class org.springframework.integration.support.SmartLifecycleRoleController
-
Construct an instance without any lifecycle initially: can be added later on via
SmartLifecycleRoleController.addLifecycleToRole(String, SmartLifecycle)
. - 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.
- Smb - Class in org.springframework.integration.smb.dsl
-
The factory for SMB components.
- SmbConfig - Class in org.springframework.integration.smb.session
-
Data holder class for a SMB share configuration.
- SmbConfig() - Constructor for class org.springframework.integration.smb.session.SmbConfig
- SmbConfig(String, int, String, String, String, String) - Constructor for class org.springframework.integration.smb.session.SmbConfig
- SmbFileInfo - Class in org.springframework.integration.smb.session
-
An
AbstractFileInfo
implementation for SMB protocol. - SmbFileInfo(SmbFile) - Constructor for class org.springframework.integration.smb.session.SmbFileInfo
- SmbInboundChannelAdapterParser - Class in org.springframework.integration.smb.config
-
Parser for the SMB 'inbound-channel-adapter' element.
- SmbInboundChannelAdapterParser() - Constructor for class org.springframework.integration.smb.config.SmbInboundChannelAdapterParser
- SmbInboundChannelAdapterSpec - Class in org.springframework.integration.smb.dsl
- SmbInboundChannelAdapterSpec(SessionFactory<SmbFile>, Comparator<File>) - Constructor for class org.springframework.integration.smb.dsl.SmbInboundChannelAdapterSpec
- SmbInboundFileSynchronizer - Class in org.springframework.integration.smb.inbound
-
An implementation of
AbstractInboundFileSynchronizer
for SMB. - SmbInboundFileSynchronizer(SessionFactory<SmbFile>) - Constructor for class org.springframework.integration.smb.inbound.SmbInboundFileSynchronizer
-
Create a synchronizer with the
SessionFactory
used to acquireSession
instances. - SmbInboundFileSynchronizingMessageSource - Class in org.springframework.integration.smb.inbound
-
A
MessageSource
implementation for SMB. - SmbInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<SmbFile>) - Constructor for class org.springframework.integration.smb.inbound.SmbInboundFileSynchronizingMessageSource
- SmbInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<SmbFile>, Comparator<File>) - Constructor for class org.springframework.integration.smb.inbound.SmbInboundFileSynchronizingMessageSource
- SmbMessageHandler - Class in org.springframework.integration.smb.outbound
-
The SMB specific
FileTransferringMessageHandler
extension. - SmbMessageHandler(SessionFactory<SmbFile>) - Constructor for class org.springframework.integration.smb.outbound.SmbMessageHandler
- SmbMessageHandler(SmbRemoteFileTemplate) - Constructor for class org.springframework.integration.smb.outbound.SmbMessageHandler
- SmbMessageHandler(SmbRemoteFileTemplate, FileExistsMode) - Constructor for class org.springframework.integration.smb.outbound.SmbMessageHandler
- SmbMessageHandlerSpec - Class in org.springframework.integration.smb.dsl
-
A
FileTransferringMessageHandlerSpec
for SMB. - SmbMessageHandlerSpec(SessionFactory<SmbFile>) - Constructor for class org.springframework.integration.smb.dsl.SmbMessageHandlerSpec
- SmbMessageHandlerSpec(SmbRemoteFileTemplate) - Constructor for class org.springframework.integration.smb.dsl.SmbMessageHandlerSpec
- SmbMessageHandlerSpec(SmbRemoteFileTemplate, FileExistsMode) - Constructor for class org.springframework.integration.smb.dsl.SmbMessageHandlerSpec
- SmbNamespaceHandler - Class in org.springframework.integration.smb.config
-
Provides namespace support for using SMB.
- SmbNamespaceHandler() - Constructor for class org.springframework.integration.smb.config.SmbNamespaceHandler
- SmbOutboundChannelAdapterParser - Class in org.springframework.integration.smb.config
-
The parser for
<Int-smb:outbound-channel-adapter>
. - SmbOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.smb.config.SmbOutboundChannelAdapterParser
- SmbOutboundGateway - Class in org.springframework.integration.smb.outbound
-
Outbound Gateway for performing remote file operations via SMB.
- SmbOutboundGateway(RemoteFileTemplate<SmbFile>, String) - Constructor for class org.springframework.integration.smb.outbound.SmbOutboundGateway
-
Construct an instance with the supplied remote file template and command ('ls', 'nlst', 'put' or 'mput').
- SmbOutboundGateway(RemoteFileTemplate<SmbFile>, String, String) - Constructor for class org.springframework.integration.smb.outbound.SmbOutboundGateway
-
Construct an instance with the supplied remote file template, a command ('ls', 'get' etc), and an expression to determine the filename.
- SmbOutboundGateway(RemoteFileTemplate<SmbFile>, MessageSessionCallback<SmbFile, ?>) - Constructor for class org.springframework.integration.smb.outbound.SmbOutboundGateway
-
Construct an instance with the supplied remote file template and callback for performing operations on the session.
- SmbOutboundGateway(SessionFactory<SmbFile>, String) - Constructor for class org.springframework.integration.smb.outbound.SmbOutboundGateway
-
Construct an instance with the supplied session factory and command ('ls', 'nlst', 'put' or 'mput').
- SmbOutboundGateway(SessionFactory<SmbFile>, String, String) - Constructor for class org.springframework.integration.smb.outbound.SmbOutboundGateway
-
Construct an instance with the supplied session factory, a command ('ls', 'get' etc), and an expression to determine the filename.
- SmbOutboundGateway(SessionFactory<SmbFile>, MessageSessionCallback<SmbFile, ?>) - Constructor for class org.springframework.integration.smb.outbound.SmbOutboundGateway
-
Construct an instance using the provided session factory and callback for performing operations on the session.
- SmbOutboundGatewayParser - Class in org.springframework.integration.smb.config
-
Parser for the SMB 'outbound-gateway' element.
- SmbOutboundGatewayParser() - Constructor for class org.springframework.integration.smb.config.SmbOutboundGatewayParser
- SmbOutboundGatewaySpec - Class in org.springframework.integration.smb.dsl
-
A
RemoteFileOutboundGatewaySpec
for SMB. - SmbOutboundGatewaySpec(SmbOutboundGateway) - Constructor for class org.springframework.integration.smb.dsl.SmbOutboundGatewaySpec
- SmbPersistentAcceptOnceFileListFilter - Class in org.springframework.integration.smb.filters
-
Implementation of
AbstractPersistentAcceptOnceFileListFilter
for SMB. - SmbPersistentAcceptOnceFileListFilter(ConcurrentMetadataStore, String) - Constructor for class org.springframework.integration.smb.filters.SmbPersistentAcceptOnceFileListFilter
- SmbRegexPatternFileListFilter - Class in org.springframework.integration.smb.filters
-
Implementation of
AbstractRegexPatternFileListFilter
for SMB. - SmbRegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.smb.filters.SmbRegexPatternFileListFilter
- SmbRegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.smb.filters.SmbRegexPatternFileListFilter
- SmbRemoteFileTemplate - Class in org.springframework.integration.smb.session
-
The SMB-specific
RemoteFileTemplate
implementation. - SmbRemoteFileTemplate(SessionFactory<SmbFile>) - Constructor for class org.springframework.integration.smb.session.SmbRemoteFileTemplate
-
Construct a
SmbRemoteFileTemplate
with the supplied session factory. - SmbSession - Class in org.springframework.integration.smb.session
-
Implementation of the
Session
interface for Server Message Block (SMB) also known as Common Internet File System (CIFS). - SmbSession(SmbShare) - Constructor for class org.springframework.integration.smb.session.SmbSession
-
Constructor for an SMB session.
- SmbSessionFactory - Class in org.springframework.integration.smb.session
-
The SMB session factory.
- SmbSessionFactory() - Constructor for class org.springframework.integration.smb.session.SmbSessionFactory
- SmbSessionFactory(CIFSContext) - Constructor for class org.springframework.integration.smb.session.SmbSessionFactory
-
Initializes the SMB session factory with a custom client context configuration.
- SmbShare - Class in org.springframework.integration.smb.session
-
The
SmbFile
extension to represent an SMB share directory. - SmbShare(SmbConfig) - Constructor for class org.springframework.integration.smb.session.SmbShare
-
Initializes the jCIFS library with default properties.
- SmbShare(SmbConfig, Properties) - Constructor for class org.springframework.integration.smb.session.SmbShare
-
Initializes the jCIFS library with custom properties such as 'jcifs.smb.client.minVersion' and 'jcifs.smb.client.maxVersion' for setting the minimum/maximum SMB supported versions.
- SmbShare(SmbConfig, CIFSContext) - Constructor for class org.springframework.integration.smb.session.SmbShare
-
Initializes the jCIFS library with a custom client context configuration.
- SmbSimplePatternFileListFilter - Class in org.springframework.integration.smb.filters
-
Implementation of
AbstractSimplePatternFileListFilter
for SMB. - SmbSimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.smb.filters.SmbSimplePatternFileListFilter
- SmbStreamingInboundChannelAdapterParser - Class in org.springframework.integration.smb.config
-
Parser for the SMB 'inbound-streaming-channel-adapter' element.
- SmbStreamingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.smb.config.SmbStreamingInboundChannelAdapterParser
- SmbStreamingInboundChannelAdapterSpec - Class in org.springframework.integration.smb.dsl
- SmbStreamingInboundChannelAdapterSpec(RemoteFileTemplate<SmbFile>, Comparator<SmbFile>) - Constructor for class org.springframework.integration.smb.dsl.SmbStreamingInboundChannelAdapterSpec
- SmbStreamingMessageSource - Class in org.springframework.integration.smb.inbound
-
Message source for streaming SMB remote file contents.
- SmbStreamingMessageSource(RemoteFileTemplate<SmbFile>) - Constructor for class org.springframework.integration.smb.inbound.SmbStreamingMessageSource
-
Construct an instance with the supplied template.
- SmbStreamingMessageSource(RemoteFileTemplate<SmbFile>, Comparator<SmbFile>) - Constructor for class org.springframework.integration.smb.inbound.SmbStreamingMessageSource
-
Construct an instance with the supplied template and comparator.
- SmbSystemMarkerFilePresentFileListFilter - Class in org.springframework.integration.smb.filters
-
Implementation of
AbstractMarkerFilePresentFileListFilter
for SMB. - SmbSystemMarkerFilePresentFileListFilter(Map<FileListFilter<SmbFile>, Function<String, String>>) - Constructor for class org.springframework.integration.smb.filters.SmbSystemMarkerFilePresentFileListFilter
- SmbSystemMarkerFilePresentFileListFilter(FileListFilter<SmbFile>) - Constructor for class org.springframework.integration.smb.filters.SmbSystemMarkerFilePresentFileListFilter
- SmbSystemMarkerFilePresentFileListFilter(FileListFilter<SmbFile>, String) - Constructor for class org.springframework.integration.smb.filters.SmbSystemMarkerFilePresentFileListFilter
- SmbSystemMarkerFilePresentFileListFilter(FileListFilter<SmbFile>, Function<String, String>) - Constructor for class org.springframework.integration.smb.filters.SmbSystemMarkerFilePresentFileListFilter
- SOAP_ACTION - Static variable in class org.springframework.integration.ws.WebServiceHeaders
- SoapHeaderMapper - Interface in org.springframework.integration.ws
-
A convenience interface that extends
RequestReplyHeaderMapper
, parameterized withSoapHeader
. - socket(DatagramSocket) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
- 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
- socketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.dsl.TcpNetClientConnectionFactorySpec
-
Set the
TcpSocketFactorySupport
used to create server sockets. - socketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.dsl.TcpNetServerConnectionFactorySpec
-
Set the
TcpSocketFactorySupport
used to create server sockets. - 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
- socketSupport(TcpSocketSupport) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
- 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
-
Transforms the payload to a
Source
using aSourceFactory
. - 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 - Variable in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
- sourceExtractor(SourceExtractor<?>) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
-
Configure a
SourceExtractor
to use. - sourceExtractor(SourceExtractor<?>) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
-
Configure a
SourceExtractor
to use. - 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
-
A Channel Adapter implementation for connecting a
MessageSource
to aMessageChannel
. - 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
-
A
FactoryBean
implementation to encapsulate the population of a staticMethod
from the provided SpelFunctionFactoryBean.functionClass and SpelFunctionFactoryBean.functionMethodSignature as a validStandardEvaluationContext
function. - 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(Map<String, PropertyAccessor>) - Constructor for class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
-
Create an instance with the provided named property accessors.
- SpelPropertyAccessorRegistrar(PropertyAccessor...) - Constructor for class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
-
Create an instance with the provided 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
- SPIN_LOCK - Enum constant in enum class org.springframework.integration.redis.util.RedisLockRegistry.RedisLockType
-
The lock is acquired by periodically(100ms) checking whether the lock can be acquired.
- split() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
DefaultMessageSplitter
with default options to the current integration flow position. - split(Class<P>, Function<P, ?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MethodInvokingSplitter
to evaluate the providedFunction
at runtime. - split(Class<P>, Function<P, ?>, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MethodInvokingSplitter
to evaluate the providedFunction
at runtime. - 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) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
ExpressionEvaluatingSplitter
with provided SpEL expression. - 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(String, Consumer<SplitterEndpointSpec<ExpressionEvaluatingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
ExpressionEvaluatingSplitter
with provided SpEL expression. - split(Consumer<SplitterEndpointSpec<DefaultMessageSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
DefaultMessageSplitter
with provided options to the current integration flow position. - split(Function<P, ?>, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
-
Populate the
MethodInvokingSplitter
to evaluate the providedFunction
at runtime. - split(MessageHandlerSpec<?, S>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the provided
AbstractMessageSplitter
to the current integration flow position. - split(MessageHandlerSpec<?, S>, Consumer<SplitterEndpointSpec<S>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the provided
AbstractMessageSplitter
to the current integration flow position. - split(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MethodInvokingSplitter
to evaluate theMessageProcessor
at runtime from providedMessageProcessorSpec
. - split(MessageProcessorSpec<?>, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MethodInvokingSplitter
to evaluate theMessageProcessor
at runtime from providedMessageProcessorSpec
. - split(AbstractMessageSplitter) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the provided
AbstractMessageSplitter
to the current integration flow position. - split(S, Consumer<SplitterEndpointSpec<S>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the provided
AbstractMessageSplitter
to the current integration flow position. - splitMessage(Message<?>) - Method in class org.springframework.integration.file.splitter.FileSplitter
- splitMessage(Message<?>) - Method in class org.springframework.integration.splitter.MethodInvokingSplitter
- 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 - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- splitter() - Static method in class org.springframework.integration.file.dsl.Files
-
The
FileSplitterSpec
builder factory method with default arguments. - splitter(boolean) - Static method in class org.springframework.integration.file.dsl.Files
-
The
FileSplitterSpec
builder factory method withiterator
flag specified. - splitter(boolean, boolean) - Static method in class org.springframework.integration.file.dsl.Files
- Splitter - Annotation Interface 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.
- SplitterAnnotationPostProcessor - Class in org.springframework.integration.config
-
Post-processor for Methods annotated with
@Splitter
. - SplitterAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.SplitterAnnotationPostProcessor
- SplitterEndpointSpec<S extends AbstractMessageSplitter> - Class in org.springframework.integration.dsl
-
A
ConsumerEndpointSpec
for aAbstractMessageSplitter
implementations. - 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
- Splitters - Annotation Interface in org.springframework.integration.annotation
-
The repeatable container for
Splitter
annotations. - SPRING_INTEGRATION_INTERNAL_CLUSTER_LOCK - Static variable in class org.springframework.integration.hazelcast.HazelcastLocalInstanceRegistrar
-
The name for the Hazelcast Lock used for membership registration.
- SPRING_INTEGRATION_INTERNAL_CLUSTER_MULTIMAP - Static variable in class org.springframework.integration.hazelcast.HazelcastLocalInstanceRegistrar
-
The name for the Hazelcast MultiMap used for membership registration.
- SpringIntegrationTest - Annotation Interface 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
- SQLXML - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- 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
-
Standard implementation of
IntegrationFlowContext
. - 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.channel.PointToPointSubscribableAmqpChannel
- 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.hazelcast.leader.LeaderInitiator
-
Start the registration of the
LeaderInitiator.candidate
for leader election. - 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.jdbc.channel.PostgresChannelMessageTableSubscriber
- 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.mqtt.core.Mqttv3ClientManager
- start() - Method in class org.springframework.integration.mqtt.core.Mqttv5ClientManager
- 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.router.ExpressionEvaluatingRouter
- 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.splitter.MethodInvokingSplitter
- 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 the registration of the
LockRegistryLeaderInitiator.candidate
for leader election. - 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.outbound.ZeroMqMessageHandler
- 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 the registration of the
LeaderInitiator.candidate
for leader election. - start() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
- START - Enum constant in enum class org.springframework.integration.file.splitter.FileSplitter.FileMarker.Mark
- 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
-
Start all registered
SmartLifecycle
s in the role. - STAT - Enum constant in enum class org.springframework.integration.ftp.session.FtpRemoteFileTemplate.ExistsMode
-
Perform the
STAT
FTP command. - 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.
- STATEMENT - Enum constant in enum class org.springframework.integration.cassandra.outbound.CassandraMessageHandler.Type
-
Set a
CassandraMessageHandler
into astatement
mode. - statementExpression(String) - Method in class org.springframework.integration.cassandra.dsl.CassandraMessageHandlerSpec
-
Set a SpEL expression to evaluate a
Statement
against request message. - statementExpression(Expression) - Method in class org.springframework.integration.cassandra.dsl.CassandraMessageHandlerSpec
-
Set a SpEL expression to evaluate a
Statement
against request message. - statementFunction(Function<Message<?>, Statement<?>>) - Method in class org.springframework.integration.cassandra.dsl.CassandraMessageHandlerSpec
-
Set a
Function
to evaluate aStatement
against request message. - 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
-
Create a source that reads from
System.in
. - stdin(String) - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
Create a source that reads from
System.in
. - stdinPipe() - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
Create a source that reads from
System.in
. - stdinPipe(String) - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
Create a source that reads from
System.in
. - 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
-
The
StompIntegrationEvent
implementation for the failed connection exceptions. - StompConnectionFailedEvent(Object, Throwable) - Constructor for class org.springframework.integration.stomp.event.StompConnectionFailedEvent
- StompExceptionEvent - Class in org.springframework.integration.stomp.event
-
The
StompIntegrationEvent
implementation for the exception from STOMP Adapters. - StompExceptionEvent(Object, Throwable) - Constructor for class org.springframework.integration.stomp.event.StompExceptionEvent
- StompHeaderMapper - Class in org.springframework.integration.stomp.support
-
The STOMP
HeaderMapper
implementation. - 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 theoutputChannel
. - StompInboundChannelAdapter(StompSessionManager, String...) - Constructor for class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
- StompInboundChannelAdapterParser - Class in org.springframework.integration.stomp.config
-
The
AbstractChannelAdapterParser
implementation for the<stomp:inbound-channel-adapter/>
element. - StompInboundChannelAdapterParser() - Constructor for class org.springframework.integration.stomp.config.StompInboundChannelAdapterParser
- StompIntegrationEvent - Class in org.springframework.integration.stomp.event
-
Base class for all
IntegrationEvent
s generated by the STOMP Adapters. - 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
-
The
AbstractMessageHandler
implementation to send messages to STOMP destinations. - 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
-
The
AbstractOutboundChannelAdapterParser
implementation for the<stomp:outbound-channel-adapter/>
element. - StompOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.stomp.config.StompOutboundChannelAdapterParser
- StompReceiptEvent - Class in org.springframework.integration.stomp.event
-
The
StompIntegrationEvent
for the STOMPRECEIPT
Frames or lost receipts. - StompReceiptEvent(Object, String, String, StompCommand, boolean) - Constructor for class org.springframework.integration.stomp.event.StompReceiptEvent
- StompSessionConnectedEvent - Class in org.springframework.integration.stomp.event
-
The
StompIntegrationEvent
indicating the STOMP session establishment. - 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.channel.PointToPointSubscribableAmqpChannel
- stop() - 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() - Method in class org.springframework.integration.channel.interceptor.WireTap
-
Stop the wire tap.
- stop() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
- stop() - 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() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- stop() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
- stop() - 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() - 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() - 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.hazelcast.leader.LeaderInitiator
-
Stop the registration of the
LeaderInitiator.candidate
for leader election. - 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.jdbc.channel.PostgresChannelMessageTableSubscriber
- stop() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
- stop() - 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() - 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.mqtt.core.Mqttv3ClientManager
- stop() - Method in class org.springframework.integration.mqtt.core.Mqttv5ClientManager
- stop() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
- stop() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
- stop() - Method in class org.springframework.integration.router.ExpressionEvaluatingRouter
- 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.splitter.MethodInvokingSplitter
- 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 the registration of the
LockRegistryLeaderInitiator.candidate
for leader election. - stop() - Method in interface org.springframework.integration.support.management.ManageableLifecycle
- stop() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
- 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() - 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.outbound.ZeroMqMessageHandler
- 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() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
-
Stop the registration of the
LeaderInitiator.candidate
for leader election. - stop() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
- stop(Runnable) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- stop(Runnable) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- stop(Runnable) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
- stop(Runnable) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
- stop(Runnable) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
- stop(Runnable) - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
- stop(Runnable) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- stop(Runnable) - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
- stop(Runnable) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
- stop(Runnable) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
- stop(Runnable) - Method in class org.springframework.integration.handler.MessageHandlerChain
- stop(Runnable) - Method in class org.springframework.integration.hazelcast.leader.LeaderInitiator
- stop(Runnable) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
- stop(Runnable) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
- stop(Runnable) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
- stop(Runnable) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
- stop(Runnable) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
- stop(Runnable) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
- stop(Runnable) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
- stop(Runnable) - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
- stop(TimerFacade) - Method in interface org.springframework.integration.support.management.metrics.SampleFacade
- 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
-
Stops all inbound message producers (that are not
OrderlyShutdownCapable
) - may cause interrupts. - stopLifecyclesInRole(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
Stop all registered
SmartLifecycle
s in the role. - stopMessageSources() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
Stops all message sources - may cause interrupts.
- store - Variable in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- store(Object, Message<?>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- 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
-
Constructor passing in the
StoredProcExecutor
. - 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
-
An
AbstractReplyProducingMessageHandler
implementation for performing RDBMS stored procedures which return results. - StoredProcOutboundGateway(StoredProcExecutor) - Constructor for class org.springframework.integration.jdbc.StoredProcOutboundGateway
-
Constructor taking
StoredProcExecutor
. - 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
-
Constructor taking
StoredProcExecutor
. - 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() - Method in class org.springframework.integration.store.MessageGroupQueue
- STREAM - Enum constant in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
-
(-stream) Streaming 'get' (returns InputStream); user must call
Session.close()
. - 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
- streamConverter(StreamMessageConverter) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageListenerContainerSpec
-
Set a stream message converter.
- streamMessages() - Method in interface org.springframework.integration.store.MessageGroup
-
Return a stream for messages stored in this group.
- streamMessagesForGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- streamMessagesForGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- streamMessagesForGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
- streamMessagesForGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- streamMessagesForGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
-
Return a stream for messages stored in the provided group.
- 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 abyte[]
. - 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 - Enum constant in enum class org.springframework.integration.json.ObjectToJsonTransformer.ResultType
- STRING - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
- STRING_RESULT - Enum constant in enum class org.springframework.integration.xml.xpath.XPathEvaluationType
- 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
-
SourceFactory
implementation which supports creation of aStringSource
from aDocument
,File
orString
payload - 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, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
-
Creates a non-namespaced testing selector.
- StringValueTestXPathMessageSelector(String, String, String, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
-
Creates a single namespace Xpath 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(XPathExpression, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
-
Creates a selector with the provided
XPathExpression
. - STRUCT - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- 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.
- SUB_PUB - Enum constant in enum class org.springframework.integration.zeromq.ZeroMqProxy.Type
- SUBDIRS - Enum constant in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
-
(-dirs) Include directories in the results (ls).
- subFlowMapping(K, IntegrationFlow) - Method in class org.springframework.integration.dsl.RouterSpec
-
Add a subflow as an alternative to a
RouterSpec.channelMapping(Object, String)
. - 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(List<SubProtocolHandler>, SubProtocolHandler) - Constructor for class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
- SubProtocolHandlerRegistry(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
-
An
AbstractJmsChannel
implementation for message-driven subscriptions. - SubscribableJmsChannel(AbstractMessageListenerContainer, JmsTemplate) - Constructor for class org.springframework.integration.jms.SubscribableJmsChannel
- SubscribableKafkaChannel - Class in org.springframework.integration.kafka.channel
-
Subscribable channel backed by an Apache 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
-
An
AbstractMessageChannel
implementation withBroadcastCapableChannel
aspect to provide a pub-sub semantics to consume messages fgrom Redis topic. - SubscribableRedisChannel(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.channel.SubscribableRedisChannel
- subscribe(Subscriber<? super Message<?>>) - Method in class org.springframework.integration.channel.FluxMessageChannel
- subscribe(IntegrationFlow) - Method in class org.springframework.integration.dsl.BroadcastPublishSubscribeSpec
-
Configure a
IntegrationFlow
to configure as a subscriber for the currentBroadcastCapableChannel
. - subscribe(IntegrationFlow) - Method in class org.springframework.integration.dsl.PublishSubscribeSpec
- subscribe(PostgresChannelMessageTableSubscriber.Subscription) - Method in class org.springframework.integration.jdbc.channel.PostgresChannelMessageTableSubscriber
-
Add a new subscription to this subscriber.
- subscribe(MessageHandler) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- subscribe(MessageHandler) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
- subscribe(MessageHandler) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
- subscribe(MessageHandler) - Method in class org.springframework.integration.jdbc.channel.PostgresSubscribableChannel
- 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
-
Replace the real
MessageSource
in theSourcePollingChannelAdapter
bean with providedMessageSource
instance. - substituteMessageSourceFor(String, MessageSource<?>, boolean) - Method in class org.springframework.integration.test.context.MockIntegrationContext
-
Replace the real
MessageSource
in theSourcePollingChannelAdapter
bean with providedMessageSource
instance. - suffix() - Element in annotation interface org.springframework.integration.annotation.Router
-
Specify a suffix to be added to each channel name prior to resolution.
- suffix(String) - Method in class org.springframework.integration.dsl.RouterSpec
-
Cannot be invoked if
RouterSpec.subFlowMapping(Object, IntegrationFlow)
is used. - suggestedClassName() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
- superStream(String, String) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageListenerContainerSpec
-
Enable Single Active Consumer on a Super Stream.
- 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
-
Deprecated.
- supports(HandlerResult) - Method in class org.springframework.integration.webflux.inbound.IntegrationHandlerResultHandler
- supportsContext(Observation.Context) - Method in interface org.springframework.integration.support.management.observation.MessageReceiverObservationConvention
- supportsContext(Observation.Context) - Method in interface org.springframework.integration.support.management.observation.MessageRequestReplyReceiverObservationConvention
- supportsContext(Observation.Context) - Method in interface org.springframework.integration.support.management.observation.MessageSenderObservationConvention
- 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.ContinuationHandlerMethodArgumentResolver
- 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
- supportsPojoMethod() - Method in interface org.springframework.integration.config.annotation.MethodAnnotationPostProcessor
- supportsPojoMethod() - Method in class org.springframework.integration.config.BridgeFromAnnotationPostProcessor
- supportsPojoMethod() - Method in class org.springframework.integration.config.BridgeToAnnotationPostProcessor
- 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.amqp.dsl.RabbitStreamMessageHandlerSpec
-
Set to true to wait for a confirmation.
- sync(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
A
boolean
indicating if theKafkaProducerMessageHandler
should wait for the send operation results or not. - syncCommits(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
-
Set whether to call consumer.commitSync() or commitAsync() when the container is responsible for commits.
- SYNCHRONISED_SET - Enum constant in enum class org.springframework.integration.store.SimpleMessageGroupFactory.GroupType
- synchronizer - Variable in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
- synchronizeToLocalDirectory(File) - 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 class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
- 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
-
Headers in a
Map
generated by the @linkSyslogToMapTransformer
that will be added to Spring Integration messages as headers, prefixed bySyslogHeaders.PREFIX
. - 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
-
Instantiates a factory bean that creates a
UdpSyslogReceivingChannelAdapter
if the protocol isSyslogReceivingChannelAdapterFactoryBean.Protocol.udp
or aTcpSyslogReceivingChannelAdapter
if the protocol isSyslogReceivingChannelAdapterFactoryBean.Protocol.tcp
. - SyslogReceivingChannelAdapterFactoryBean.Protocol - Enum Class 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
- system_management - Enum constant in enum class org.springframework.integration.IntegrationPatternType.IntegrationPatternCategory
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
new AuthorizationChannelInterceptor(AuthorityAuthorizationManager.hasAnyRole())