Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
R
- R2dbc - Class in org.springframework.integration.r2dbc.dsl
- 
Java DSL Factory class for R2DBC components.
- R2dbcMessageHandler - Class in org.springframework.integration.r2dbc.outbound
- 
Implementation ofReactiveMessageHandlerwhich writes Message payload into a Relational Database, using reactive r2dbc support.
- R2dbcMessageHandler(R2dbcEntityOperations) - Constructor for class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
- 
Construct this instance using a fully created and initialized instance of providedR2dbcEntityOperations.
- R2dbcMessageHandler.Type - Enum Class in org.springframework.integration.r2dbc.outbound
- 
/** The mode for theR2dbcMessageHandler.
- R2dbcMessageHandlerSpec - Class in org.springframework.integration.r2dbc.dsl
- 
TheReactiveMessageHandlerSpecfor theR2dbcMessageHandler.
- R2dbcMessageHandlerSpec(R2dbcEntityOperations) - Constructor for class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
- R2dbcMessageSource - Class in org.springframework.integration.r2dbc.inbound
- 
An instance ofMessageSourcewhich returns aMessagewith a payload which is the result of execution of query.
- R2dbcMessageSource(R2dbcEntityOperations, String) - Constructor for class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
- 
Create an instance with the providedR2dbcEntityOperationsand SpEL expression which should resolve to a Relational 'query' string.
- R2dbcMessageSource(R2dbcEntityOperations, Expression) - Constructor for class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
- 
Create an instance with the providedR2dbcEntityOperationsand SpEL expression which should resolve to a query string orStatementMapper.SelectSpecinstance.
- R2dbcMessageSource.SelectCreator - Class in org.springframework.integration.r2dbc.inbound
- 
An instance of this class is used as a root object for query expression to give a limited access only to theStatementMapper.createSelect(java.lang.String)fluent API.
- R2dbcMessageSourceSpec - Class in org.springframework.integration.r2dbc.dsl
- 
TheMessageSourceSpecfor theR2dbcMessageSource.
- R2dbcMessageSourceSpec(R2dbcEntityOperations, String) - Constructor for class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
- R2dbcMessageSourceSpec(R2dbcEntityOperations, Expression) - Constructor for class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
- RabbitStream - Class in org.springframework.integration.amqp.dsl
- 
Factory class for RabbitMQ components.
- RabbitStreamInboundChannelAdapterSpec - Class in org.springframework.integration.amqp.dsl
- 
Spec for an inbound channel adapter with aStreamListenerContainer.
- RabbitStreamInboundChannelAdapterSpec(Environment, Codec) - Constructor for class org.springframework.integration.amqp.dsl.RabbitStreamInboundChannelAdapterSpec
- RabbitStreamInboundChannelAdapterSpec(StreamListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.RabbitStreamInboundChannelAdapterSpec
- RabbitStreamMessageHandler - Class in org.springframework.integration.amqp.outbound
- 
MessageHandlerbased onRabbitStreamOperations.
- RabbitStreamMessageHandler(RabbitStreamOperations) - Constructor for class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
- 
Create an instance with the providedRabbitStreamOperations.
- RabbitStreamMessageHandlerSpec - Class in org.springframework.integration.amqp.dsl
- 
The baseMessageHandlerSpecforRabbitStreamMessageHandlers.
- RabbitStreamMessageListenerContainerSpec - Class in org.springframework.integration.amqp.dsl
- 
Spec forStreamListenerContainer.
- RateLimiterRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
- 
AnAbstractRequestHandlerAdviceextension for a rate limiting to service method calls.
- RateLimiterRequestHandlerAdvice() - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
- 
Construct an instance based on default rate limiter options and "RateLimiterRequestHandlerAdvice" as a rate limiter name.
- RateLimiterRequestHandlerAdvice(RateLimiter) - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
- 
Construct an instance based on the providedRateLimiter.
- RateLimiterRequestHandlerAdvice(RateLimiterConfig) - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
- 
Construct an instance based on the providedRateLimiterConfigand "RateLimiterRequestHandlerAdvice" as a rate limiter name.
- RateLimiterRequestHandlerAdvice(RateLimiterConfig, String) - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
- 
Construct an instance based on the providedRateLimiterConfigand name.
- RateLimiterRequestHandlerAdvice(String) - Constructor for class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
- 
Construct an instance based on default rate limiter options and provided name.
- RateLimiterRequestHandlerAdvice.RateLimitExceededException - Exception Class in org.springframework.integration.handler.advice
- 
AMessagingExceptionwrapper for theRequestNotPermittedwith therequestMessageandtargetcontext.
- raw() - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
- 
Return a serializer with the default max message size for deserialization.
- raw(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
- 
Return a serializer with the provided max message size for deserialization.
- RAW_HEADERS - Static variable in class org.springframework.integration.mail.MailHeaders
- rawMessageHeader(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
- rawMessageHeader(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
- 
Set to true to include the rawConsumerRecordas headers with keysKafkaHeaders.RAW_DATAandIntegrationMessageHeaderAccessor.SOURCE_DATA.
- RawRecordHeaderErrorMessageStrategy - Class in org.springframework.integration.kafka.support
- 
ErrorMessageStrategyextension that adds the raw record as a header to theErrorMessage.
- RawRecordHeaderErrorMessageStrategy() - Constructor for class org.springframework.integration.kafka.support.RawRecordHeaderErrorMessageStrategy
- rawUrl() - Method in class org.springframework.integration.smb.session.SmbConfig
- 
Return the url string for the share connection without encoding.
- rawUrl(boolean) - Method in class org.springframework.integration.smb.session.SmbConfig
- 
Return the url string for the share connection without encoding the host and path.
- reactive() - Element in annotation interface org.springframework.integration.annotation.Aggregator
- reactive() - Element in annotation interface org.springframework.integration.annotation.BridgeFrom
- reactive() - Element in annotation interface org.springframework.integration.annotation.BridgeTo
- reactive() - Element in annotation interface org.springframework.integration.annotation.Filter
- reactive() - Element in annotation interface org.springframework.integration.annotation.Router
- reactive() - Element in annotation interface org.springframework.integration.annotation.ServiceActivator
- reactive() - Element in annotation interface org.springframework.integration.annotation.Splitter
- reactive() - Element in annotation interface org.springframework.integration.annotation.Transformer
- reactive() - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
- 
Make the consumer endpoint as reactive independently of an input channel.
- reactive(Function<? super Flux<Message<?>>, ? extends Publisher<Message<?>>>) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
- 
Make the consumer endpoint as reactive independently of an input channel and apply the provided function into theFlux.transform(Function)operator.
- Reactive - Annotation Interface in org.springframework.integration.annotation
- 
Provides reactive configuration options for the consumer endpoint making any input channel as a reactive stream source of data.
- reactive_channel - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- reactiveAdapterRegistry(ReactiveAdapterRegistry) - Method in class org.springframework.integration.webflux.dsl.WebFluxInboundEndpointSpec
- reactiveInboundChannelAdapter(MongoOperations, Query) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aMongoDbMessageSourceSpecbuilder instance based on the providedMongoOperations.
- reactiveInboundChannelAdapter(ReactiveMongoOperations, String) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aReactiveMongoDbMessageSourceSpecbuilder instance based on the providedReactiveMongoOperations.
- reactiveInboundChannelAdapter(ReactiveMongoOperations, Query) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aReactiveMongoDbMessageSourceSpecbuilder instance based on the providedReactiveMongoOperations.
- reactiveInboundChannelAdapter(ReactiveMongoDatabaseFactory, String) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aReactiveMongoDbMessageSourceSpecbuilder instance based on the providedReactiveMongoDatabaseFactory.
- reactiveInboundChannelAdapter(ReactiveMongoDatabaseFactory, Query) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aReactiveMongoDbMessageSourceSpecbuilder instance based on the providedReactiveMongoDatabaseFactory.
- reactiveMessageHandler - Variable in class org.springframework.integration.dsl.ReactiveMessageHandlerSpec
- ReactiveMessageHandlerAdapter - Class in org.springframework.integration.handler
- 
AMessageHandlerimplementation to adapt aReactiveMessageHandlerfor synchronous invocations.
- ReactiveMessageHandlerAdapter(ReactiveMessageHandler) - Constructor for class org.springframework.integration.handler.ReactiveMessageHandlerAdapter
- 
Instantiate based on the providedReactiveMessageHandler.
- ReactiveMessageHandlerSpec<S,H> - Class in org.springframework.integration.dsl
- 
TheMessageHandlerSpecextension forReactiveMessageHandler.
- ReactiveMessageHandlerSpec(H) - Constructor for class org.springframework.integration.dsl.ReactiveMessageHandlerSpec
- ReactiveMessageSourceProducer - Class in org.springframework.integration.endpoint
- 
TheMessageProducerSupportto adapt a providedMessageSourceinto aFluxand let it be subscribed in theMessageProducerSupport.subscribeToPublisher(org.reactivestreams.Publisher<? extends org.springframework.messaging.Message<?>>).
- ReactiveMessageSourceProducer(MessageSource<?>) - Constructor for class org.springframework.integration.endpoint.ReactiveMessageSourceProducer
- 
Create an instance based on the providedMessageSource.
- ReactiveMongoDbMessageHandlerSpec - Class in org.springframework.integration.mongodb.dsl
- 
AReactiveMessageHandlerSpecextension for the Reactive MongoDb Outbound endpointReactiveMongoDbStoringMessageHandler.
- ReactiveMongoDbMessageHandlerSpec(ReactiveMongoOperations) - Constructor for class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
- ReactiveMongoDbMessageHandlerSpec(ReactiveMongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
- ReactiveMongoDbMessageSource - Class in org.springframework.integration.mongodb.inbound
- 
An instance ofMessageSourcewhich returns aMessagewith a payload which is the result of execution of aQuery.
- ReactiveMongoDbMessageSource(ReactiveMongoOperations, Expression) - Constructor for class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
- 
Create an instance with the providedReactiveMongoOperationsand SpEL expression which should resolve to a Mongo 'query' string (see https://www.mongodb.org/display/DOCS/Querying).
- ReactiveMongoDbMessageSource(ReactiveMongoDatabaseFactory, Expression) - Constructor for class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
- 
Create an instance with the providedReactiveMongoDatabaseFactoryand SpEL expression which should resolve to a MongoDb 'query' string (see https://www.mongodb.org/display/DOCS/Querying).
- ReactiveMongoDbMessageSourceSpec - Class in org.springframework.integration.mongodb.dsl
- 
AAbstractMongoDbMessageSourceSpecimplementation for aReactiveMongoDbMessageSource.
- ReactiveMongoDbMessageSourceSpec(ReactiveMongoOperations, Expression) - Constructor for class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
- ReactiveMongoDbMessageSourceSpec(ReactiveMongoDatabaseFactory, Expression) - Constructor for class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageSourceSpec
- ReactiveMongoDbStoringMessageHandler - Class in org.springframework.integration.mongodb.outbound
- 
Implementation ofReactiveMessageHandlerwhich writes Message payload into a MongoDb collection, using reactive MongoDb support, The collection is identified by evaluation of theReactiveMongoDbStoringMessageHandler.collectionNameExpression.
- ReactiveMongoDbStoringMessageHandler(ReactiveMongoOperations) - Constructor for class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
- 
Construct this instance using a fully created and initialized instance of providedReactiveMongoOperations.
- ReactiveMongoDbStoringMessageHandler(ReactiveMongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
- 
Construct this instance using a providedReactiveMongoDatabaseFactory.
- reactiveOutboundChannelAdapter(ReactiveMongoOperations) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aReactiveMongoDbMessageHandlerSpecbuilder instance based on the providedReactiveMongoOperations.
- reactiveOutboundChannelAdapter(ReactiveMongoDatabaseFactory) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aReactiveMongoDbMessageHandlerSpecbuilder instance based on the providedReactiveMongoDatabaseFactory.
- ReactiveRedisStreamMessageHandler - Class in org.springframework.integration.redis.outbound
- 
Implementation ofReactiveMessageHandlerwhich writes Message payload or Message itself (seeReactiveRedisStreamMessageHandler.extractPayload) into a Redis stream using Reactive Stream operations.
- ReactiveRedisStreamMessageHandler(ReactiveRedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
- 
Create an instance based on providedReactiveRedisConnectionFactoryand key for stream.
- ReactiveRedisStreamMessageHandler(ReactiveRedisConnectionFactory, Expression) - Constructor for class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
- 
Create an instance based on providedReactiveRedisConnectionFactoryand expression for stream key.
- ReactiveRedisStreamMessageProducer - Class in org.springframework.integration.redis.inbound
- 
AMessageProducerSupportfor reading messages from a Redis Stream and publishing them into the provided output channel.
- ReactiveRedisStreamMessageProducer(ReactiveRedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
- ReactiveRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
- 
AMethodInterceptorfor message handlers producing aMonoas a payload for reply.
- ReactiveRequestHandlerAdvice(BiFunction<Message<?>, Mono<?>, Publisher<?>>) - Constructor for class org.springframework.integration.handler.advice.ReactiveRequestHandlerAdvice
- 
Instantiate advice based on a providedBiFunctioncustomizer.
- ReactiveStreamsConsumer - Class in org.springframework.integration.endpoint
- 
AnAbstractEndpointimplementation for Reactive Streams subscription into an input channel and reactive consumption of messages from that channel.
- ReactiveStreamsConsumer(MessageChannel, Subscriber<Message<?>>) - Constructor for class org.springframework.integration.endpoint.ReactiveStreamsConsumer
- ReactiveStreamsConsumer(MessageChannel, MessageHandler) - Constructor for class org.springframework.integration.endpoint.ReactiveStreamsConsumer
- ReactiveStreamsConsumer(MessageChannel, ReactiveMessageHandler) - Constructor for class org.springframework.integration.endpoint.ReactiveStreamsConsumer
- 
Instantiate an endpoint based on the providedMessageChannelandReactiveMessageHandler.
- ReactiveStreamsSubscribableChannel - Interface in org.springframework.integration.channel
- REACTOR_CONTEXT - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
- 
The header forContextView.
- ReactorNettyTcpStompSessionManager - Class in org.springframework.integration.stomp
- 
TheReactorNettyTcpStompClientbasedAbstractStompSessionManagerimplementation.
- ReactorNettyTcpStompSessionManager(ReactorNettyTcpStompClient) - Constructor for class org.springframework.integration.stomp.ReactorNettyTcpStompSessionManager
- read(Kryo, Input, Class<? extends File>) - Method in class org.springframework.integration.codec.kryo.FileSerializer
- read(InputStream, byte[], boolean) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
- 
Read data from the socket and puts the data in buffer.
- read(Class<? extends MultiValueMap<String, ?>>, HttpInputMessage) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
- read(String, OutputStream) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
- read(String, OutputStream) - Method in interface org.springframework.integration.file.remote.session.Session
- read(String, OutputStream) - Method in class org.springframework.integration.ftp.session.FtpSession
- read(String, OutputStream) - Method in class org.springframework.integration.sftp.session.SftpSession
- read(String, OutputStream) - Method in class org.springframework.integration.smb.session.SmbSession
- 
Read the remote resource specified by path and copies its contents to the specifiedOutputStream.
- read(EvaluationContext, Object, Object) - Method in class org.springframework.integration.json.JsonIndexAccessor
- read(EvaluationContext, Object, String) - Method in class org.springframework.integration.json.JsonPropertyAccessor
- read(Message<?>) - Static method in class org.springframework.integration.history.MessageHistory
- READ_DELAY - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- READ_ONLY_HEADERS - Static variable in class org.springframework.integration.context.IntegrationProperties
- 
Specifies the value ofDefaultMessageBuilderFactory.readOnlyHeaders.
- readDelay(long) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
- Reader(String) - Constructor for class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
- readFraction() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
- readHeader(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
- 
Read the header and returns the length of the data part.
- readHeader(JsonParser, String, String) - Method in class org.springframework.integration.support.json.Jackson2JsonMessageParser
- readHeaders(JsonInboundMessageMapper.JsonMessageParser<?>, String) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
- readHeaders(P, String) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
- readInt() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
- 
Read characters building an int until a non-digit is found
- readInternal(Class, HttpInputMessage) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
- readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.DefaultMultipartFileReader
- readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
- readMultipartFile(MultipartFile) - Method in interface org.springframework.integration.http.multipart.MultipartFileReader
- 
ReadMultipartFilecontent.
- readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.SimpleMultipartFileReader
- readOnly(boolean) - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
- readOnlyHeaders(String...) - Method in class org.springframework.integration.support.BaseMessageBuilder
- 
Specify a list of headers which should be considered as read only and prohibited from being populated in the message.
- readPacket() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
- 
Invoked by the factory when there is data to be read.
- readPayload(JsonInboundMessageMapper.JsonMessageParser<?>, String) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
- readPayload(JsonParser, String) - Method in class org.springframework.integration.support.json.Jackson2JsonMessageParser
- readPayload(P, String) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
- readRaw(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
- readRaw(String) - Method in interface org.springframework.integration.file.remote.session.Session
- 
Retrieve a remote file as a rawInputStream.
- readRaw(String) - Method in class org.springframework.integration.ftp.session.FtpSession
- readRaw(String) - Method in class org.springframework.integration.sftp.session.SftpSession
- readRaw(String) - Method in class org.springframework.integration.smb.session.SmbSession
- REAL - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- rebuild() - Method in class org.springframework.integration.graph.IntegrationGraphServer
- 
Rebuild the graph, re-cache it, and return it.
- RECEIPT - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
- RECEIPT_ID - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
- ReceiptEvent - Class in org.springframework.integration.websocket.event
- 
TheAbstractSubProtocolEventimplementation, which is emitted for the WebSocket sub-protocol-specificRECEIPTframe on the client side.
- ReceiptEvent(Object, Message<byte[]>) - Constructor for class org.springframework.integration.websocket.event.ReceiptEvent
- receive() - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
- receive() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- receive() - Method in class org.springframework.integration.channel.AbstractPollableChannel
- 
Receive the first available message from this channel.
- receive() - Method in class org.springframework.integration.channel.NullChannel
- receive() - Method in interface org.springframework.integration.core.MessageSource
- 
Retrieve the next available message from this source.
- receive() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
- receive() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- receive() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
- receive() - Method in class org.springframework.integration.jms.PollableJmsChannel
- receive() - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
- receive() - Method in class org.springframework.integration.mail.AbstractMailReceiver
- receive() - Method in interface org.springframework.integration.mail.MailReceiver
- receive(long) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- receive(long) - Method in class org.springframework.integration.channel.AbstractPollableChannel
- 
Receive the first available message from this channel.
- receive(long) - Method in class org.springframework.integration.channel.NullChannel
- receive(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- receive(long) - Method in class org.springframework.integration.jms.PollableJmsChannel
- receive(long) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
- receive(MessageChannel, long) - Method in class org.springframework.integration.core.MessagingTemplate
- RECEIVE_COUNTER_NAME - Static variable in interface org.springframework.integration.support.management.IntegrationManagement
- receiveAndConvert(MessageChannel, long) - Method in class org.springframework.integration.core.MessagingTemplate
- receiveBufferSize(int) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
- receiveCounters(Supplier<ReceiveCounters>) - Method in class org.springframework.integration.graph.MessageSourceNode
- receiveCounters(Supplier<ReceiveCounters>) - Method in class org.springframework.integration.graph.PollableChannelNode
- receiveCounters(Supplier<ReceiveCounters>) - Method in interface org.springframework.integration.graph.ReceiveCountersAware
- ReceiveCounters - Class in org.springframework.integration.graph
- 
Counters for components that maintain receive counters.
- ReceiveCounters(long, long) - Constructor for class org.springframework.integration.graph.ReceiveCounters
- ReceiveCountersAware - Interface in org.springframework.integration.graph
- RECEIVED_DATE - Static variable in class org.springframework.integration.mail.MailHeaders
- RECEIVED_QOS - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
- RECEIVED_RETAINED - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
- RECEIVED_TOPIC - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
- receivedQos(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
- 
Return the received QOS header.
- receivedRetained(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
- 
Return the received retained header.
- receivedTopic(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
- 
Return the received topic header.
- receiveMessage() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
- 
Obtain the next message (if one is available).
- receiveMessage() - Method in class org.springframework.integration.endpoint.PollingConsumer
- receiveMessage() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
- receiveMessage() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- receiveMessage(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- ReceiveMessageAdvice - Interface in org.springframework.integration.aop
- 
An AOP advice to perform hooks before and/or after areceive()contract is called.
- receiver - Variable in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
- receiver - Variable in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
- receiveRaw(boolean) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
- 
Whether rawZMsgis present as a payload of message to produce or it is fully converted to aMessageincludingZeroMqHeaders.TOPICheader (if any).
- receiveTimeout() - Element in annotation interface org.springframework.integration.annotation.Poller
- 
Only applies to polling consumers.
- receiveTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- receiveTimeout(long) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- receiveTimeout(long) - Method in class org.springframework.integration.dsl.PollerSpec
- 
Specify a timeout in milliseconds to wait for a message in theMessageChannel.
- receiveTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
- 
A receive timeout.
- receiveTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- receiveTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
- receiveTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsTemplateSpec
- receiveTimeout(Long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
- recipient(String) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a recipient channel that is always selected.
- recipient(String, String) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a recipient channel that will be selected if the expression evaluates to 'true'.
- recipient(String, Expression) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a recipient channel that will be selected if the expression evaluates to 'true'.
- recipient(String, GenericSelector<P>) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a recipient channel that will be selected if the selector's accept method returns 'true'.
- recipient(MessageChannel) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a recipient channel that always is selected.
- recipient(MessageChannel, String) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a recipient channel that will be selected if the expression evaluates to 'true'.
- recipient(MessageChannel, Expression) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a recipient channel that will be selected if the expression evaluates to 'true'.
- recipient(MessageChannel, GenericSelector<P>) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a recipient channel that will be selected if the selector's accept method returns 'true'.
- Recipient(String) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
- Recipient(String, MessageSelector) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
- Recipient(MessageChannel) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
- Recipient(MessageChannel, MessageSelector) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
- recipient_list_router - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- recipientFlow(String, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a subflow that will be invoked if the expression evaluates to 'true'.
- recipientFlow(Expression, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a subflow that will be invoked if the expression evaluates to 'true'.
- recipientFlow(GenericSelector<P>, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a subflow that will be invoked if the selector's accept methods returns 'true'.
- recipientFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a subflow that will be invoked as a recipient.
- RecipientListRouter - Class in org.springframework.integration.router
- 
<recipient-list-router id="simpleRouter" input-channel="routingChannelA"> <recipient channel="channel1"/> <recipient channel="channel2"/> </recipient-list-router>
- RecipientListRouter() - Constructor for class org.springframework.integration.router.RecipientListRouter
- RecipientListRouter.Recipient - Class in org.springframework.integration.router
- RecipientListRouterManagement - Interface in org.springframework.integration.router
- 
Exposes adding/removing individual recipients operations for RecipientListRouter.
- RecipientListRouterParser - Class in org.springframework.integration.config.xml
- 
Parser for the <recipient-list-router/> element.
- RecipientListRouterParser() - Constructor for class org.springframework.integration.config.xml.RecipientListRouterParser
- RecipientListRouterSpec - Class in org.springframework.integration.dsl
- 
AnAbstractRouterSpecfor aRecipientListRouter.
- RecipientListRouterSpec() - Constructor for class org.springframework.integration.dsl.RecipientListRouterSpec
- recipientMessageSelector(String, MessageSelector) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a recipient channel that will be selected if the selector's accept method returns 'true'.
- recipientMessageSelector(MessageChannel, MessageSelector) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a recipient channel that will be selected if the selector's accept method returns 'true'.
- recipientMessageSelectorFlow(MessageSelector, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
- 
Adds a subflow that will be invoked if the selector's accept methods returns 'true'.
- reconnectDelay(long) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
- 
The time between connection attempts in milliseconds (default 10 seconds).
- record - Enum constant in enum class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter.ListenerMode
- 
EachMessagewill be converted from a singleConsumerRecord.
- record(long, TimeUnit) - Method in interface org.springframework.integration.support.management.metrics.TimerFacade
- record(long, TimeUnit) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimer
- recordFilterStrategy(RecordFilterStrategy<K, V>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
- 
Specify aRecordFilterStrategyto wrapKafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListenerintoFilteringMessageListenerAdapter.
- recordMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
- 
Set the message converter to use with a record-based consumer.
- recover(RetryContext) - Method in class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
- recoverer - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- recoveryBackOff(BackOff) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- 
Specify theBackOfffor interval between recovery attempts.
- recoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
- 
Set aRecoveryCallbackwhen using retry within the adapter.
- recoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
- 
Set aRecoveryCallbackwhen using retry within the adapter.
- recoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
- 
ARecoveryCallbackinstance for retry operation; if null, the exception will be thrown to the container after retries are exhausted.
- recoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
- 
ARecoveryCallbackinstance for retry operation; if null, the exception will be thrown to the container after retries are exhausted.
- recoveryCallback(RecoveryCallback<Message<?>>) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- 
Set aRecoveryCallbackwhen using retry within the adapter.
- recoveryCallback(RecoveryCallback<Message<?>>) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec
- 
Set aRecoveryCallbackwhen using retry within the adapter.
- recoveryInterval(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- recoveryInterval(long) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- recoveryInterval(long) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
- 
Specify a recovery interval.
- recoveryInterval(long) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
- 
Only applies if theJmsMessageChannelSpec.containerType(Class)is aDefaultMessageListenerContainer.
- recoveryInterval(Long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
- recursive(boolean) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
- 
A convenient flag to determine if target message source should use aRecursiveDirectoryScanneror stay with a default one.
- RECURSIVE - Enum constant in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
- 
(-R) Recursive (ls, mget).
- RecursiveDirectoryScanner - Class in org.springframework.integration.file
- 
TheDefaultDirectoryScannerextension which walks through the directory tree usingFiles.walk(Path, int, FileVisitOption...).
- RecursiveDirectoryScanner() - Constructor for class org.springframework.integration.file.RecursiveDirectoryScanner
- RedisChannelMessageStore - Class in org.springframework.integration.redis.store
- 
Specialized RedisChannelMessageStorethat uses a list to back a QueueChannel.
- RedisChannelMessageStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.store.RedisChannelMessageStore
- 
Construct a message store that uses Java Serialization for messages.
- RedisChannelParser - Class in org.springframework.integration.redis.config
- 
Parser for the 'channel' and 'publish-subscribe-channel' elements of the Spring Integration Redis namespace.
- RedisChannelParser() - Constructor for class org.springframework.integration.redis.config.RedisChannelParser
- RedisChannelPriorityMessageStore - Class in org.springframework.integration.redis.store
- 
Specialized RedisPriorityCapableChannelMessageStorethat uses lists to back a QueueChannel.
- RedisChannelPriorityMessageStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
- RedisExceptionEvent - Class in org.springframework.integration.redis.event
- RedisExceptionEvent(Object, Throwable) - Constructor for class org.springframework.integration.redis.event.RedisExceptionEvent
- RedisHeaders - Class in org.springframework.integration.redis.support
- 
Pre-defined names and prefixes to be used for for dealing with headers required by Redis components
- RedisInboundChannelAdapter - Class in org.springframework.integration.redis.inbound
- RedisInboundChannelAdapter(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
- RedisInboundChannelAdapterParser - Class in org.springframework.integration.redis.config
- RedisInboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisInboundChannelAdapterParser
- RedisIntegrationEvent - Class in org.springframework.integration.redis.event
- RedisIntegrationEvent(Object) - Constructor for class org.springframework.integration.redis.event.RedisIntegrationEvent
- RedisIntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.redis.event.RedisIntegrationEvent
- RedisLockRegistry - Class in org.springframework.integration.redis.util
- 
Implementation ofExpirableLockRegistryproviding a distributed lock using Redis.
- RedisLockRegistry(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.util.RedisLockRegistry
- 
Constructs a lock registry with the default (60 second) lock expiration.
- RedisLockRegistry(RedisConnectionFactory, String, long) - Constructor for class org.springframework.integration.redis.util.RedisLockRegistry
- 
Constructs a lock registry with the supplied lock expiration.
- RedisLockRegistry.RedisLockType - Enum Class in org.springframework.integration.redis.util
- 
The mode in which this registry is going to work with locks.
- RedisMessageStore - Class in org.springframework.integration.redis.store
- 
Redis implementation of the key/value styleMessageStoreandMessageGroupStore
- RedisMessageStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.store.RedisMessageStore
- 
ConstructRedisMessageStorebased on the providedRedisConnectionFactoryand default empty prefix.
- RedisMessageStore(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.store.RedisMessageStore
- 
ConstructRedisMessageStorebased on the providedRedisConnectionFactoryand prefix.
- RedisMetadataStore - Class in org.springframework.integration.redis.metadata
- 
Redis implementation ofConcurrentMetadataStore.
- RedisMetadataStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
- 
Initializes theRedisPropertiesby providedRedisConnectionFactoryand default hash key -RedisMetadataStore.KEY.
- RedisMetadataStore(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
- 
Initializes theRedisPropertiesby providedRedisConnectionFactoryand key.
- RedisMetadataStore(RedisOperations<String, ?>) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
- 
Initializes theRedisPropertiesby providedRedisConnectionFactoryand default hash key -RedisMetadataStore.KEY.
- RedisMetadataStore(RedisOperations<String, ?>, String) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
- 
Initializes theRedisPropertiesby providedRedisConnectionFactoryand key.
- RedisMetadataStore(RedisProperties) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
- 
Specifies theRedisPropertiesbackend for thisConcurrentMetadataStore.
- RedisNamespaceHandler - Class in org.springframework.integration.redis.config
- 
Namespace handler for Spring Integration's 'redis' namespace.
- RedisNamespaceHandler() - Constructor for class org.springframework.integration.redis.config.RedisNamespaceHandler
- RedisOutboundChannelAdapterParser - Class in org.springframework.integration.redis.config
- 
Parser for the<outbound-channel-adapter/>component.
- RedisOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisOutboundChannelAdapterParser
- RedisOutboundGateway - Class in org.springframework.integration.redis.outbound
- 
The Gateway component implementation to perform Redis commands with provided arguments and to return command result.
- RedisOutboundGateway(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisOutboundGateway
- RedisOutboundGateway(RedisTemplate<?, ?>) - Constructor for class org.springframework.integration.redis.outbound.RedisOutboundGateway
- RedisOutboundGatewayParser - Class in org.springframework.integration.redis.config
- 
Parser for the<int-redis:outbound-gateway/>component.
- RedisOutboundGatewayParser() - Constructor for class org.springframework.integration.redis.config.RedisOutboundGatewayParser
- RedisPublishingMessageHandler - Class in org.springframework.integration.redis.outbound
- RedisPublishingMessageHandler(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
- RedisQueueInboundChannelAdapterParser - Class in org.springframework.integration.redis.config
- 
Parser for the <queue-inbound-channel-adapter> element of the 'redis' namespace.
- RedisQueueInboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueInboundChannelAdapterParser
- RedisQueueInboundGateway - Class in org.springframework.integration.redis.inbound
- RedisQueueInboundGateway(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
- RedisQueueInboundGatewayParser - Class in org.springframework.integration.redis.config
- 
Parser for the <queue-inbound-gateway> element of the 'redis' namespace.
- RedisQueueInboundGatewayParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueInboundGatewayParser
- RedisQueueMessageDrivenEndpoint - Class in org.springframework.integration.redis.inbound
- RedisQueueMessageDrivenEndpoint(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
- RedisQueueOutboundChannelAdapter - Class in org.springframework.integration.redis.outbound
- RedisQueueOutboundChannelAdapter(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
- RedisQueueOutboundChannelAdapter(Expression, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
- RedisQueueOutboundChannelAdapterParser - Class in org.springframework.integration.redis.config
- 
Parser for the <int-redis:queue-outbound-channel-adapter> element.
- RedisQueueOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueOutboundChannelAdapterParser
- RedisQueueOutboundGateway - Class in org.springframework.integration.redis.outbound
- RedisQueueOutboundGateway(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
- RedisQueueOutboundGatewayParser - Class in org.springframework.integration.redis.config
- 
Parser for the <int-redis:queue-outbound-channel-adapter> element.
- RedisQueueOutboundGatewayParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueOutboundGatewayParser
- RedisStoreInboundChannelAdapterParser - Class in org.springframework.integration.redis.config
- 
Parser for Redis store inbound adapters
- RedisStoreInboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisStoreInboundChannelAdapterParser
- RedisStoreMessageSource - Class in org.springframework.integration.redis.inbound
- 
Inbound channel adapter which returns a Message representing a view into a Redis store.
- RedisStoreMessageSource(RedisConnectionFactory, Expression) - Constructor for class org.springframework.integration.redis.inbound.RedisStoreMessageSource
- 
Create an instance with the providedRedisConnectionFactoryand SpEL expression which should resolve to a 'key' name of the collection to be used.
- RedisStoreMessageSource(RedisTemplate<String, ?>, Expression) - Constructor for class org.springframework.integration.redis.inbound.RedisStoreMessageSource
- 
Create an instance with the providedRedisTemplateand SpEL expression which should resolve to a 'key' name of the collection to be used.
- RedisStoreOutboundChannelAdapterParser - Class in org.springframework.integration.redis.config
- 
Parser for the <redis:store-outbound-channel-adapter> element.
- RedisStoreOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisStoreOutboundChannelAdapterParser
- RedisStoreWritingMessageHandler - Class in org.springframework.integration.redis.outbound
- 
Implementation ofMessageHandlerwhich writes Message data into a Redis store identified by a keyString.
- RedisStoreWritingMessageHandler(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
- 
Constructs an instance using the providedRedisConnectionFactory.
- RedisStoreWritingMessageHandler(RedisTemplate<String, ?>) - Constructor for class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
- 
Constructs an instance using the providedRedisTemplate.
- ref(Object) - Method in class org.springframework.integration.dsl.SplitterSpec
- 
Provide a service to use aMethodInvokingSplitterfor the target handler.
- ref(Object) - Method in class org.springframework.integration.dsl.TransformerEndpointSpec
- 
Provide a service to use aMethodInvokingTransformerfor the target handler.
- REF - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
- REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- refName(String) - Method in class org.springframework.integration.dsl.SplitterSpec
- 
Provide a bean name to use aMethodInvokingSplitter(based onBeanNameMessageProcessor) for the target handler.
- refName(String) - Method in class org.springframework.integration.dsl.TransformerEndpointSpec
- 
Provide a bean name to use aMethodInvokingTransformer(based onBeanNameMessageProcessor) for the target handler.
- REFRESH - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
- REFRESH_CHECK_DELAY_ATTRIBUTE - Static variable in class org.springframework.integration.scripting.config.AbstractScriptParser
- RefreshableResourceScriptSource - Class in org.springframework.integration.scripting
- 
AScriptSourceimplementation, which caches a script string and refreshes it from the target file (if modified) according the providedRefreshableResourceScriptSource.refreshDelay.
- RefreshableResourceScriptSource(Resource, long) - Constructor for class org.springframework.integration.scripting.RefreshableResourceScriptSource
- refreshCheckDelay(long) - Method in class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
- 
The refreshCheckDelay in milliseconds for refreshable script resource.
- refreshCheckDelay(long) - Method in class org.springframework.integration.scripting.dsl.ScriptSpec
- 
The refreshCheckDelay in milliseconds for refreshable script resource.
- refreshGraph() - Method in class org.springframework.integration.http.management.IntegrationGraphController
- regexFileNameFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Specify a simple pattern to match remote files (e.g.
- regexFileNameFilter(String) - Method in class org.springframework.integration.ftp.dsl.FtpOutboundGatewaySpec
- regexFileNameFilter(String) - Method in class org.springframework.integration.sftp.dsl.SftpOutboundGatewaySpec
- regexFileNameFilter(String) - Method in class org.springframework.integration.smb.dsl.SmbOutboundGatewaySpec
- regexFilter(String) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
- 
Configure aRegexPatternFileListFilter.
- regexFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
- 
Configure a regex pattern filter (e.g.
- regexFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
- 
Configure a regex pattern filter (e.g.
- regexFilter(String) - Method in class org.springframework.integration.ftp.dsl.FtpInboundChannelAdapterSpec
- 
Specify a regular expression to match remote files.
- regexFilter(String) - Method in class org.springframework.integration.ftp.dsl.FtpStreamingInboundChannelAdapterSpec
- 
Specify a regular expression to match remote files (e.g.
- regexFilter(String) - Method in class org.springframework.integration.sftp.dsl.SftpInboundChannelAdapterSpec
- regexFilter(String) - Method in class org.springframework.integration.sftp.dsl.SftpStreamingInboundChannelAdapterSpec
- 
Specify a regular expression to match remote files (e.g.
- regexFilter(String) - Method in class org.springframework.integration.smb.dsl.SmbInboundChannelAdapterSpec
- 
Specify a regular expression to match remote files.
- regexFilter(String) - Method in class org.springframework.integration.smb.dsl.SmbStreamingInboundChannelAdapterSpec
- 
Specify a regular expression to match remote files (e.g.
- regexMputFilter(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
ASimplePatternFileListFilterthat runs against the local file system view when usingMPUTcommand.
- RegexPatternFileListFilter - Class in org.springframework.integration.file.filters
- 
Implementation of AbstractRegexPatternMatchingFileListFilter for java.io.File instances.
- RegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.RegexPatternFileListFilter
- RegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.file.filters.RegexPatternFileListFilter
- RegexTestXPathMessageSelector - Class in org.springframework.integration.xml.selector
- 
XPathMessageSelectorthat tests if a provided String value matches a given Regular Expression.
- RegexTestXPathMessageSelector(String, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
- 
Creates a non-namespaced selector which attempts to match the given regex.
- RegexTestXPathMessageSelector(String, String, String, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
- 
Creates a selector which attempts to match the given regex and supports a single namespace.
- RegexTestXPathMessageSelector(String, Map<String, String>, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
- 
Creates a selector which attempts to match the given regex and supports multiple namespaces.
- RegexTestXPathMessageSelector(XPathExpression, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
- 
Creates a selector which attempts to match the given regex against the evaluation result of the providedXPathExpression.
- RegexUtils - Class in org.springframework.integration.ip.util
- 
Regular Expression Utilities.
- register() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
- 
Register anIntegrationFlowand all the dependant and support components in the application context and return an associatedIntegrationFlowContext.IntegrationFlowRegistrationcontrol object.
- register() - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
- 
Register anIntegrationFlowand all the dependant and support components in the application context and return an associatedIntegrationFlowContext.IntegrationFlowRegistrationcontrol object.
- register(S, Consumer<? super S>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- registerBean(String, Object) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
- registerBeanDefinition(BeanDefinitionHolder, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.IntegrationComponentScanRegistrar
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.IntegrationRegistrar
- 
Invoked by the framework when an @EnableIntegration annotation is encountered.
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.MessageHistoryRegistrar
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.PublisherRegistrar
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.http.config.IntegrationGraphControllerRegistrar
- registerChannel(String, MessageChannel) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
- registerControlBusCommands(String, Object) - Method in class org.springframework.integration.support.management.ControlBusCommandRegistry
- 
Manually register Control Bus commands (if any) for a specific bean.
- registerEndpoint(String, Object) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- 
Registers a TcpListener to receive messages after the payload has been converted from the input data.
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
- 
Delegate TCP Client Connection factories that are used to receive data need a Listener to send the messages to.
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
- 
Delegate TCP Client Connection factories that are used to receive data need a Listener to send the messages to.
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
- 
Set the listener that will receive incoming Messages.
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
- registerMessageGroupExpiryCallback(MessageGroupStore.MessageGroupCallback) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
- registerMessageGroupExpiryCallback(MessageGroupStore.MessageGroupCallback) - Method in interface org.springframework.integration.store.MessageGroupStore
- 
Register a callback for when a message group is expired throughMessageGroupStore.expireMessageGroups(long).
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.channel.NullChannel
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.channel.QueueChannel
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.handler.MessageHandlerSupport
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.jms.JmsInboundGateway
- registerMetricsCaptor(MetricsCaptor) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
- registerMetricsCaptor(MetricsCaptor) - Method in interface org.springframework.integration.support.management.IntegrationManagement
- 
Inject aMetricsCaptor.
- registerObservationRegistry(ObservationRegistry) - Method in class org.springframework.integration.channel.AbstractMessageChannel
- registerObservationRegistry(ObservationRegistry) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
- registerObservationRegistry(ObservationRegistry) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- registerObservationRegistry(ObservationRegistry) - Method in class org.springframework.integration.handler.MessageHandlerSupport
- registerObservationRegistry(ObservationRegistry) - Method in class org.springframework.integration.jms.JmsInboundGateway
- registerObservationRegistry(ObservationRegistry) - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
- registerObservationRegistry(ObservationRegistry) - Method in interface org.springframework.integration.support.management.IntegrationManagement
- 
Inject anObservationRegistry.
- registerOutputChannelIfCan(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- registerReplyMessageCorrelatorIfNecessary() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- registerScriptExecutorProviderIfNecessary(BeanDefinitionRegistry) - Method in class org.springframework.integration.groovy.config.GroovyIntegrationConfigurationInitializer
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- 
Registers a TcpSender; for server sockets, used to provide connection information so a sender can be used to reply to incoming messages.
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
- 
Register a sender.
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
- registerSenders(List<TcpSender>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- registerSenders(List<TcpSender>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
- 
Register the senders.
- registerSpelFunctionBean(BeanDefinitionRegistry, String, Class<?>, String) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
- 
Register aSpelFunctionFactoryBeanfor the provided method signature.
- registerSpelFunctionBean(BeanDefinitionRegistry, String, String, String) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
- registerTestListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
- 
Set a temporary listener to receive just the first incoming message.
- registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
- registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.CompositeKryoRegistrar
- registerTypes(Kryo) - Method in interface org.springframework.integration.codec.kryo.KryoRegistrar
- 
This method is invoked by thePojoCodecand applied to theKryoinstance whenever a new instance is created.
- registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
- registerWebSocketHandlers(WebSocketHandlerRegistry) - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
- registration() - Element in annotation interface org.springframework.integration.jmx.config.EnableIntegrationMBeanExport
- 
The policy to use when attempting to register an MBean under anObjectNamethat already exists.
- registration(IntegrationFlow) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
- 
Associate providedIntegrationFlowwith anIntegrationFlowContext.IntegrationFlowRegistrationBuilderfor additional options and farther registration in the application context.
- registration(IntegrationFlow) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
- 
Associate providedIntegrationFlowwith anStandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilderfor additional options and farther registration in the application context.
- RegistrationIds - Class in org.springframework.integration.codec.kryo
- 
Default registration ids for serializers provided by the framework.
- reject(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
- 
REJECT the associated message if the callback is not null.
- REJECT - Enum constant in enum class org.springframework.integration.acks.AcknowledgmentCallback.Status
- 
Mark the message as rejected.
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.springframework.integration.util.CallerBlocksPolicy
- RELATIVE_PATH - Static variable in class org.springframework.integration.file.FileHeaders
- RELAX_NG - Enum constant in enum class org.springframework.integration.xml.selector.XmlValidatingMessageSelector.SchemaType
- release() - Method in class org.springframework.integration.util.UpperBound
- 
Releases one lock on the underlying semaphore.
- release(int) - Method in class org.springframework.integration.util.UpperBound
- 
Releases several locks on the underlying semaphore.
- releaseConnection() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
- releaseExpression(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- 
Configure the handler with anExpressionEvaluatingReleaseStrategyfor the given expression.
- releaseItem(T) - Method in interface org.springframework.integration.util.Pool
- 
Release an item back into the pool.
- releaseItem(T) - Method in class org.springframework.integration.util.SimplePool
- 
Return an item to the pool.
- releaseLockBeforeSend(boolean) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- 
Set to true to release the message group lock before sending any output.
- releasePartialSequences(boolean) - Method in class org.springframework.integration.dsl.ResequencerSpec
- releaseStrategy(Object, String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- 
Configure the handler with anMethodInvokingReleaseStrategyfor the target object and method name.
- releaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- ReleaseStrategy - Interface in org.springframework.integration.aggregator
- 
Strategy for determining when a group of messages reaches a state of completion (i.e.
- ReleaseStrategy - Annotation Interface in org.springframework.integration.annotation
- 
Indicates that a method is capable of asserting if a list of messages or payload objects is complete.
- ReleaseStrategyFactoryBean - Class in org.springframework.integration.config
- 
Convenience factory for XML configuration of aReleaseStrategy.
- ReleaseStrategyFactoryBean() - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
- ReloadableResourceBundleExpressionSource - Class in org.springframework.integration.expression
- 
ExpressionSourceimplementation that accesses resource bundles using specified basenames.
- ReloadableResourceBundleExpressionSource() - Constructor for class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
- REMAINING_RECORDS - Static variable in class org.springframework.integration.kafka.inbound.KafkaMessageSource
- 
The number of records remaining from the previous poll.
- remainingCapacity() - Method in class org.springframework.integration.store.MessageGroupQueue
- REMOTE_DIRECTORY - Static variable in class org.springframework.integration.file.FileHeaders
- REMOTE_FILE - Static variable in class org.springframework.integration.file.FileHeaders
- REMOTE_FILE_INFO - Static variable in class org.springframework.integration.file.FileHeaders
- 
A remote file information representation.
- REMOTE_HOST_PORT - Static variable in class org.springframework.integration.file.FileHeaders
- 
A remote host/port the file has been polled from.
- REMOTE_PORT - Static variable in class org.springframework.integration.ip.IpHeaders
- 
The remote port from which a TCP message was received.
- REMOTE_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- REMOTE_TIMEOUT_EXPRESSION - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- remoteComparator(Comparator<? extends F>) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
- 
Set a comparator to sort the retrieved list ofF(the Type that represents the remote file) prior to applying filters and max fetch size.
- remoteDirectory(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- 
Specify a remote directory path.
- remoteDirectory(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
- 
Specify the full path to the remote directory.
- remoteDirectory(String) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
- 
Specify the full path to the remote directory.
- remoteDirectory(Function<Message<?>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
- 
Specify a function that is invoked to determine the full path to the remote directory.
- remoteDirectory(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- 
Specify a remote directory pathFunction.
- remoteDirectory(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
- 
Specify an expression that evaluates to the full path to the remote directory.
- remoteDirectoryExpression(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- 
Specify a remote directory path SpEL expression.
- remoteDirectoryExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Set the remote directory expression used to determine the remote directory to which files will be sent.
- remoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- 
Specify a remote directory path SpEL expression.
- remoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
- 
Specify an expression that evaluates to the full path to the remote directory.
- remoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Set the remote directory expression used to determine the remote directory to which files will be sent.
- remoteDirectoryFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Specify aFunctionfor remote directory.
- RemoteFileInboundChannelAdapterSpec<F,S, - Class in org.springframework.integration.file.dslMS> 
- RemoteFileInboundChannelAdapterSpec(AbstractInboundFileSynchronizer<F>) - Constructor for class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
- remoteFileMetadataStore(MetadataStore) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
- 
Configure aMetadataStorefor remote files metadata.
- RemoteFileOperations<F> - Interface in org.springframework.integration.file.remote
- 
Strategy for performing operations on remote files.
- RemoteFileOperations.OperationsCallback<F,T> - Interface in org.springframework.integration.file.remote
- 
Callback for using the same session for multiple RemoteFileTemplate operations.
- RemoteFileOutboundChannelAdapterParser - Class in org.springframework.integration.file.config
- RemoteFileOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.RemoteFileOutboundChannelAdapterParser
- RemoteFileOutboundGatewaySpec<F,S> - Class in org.springframework.integration.file.dsl
- 
TheMessageHandlerSpecfor theAbstractRemoteFileOutboundGateway.
- RemoteFileOutboundGatewaySpec(AbstractRemoteFileOutboundGateway<F>) - Constructor for class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- remoteFileSeparator(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- 
Specify a remote file separator symbol.
- remoteFileSeparator(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
- 
Configure the file name path separator used by the remote system.
- remoteFileSeparator(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Set the file separator when dealing with remote files; default '/'.
- remoteFileSeparator(String) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
- 
Configure the file name path separator used by the remote system.
- RemoteFileStreamingInboundChannelAdapterSpec<F,S, - Class in org.springframework.integration.file.dslMS> 
- RemoteFileStreamingInboundChannelAdapterSpec() - Constructor for class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
- remoteFileTemplate - Variable in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
- RemoteFileTemplate<F> - Class in org.springframework.integration.file.remote
- 
A general abstraction for dealing with remote files.
- RemoteFileTemplate(SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.RemoteFileTemplate
- 
Construct aRemoteFileTemplatewith the supplied session factory.
- remoteFileTemplateExplicitlySet(boolean) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- RemoteFileUtils - Class in org.springframework.integration.file.remote
- 
Utility methods for supporting remote file operations.
- remotePath(AbstractFileInfo<F>) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
- remoteTimeout(long) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
- remoteTimeout(Function<Message<P>, ?>) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
- 
Configure aFunctionthat will be invoked at runtime to determine the destination to which a message will be sent.
- remove() - Method in interface org.springframework.integration.support.management.metrics.MeterFacade
- 
Remove this meter facade.
- remove() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.AbstractMeter
- remove(int) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
- remove(int) - Method in class org.springframework.integration.history.MessageHistory
- remove(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- remove(F) - Method in class org.springframework.integration.file.filters.AcceptOnceFileListFilter
- remove(F) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
- remove(F) - Method in interface org.springframework.integration.file.filters.ResettableFileListFilter
- 
Remove the specified file from the filter, so it will pass on the next attempt.
- remove(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
- remove(Object) - Method in class org.springframework.integration.history.MessageHistory
- remove(Object) - Method in class org.springframework.integration.support.MutableMessageHeaders
- remove(String) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
- 
Destroy anIntegrationFlowbean (as well as all its dependant beans) for providedflowIdand clean up all the local cache for it.
- remove(String) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
- 
Destroy anIntegrationFlowbean (as well as all its dependant beans) for providedflowIdand clean up all the local cache for it.
- remove(String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
- 
Remove a remote file.
- remove(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
- remove(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
- remove(String) - Method in interface org.springframework.integration.file.remote.session.Session
- remove(String) - Method in class org.springframework.integration.ftp.session.FtpSession
- remove(String) - Method in class org.springframework.integration.hazelcast.metadata.HazelcastMetadataStore
- remove(String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
- remove(String) - Method in interface org.springframework.integration.metadata.MetadataStore
- 
Remove a value for the given key from this MetadataStore.
- remove(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
- remove(String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
- remove(String) - Method in class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
- 
Remove the metadata entry for the providedkeyand return itsvalue, if any, usingfindAndRemoveMongoDB operation.
- remove(String) - Method in class org.springframework.integration.redis.metadata.RedisMetadataStore
- remove(String) - Method in class org.springframework.integration.sftp.session.SftpSession
- remove(String) - Method in class org.springframework.integration.smb.session.SmbSession
- 
Delete the file or directory at the specified path.
- remove(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
- remove(UUID) - Method in class org.springframework.integration.store.MessageGroupMetadata
- remove(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- remove(Message<?>) - Method in interface org.springframework.integration.store.MessageGroup
- 
Remove the message from this group.
- remove(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
- remove(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
- removeAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
- removeAll(Collection<UUID>) - Method in class org.springframework.integration.store.MessageGroupMetadata
- removeAllIdleItems() - Method in interface org.springframework.integration.util.Pool
- 
Remove all idle items from the pool.
- removeAllIdleItems() - Method in class org.springframework.integration.util.SimplePool
- removeCallback(ClientManager.ConnectCallback) - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
- removeCallback(ClientManager.ConnectCallback) - Method in interface org.springframework.integration.mqtt.core.ClientManager
- 
Remove the callback from registration.
- removeChannelMapping(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
- 
Remove a channel mapping for the given key if present.
- removeChannelMapping(String) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
- removeChannelMapping(String) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
- 
Remove a channel mapping for the given key if present.
- removed(ServerSession, Path, boolean, Throwable) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
- REMOVED - Enum constant in enum class org.springframework.integration.hazelcast.CacheEventType
- 
The Hazelcast REMOVED event.
- removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- removeDeadConnection(TcpConnection) - Method in interface org.springframework.integration.ip.tcp.connection.TcpSender
- 
When we are using sockets owned by aTcpListener, this method is called each time a connection is closed.
- removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
- removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
- removeDestination(String...) - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
- 
Remove a destination (or destinations) from the subscribed list and unsubscribe it.
- removedFromPool(T) - Method in interface org.springframework.integration.util.SimplePool.PoolItemCallback
- 
Called by the pool when an item is forcibly removed from the pool - for example when the pool size is reduced.
- removeFromIdCache(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
- 
Remove a Message Id from the idCache.
- removeHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
- 
Remove the handler from the internal handler Set.
- removeHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
- 
Remove a message handler.
- removeHeader(String) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
- 
Remove the value for the given header name.
- removeHeader(String) - Method in class org.springframework.integration.support.BaseMessageBuilder
- 
Remove the value for the given header name.
- removeHeader(String) - Method in class org.springframework.integration.support.MutableMessageBuilder
- removeHeaders(String...) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
- 
Removes all headers provided via array of 'headerPatterns'.
- removeHeaders(String...) - Method in class org.springframework.integration.support.BaseMessageBuilder
- 
Removes all headers provided via array of 'headerPatterns'.
- removeHeaders(String...) - Method in class org.springframework.integration.support.MutableMessageBuilder
- removeInterceptor(int) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- removeInterceptor(int) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
- removeInterceptor(int) - Method in class org.springframework.integration.channel.AbstractMessageChannel
- removeInterceptor(int) - Method in class org.springframework.integration.channel.AbstractPollableChannel
- removeInterceptor(int) - Method in class org.springframework.integration.jms.PollableJmsChannel
- removeInterceptor(int) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractPollableChannel
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
- removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
- removeLifecycle(SmartLifecycle) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
- 
Remove the provided SmartLifecycle from all the roles, for example when a SmartLifecycle bean is destroyed.
- removeListener(MetadataStoreListener) - Method in class org.springframework.integration.hazelcast.metadata.HazelcastMetadataStore
- removeListener(MetadataStoreListener) - Method in interface org.springframework.integration.metadata.ListenableMetadataStore
- 
Unregister a listener.
- removeListener(MetadataStoreListener) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
- removeMessage(UUID) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- removeMessage(UUID) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- removeMessage(UUID) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
- removeMessage(UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- removeMessage(UUID) - Method in interface org.springframework.integration.store.MessageStore
- 
Remove the Message with the given id from the MessageStore, if present, and return it.
- removeMessage(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
- removeMessageFromGroupById(Object, UUID) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- removeMessageFromGroupById(Object, UUID) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- removeMessageFromGroupById(Object, UUID) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
- removeMessageFromGroupById(Object, UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- removeMessageFromGroupById(Object, UUID) - Method in interface org.springframework.integration.store.MessageGroupStore
- 
Deletion the message from the group.
- removeMessageFromGroupById(Object, UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
- removeMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
- removeMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- removeMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- removeMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
- removeMessageGroup(Object) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
- removeMessageGroup(Object) - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
- removeMessageGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- 
Remove the MessageGroup with the provided group ID.
- removeMessageGroup(Object) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
- 
Remove the message group with this id.
- removeMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in interface org.springframework.integration.store.MessageGroupStore
- 
Persist the deletion of messages from the group.
- removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.store.SimpleMessageStore
- removeMessagesFromGroup(Object, Message<?>...) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
- removeMessagesFromGroup(Object, Message<?>...) - Method in interface org.springframework.integration.store.MessageGroupStore
- 
Persist the deletion of messages from the group.
- removeMeter(MeterFacade) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor
- 
Remove a meter facade.
- removeMeter(MeterFacade) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
- removeRecipient(String) - Method in class org.springframework.integration.router.RecipientListRouter
- removeRecipient(String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
- 
Remove all recipients that match the channelName.
- removeRecipient(String, String) - Method in class org.springframework.integration.router.RecipientListRouter
- removeRecipient(String, String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
- 
Remove all recipients that match the channelName and expression.
- removeRemoteFileMetadata(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
- 
Remove a metadata for remote file associated with the provided local file.
- removeSessionFactory(Object) - Method in class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
- 
Remove a session factory.
- removeTopic(String...) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
- 
Remove a topic (or topics) from the subscribed list.
- removeTopic(String...) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
- removeTopic(String...) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- rename(String, String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
- 
Rename a remote file, creating directories if needed.
- rename(String, String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
- rename(String, String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
- rename(String, String) - Method in interface org.springframework.integration.file.remote.session.Session
- rename(String, String) - Method in class org.springframework.integration.ftp.session.FtpSession
- rename(String, String) - Method in class org.springframework.integration.sftp.session.SftpSession
- rename(String, String) - Method in class org.springframework.integration.smb.session.SmbSession
- RENAME_TO - Static variable in class org.springframework.integration.file.FileHeaders
- renameExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Specify a SpEL expression for files renaming during transfer.
- renameExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Specify a SpEL expression for files renaming during transfer.
- renameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Specify aFunctionfor files renaming during transfer.
- rendezvous() - Method in class org.springframework.integration.dsl.Channels
- rendezvous() - Static method in class org.springframework.integration.dsl.MessageChannels
- rendezvous(String) - Method in class org.springframework.integration.dsl.Channels
- rendezvous(String) - Static method in class org.springframework.integration.dsl.MessageChannels
- RendezvousChannel - Class in org.springframework.integration.channel
- 
A zero-capacity version ofQueueChannelthat delegates to aSynchronousQueueinternally.
- RendezvousChannel() - Constructor for class org.springframework.integration.channel.RendezvousChannel
- RendezvousChannelSpec - Class in org.springframework.integration.dsl
- RendezvousChannelSpec() - Constructor for class org.springframework.integration.dsl.RendezvousChannelSpec
- renew(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
- renew(String) - Method in interface org.springframework.integration.jdbc.lock.LockRepository
- 
Renew the lease for a lock.
- RenewableLockRegistry - Interface in org.springframework.integration.support.locks
- 
ALockRegistryimplementing this interface supports the renewal of the time to live of a lock.
- renewLock(Object) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
- renewLock(Object) - Method in class org.springframework.integration.redis.util.RedisLockRegistry
- renewLock(Object) - Method in interface org.springframework.integration.support.locks.RenewableLockRegistry
- 
Renew the time to live of the lock is associated with the parameter object.
- reopen(boolean) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
- 
Iftrue, close and reopen the file between reading chunks.
- replace(String, String, String) - Method in class org.springframework.integration.hazelcast.metadata.HazelcastMetadataStore
- replace(String, String, String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
- replace(String, String, String) - Method in interface org.springframework.integration.metadata.ConcurrentMetadataStore
- 
Atomically replace the value for the key in the store if the old value matches the oldValue argument.
- replace(String, String, String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
- replace(String, String, String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
- replace(String, String, String) - Method in class org.springframework.integration.mongodb.metadata.MongoDbMetadataStore
- 
Replace an existing metadata entryvaluewith a new one.
- replace(String, String, String) - Method in class org.springframework.integration.redis.metadata.RedisMetadataStore
- replace(String, String, String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
- REPLACE - Enum constant in enum class org.springframework.integration.file.support.FileExistsMode
- 
If the file already exists, replace it.
- REPLACE_IF_MODIFIED - Enum constant in enum class org.springframework.integration.file.support.FileExistsMode
- 
If the file already exists, replace it only if the last modified time is different.
- replaceChannelMappings(Properties) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
- 
Convenience method allowing conversion of a list of mappings in a control-bus message.
- replaceChannelMappings(Properties) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
- replaceChannelMappings(Properties) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
- 
Provide mappings from channel keys to channel names.
- replaceRecipients(Properties) - Method in class org.springframework.integration.router.RecipientListRouter
- replaceRecipients(Properties) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
- 
Replace recipient.
- REPLY_CHANNEL - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- REPLY_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- REPLY_TO - Static variable in class org.springframework.integration.mail.MailHeaders
- replyChannel() - Element in annotation interface org.springframework.integration.annotation.Gateway
- 
Specify the channel from which reply messages will be received; overrides the encompassing gateway's default reply channel.
- replyChannel(Object) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aMessageHeaders.REPLY_CHANNELheader: bean name or instance.
- replyChannel(Object, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aMessageHeaders.REPLY_CHANNELheader: bean name or instance.
- replyChannel(String) - Method in class org.springframework.integration.dsl.EnricherSpec
- replyChannel(String) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
- 
Set a reply channel.
- replyChannel(String) - Method in class org.springframework.integration.dsl.GatewayProxySpec
- 
Identifies the default channel the gateway proxy will subscribe to, to receive replyMessages, the payloads of which will be converted to the return type of the method signature.
- replyChannel(String) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
- 
A reply channel name to use.
- replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.EnricherSpec
- replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
- 
Set a reply channel.
- replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.GatewayProxySpec
- 
Identifies the default channel the gateway proxy will subscribe to, to receive replyMessages, the payloads of which will be converted to the return type of the method signature.
- replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
- 
A reply channel to use.
- replyChannelExpression(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aMessageHeaders.REPLY_CHANNELheader where the value is a SpELExpressionevaluation result.
- replyChannelExpression(String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aMessageHeaders.REPLY_CHANNELheader where the value is a SpELExpressionevaluation result.
- replyChannelFunction(Function<Message<P>, ?>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aMessageHeaders.REPLY_CHANNELheader where the value is obtained by invoking theFunctioncallback.
- replyChannelFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aMessageHeaders.REPLY_CHANNELheader where the value is obtained by invoking theFunctioncallback.
- replyChannelInChainAllowed(Element) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
- 
Override to allow 'reply-channel' within a chain, for components where it makes sense (e.g.
- replyChannelInChainAllowed(Element) - Method in class org.springframework.integration.config.xml.EnricherParser
- replyContainer() - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- 
Configure a reply container with default properties.
- replyContainer(Consumer<JmsOutboundGatewaySpec.ReplyContainerSpec>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- 
Configure a reply container with a reply container specification determined by invoking theConsumercallback with aJmsOutboundGatewaySpec.ReplyContainerSpec.
- ReplyContainerProperties() - Constructor for class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
- replyDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- replyDestination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- replyDestination(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- replyDestination(Function<Message<P>, ?>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- 
Configure aFunctionthat will be invoked at run time to determine the destination from which a reply will be received.
- replyDestinationExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- replyHeadersMappedLast(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
- 
When mapping headers for the outbound (reply) message, determine whether the headers are mapped before the message is converted, or afterwards.
- replyKey(String) - Method in class org.springframework.integration.http.dsl.HttpControllerEndpointSpec
- 
Specify the key to be used when adding the reply Message or payload to the core map (will be payload only unless the value ofBaseHttpInboundEndpoint.setExtractReplyPayload(boolean)isfalse).
- replyMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
- 
AnOutboundMessageMapperto use.
- replyMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec
- 
Set a message converter for replies (when a gateway).
- replyPayloadToFlux(boolean) - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
- 
The boolean flag to identify if the reply payload should be as aFluxfrom the response body or as resolved value from theMonoof the response body.
- replyPriority(int) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- ReplyProducerCleaner() - Constructor for class org.springframework.integration.dsl.BaseIntegrationFlowDefinition.ReplyProducerCleaner
- ReplyProducingMessageHandlerWrapper - Class in org.springframework.integration.handler
- 
TheAbstractReplyProducingMessageHandlerwrapper around rawMessageHandlerfor request-reply scenarios, e.g.
- ReplyProducingMessageHandlerWrapper(MessageHandler) - Constructor for class org.springframework.integration.handler.ReplyProducingMessageHandlerWrapper
- replyPubSubDomain(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- ReplyRequiredException - Exception Class in org.springframework.integration.handler
- 
Exception that indicates no reply message is produced by a handler that does have a value of true for the 'requiresReply' property.
- ReplyRequiredException(Message<?>, String) - Constructor for exception class org.springframework.integration.handler.ReplyRequiredException
- ReplyRequiredException(Message<?>, String, Throwable) - Constructor for exception class org.springframework.integration.handler.ReplyRequiredException
- replyTimeout() - Element in annotation interface org.springframework.integration.annotation.Gateway
- 
Specify the time (ms) that the thread sending the request will wait for a reply.
- replyTimeout(long) - Method in class org.springframework.integration.dsl.GatewayProxySpec
- 
Allows to specify how long this gateway will wait for the replyMessagebefore returning.
- replyTimeout(long) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
- 
A reply timeout to use.
- replyTimeout(Long) - Method in class org.springframework.integration.dsl.EnricherSpec
- replyTimeout(Long) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
- 
Set a reply timeout.
- replyTimeoutExpression() - Element in annotation interface org.springframework.integration.annotation.Gateway
- 
Specify a SpEL Expression to determine the time (ms) that the thread sending the request will wait for a reply.
- replyTimeToLive(long) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- replyTo(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set the ReplyTo: address.
- replyToExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- 
Set a SpEL expression to resolve a 'replyTo' destination from a requestMessageas a root evaluation object ifMessage.getJMSReplyTo()is null.
- replyToExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set the expression that will be evaluated to determine the ReplyTo: address.
- replyToExpression(Expression) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- 
Set a SpEL expression to resolve a 'replyTo' destination from a requestMessageas a root evaluation object ifMessage.getJMSReplyTo()is null.
- replyToFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set a function that will be invoked to determine the ReplyTo: address based on the message.
- replyToFunction(CheckedFunction<Message, ?, JMSException>) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- 
Set a function to resolve a 'replyTo' destination from a requestMessageas a root evaluation object ifMessage.getJMSReplyTo()is null.
- request - Variable in class org.springframework.integration.ftp.server.FtpRequestEvent
- REQUEST_HANDLER_ADVICE_CHAIN - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- REQUEST_METHOD - Static variable in class org.springframework.integration.http.HttpHeaders
- REQUEST_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- REQUEST_URL - Static variable in class org.springframework.integration.http.HttpHeaders
- requestCallback(WebServiceMessageCallback) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- 
Specify theWebServiceMessageCallbackto use.
- requestChannel - Enum constant in enum class org.springframework.integration.rsocket.RSocketInteractionModel
- 
The model forRSocket.requestChannel(org.reactivestreams.Publisher<io.rsocket.Payload>)operation.
- requestChannel() - Element in annotation interface org.springframework.integration.annotation.Gateway
- 
Specify the channel to which messages will be sent; overrides the encompassing gateway's default request channel.
- requestChannel(String) - Method in class org.springframework.integration.dsl.EnricherSpec
- requestChannel(String) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
- 
A request channel name to use.
- requestChannel(MessageChannel) - Method in class org.springframework.integration.dsl.EnricherSpec
- requestChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
- 
A request channel to use.
- requestDestination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec
- 
Specify a request destination for incoming messages.
- requestDestination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- requestDestination(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec
- 
Specify a request destination for incoming messages.
- requestDestination(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- requestDestination(Function<Message<P>, ?>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- 
Configure aFunctionthat will be invoked at runtime to determine the destination to which a message will be sent.
- requestDestinationExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- requestedContentTypeResolver(RequestedContentTypeResolver) - Method in class org.springframework.integration.webflux.dsl.WebFluxInboundEndpointSpec
- requestElementType(ResolvableType) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
- 
Specify a type of payload to be generated when the inbound RSocket request content is read by the converters/encoders.
- requestFactory(ClientHttpRequestFactory) - Method in class org.springframework.integration.http.dsl.HttpMessageHandlerSpec
- 
Set theClientHttpRequestFactoryfor the underlyingRestTemplate.
- RequestHandlerCircuitBreakerAdvice - Class in org.springframework.integration.handler.advice
- 
A circuit breaker that stops calling a failing service after threshold failures, until halfOpenAfter milliseconds has elapsed.
- RequestHandlerCircuitBreakerAdvice() - Constructor for class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
- RequestHandlerCircuitBreakerAdvice.CircuitBreakerOpenException - Exception Class in org.springframework.integration.handler.advice
- 
An exception thrown when the circuit breaker is in an open state.
- RequestHandlerRetryAdvice - Class in org.springframework.integration.handler.advice
- 
Uses spring-retry to perform stateless or stateful retry.
- RequestHandlerRetryAdvice() - Constructor for class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
- requestMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
- 
AnInboundMessageMapperto use.
- requestMapping - Variable in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
- requestMapping(Consumer<HttpInboundEndpointSupportSpec.RequestMappingSpec>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
- 
Provide aConsumerfor configuringRequestMappingviaHttpInboundEndpointSupportSpec.RequestMappingSpec.
- RequestMapping - Class in org.springframework.integration.http.inbound
- 
Class for mapping web requests onto specificHttpRequestHandlingEndpointSupport.
- RequestMapping() - Constructor for class org.springframework.integration.http.inbound.RequestMapping
- RequestMessageCallback(WebServiceMessageCallback, Message<?>) - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.RequestMessageCallback
- requestPayload(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.EnricherSpec
- requestPayloadExpression(String) - Method in class org.springframework.integration.dsl.EnricherSpec
- requestPayloadType(Class<?>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
- 
Specify the type of payload to be generated when the inbound HTTP request content is read by theHttpMessageConverters.
- requestPayloadType(ResolvableType) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
- 
Specify the type of payload to be generated when the inbound HTTP request content is read by theHttpMessageConverters.
- requestPubSubDomain(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- RequestReplyExchanger - Interface in org.springframework.integration.gateway
- 
Interface for a request/reply Message exchange.
- RequestReplyHeaderMapper<T> - Interface in org.springframework.integration.mapping
- 
Request/Reply strategy interface for mappingMessageHeadersto and from other types of objects.
- requestResponse - Enum constant in enum class org.springframework.integration.rsocket.RSocketInteractionModel
- 
The model forRSocket.requestResponse(io.rsocket.Payload)operation.
- RequestResponseScenario - Class in org.springframework.integration.test.support
- 
Defines a Spring Integration request response test scenario.
- RequestResponseScenario(String, String) - Constructor for class org.springframework.integration.test.support.RequestResponseScenario
- 
Create an instance
- requestStream - Enum constant in enum class org.springframework.integration.rsocket.RSocketInteractionModel
- 
The model forRSocket.requestStream(io.rsocket.Payload)operation.
- requestSubFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.EnricherSpec
- 
The request sub-flow.
- requestTimeout() - Element in annotation interface org.springframework.integration.annotation.Gateway
- 
Specify the timeout (ms) when sending to the request channel - only applies if the send might block (such as a boundedQueueChannelthat is currently full.
- requestTimeout(long) - Method in class org.springframework.integration.dsl.GatewayProxySpec
- 
Provides the amount of time dispatcher would wait to send aMessage.
- requestTimeout(long) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
- 
A request timeout to use.
- requestTimeout(Long) - Method in class org.springframework.integration.dsl.EnricherSpec
- requestTimeout(Long) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
- 
Set a request timeout.
- requestTimeoutExpression() - Element in annotation interface org.springframework.integration.annotation.Gateway
- 
Specify a SpEL Expression to determine the timeout (ms) when sending to the request channel - only applies if the send might block (such as a boundedQueueChannelthat is currently full.
- requeue(AcknowledgmentCallback) - Static method in class org.springframework.integration.acks.AckUtils
- 
REQUEUE the associated message if the callback is not null.
- REQUEUE - Enum constant in enum class org.springframework.integration.acks.AcknowledgmentCallback.Status
- 
Reject the message and requeue so that it will be redelivered.
- requiresDestruction(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition.ReplyProducerCleaner
- requiresDestruction(Object) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
- requiresDestruction(Object) - Method in class org.springframework.integration.http.inbound.DynamicRequestMappingBeanPostProcessor
- requiresDestruction(Object) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
- requiresDestruction(Object) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
- requiresReply() - Element in annotation interface org.springframework.integration.annotation.ServiceActivator
- 
Specify whether the service method must return a non-null value.
- requiresReply(boolean) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
- rescheduleAt(Message<?>, Date) - Method in class org.springframework.integration.handler.DelayHandler
- reschedulePersistedMessages() - Method in class org.springframework.integration.handler.DelayHandler
- 
Used for reading persisted Messages in the 'messageStore' to reschedule them e.g.
- reschedulePersistedMessages() - Method in interface org.springframework.integration.handler.DelayHandlerManagement
- resequence() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theResequencingMessageHandlerwith default options.
- resequence(Consumer<ResequencerSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theResequencingMessageHandlerwith provided options fromResequencerSpec.
- resequencer - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- ResequencerParser - Class in org.springframework.integration.config.xml
- 
Parser for the <resequencer> element.
- ResequencerParser() - Constructor for class org.springframework.integration.config.xml.ResequencerParser
- ResequencerSpec - Class in org.springframework.integration.dsl
- ResequencerSpec() - Constructor for class org.springframework.integration.dsl.ResequencerSpec
- ResequencingMessageGroupProcessor - Class in org.springframework.integration.aggregator
- 
This class implements all the strategy interfaces needed for a default resequencer.
- ResequencingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.ResequencingMessageGroupProcessor
- ResequencingMessageHandler - Class in org.springframework.integration.aggregator
- 
Resequencer specific implementation ofAbstractCorrelatingMessageHandler.
- ResequencingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
- ResequencingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
- ResequencingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
- reset() - Method in class org.springframework.integration.scheduling.SimplePollSkipStrategy
- 
Resume polling at the nextTriggerevent.
- reset() - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
- reset() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
- resetBeans(String...) - Method in class org.springframework.integration.test.context.MockIntegrationContext
- 
Reinstate the mocked beans after execution test to their real state.
- resetCache() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
- 
Clear the cache of sessions; also any in-use sessions will be closed when returned to the cache.
- resetSharedSession() - Method in interface org.springframework.integration.file.remote.session.SharedSessionCapable
- 
Resets the shared session so the next#getSession()will return a session using a new connection.
- resetSharedSession() - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
- ResettableFileListFilter<F> - Interface in org.springframework.integration.file.filters
- 
AFileListFilterthat can be reset by removing a specific file from its state.
- resolutionRequired() - Element in annotation interface org.springframework.integration.annotation.Router
- 
Specify whether channel names must always be successfully resolved to existing channel instances.
- resolutionRequired(boolean) - Method in class org.springframework.integration.dsl.RouterSpec
- RESOLVABLE_TYPE - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
- 
The header to represent aResolvableTypefor the target deserialized object.
- resolve(String, Message<?>) - Method in interface org.springframework.integration.redis.outbound.ArgumentsStrategy
- resolve(String, Message<?>) - Method in class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
- resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.CollectionArgumentResolver
- resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.ContinuationHandlerMethodArgumentResolver
- resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.MapArgumentResolver
- resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.PayloadExpressionArgumentResolver
- resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.integration.handler.support.PayloadsArgumentResolver
- resolveAttribute(List<Annotation>, String, Class<T>) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
- 
Get the attribute value from the annotation hierarchy, returning the firstnon-empty) value closest to the annotated method.
- resolveAttributeToBoolean(String) - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- resolveDestination(String) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
- resolveErrorChannel(MessageHeaders) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
- resolveHandlerBeanDefinition(String, AnnotatedBeanDefinition, ResolvableType, List<Annotation>) - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- resolveHandlerBeanDefinition(String, AnnotatedBeanDefinition, ResolvableType, List<Annotation>) - Method in class org.springframework.integration.config.BridgeFromAnnotationPostProcessor
- resolveHandlerBeanDefinition(String, AnnotatedBeanDefinition, ResolvableType, List<Annotation>) - Method in class org.springframework.integration.config.BridgeToAnnotationPostProcessor
- resolveHandlerBeanDefinition(String, AnnotatedBeanDefinition, ResolvableType, List<Annotation>) - Method in class org.springframework.integration.config.FilterAnnotationPostProcessor
- resolveHandlerBeanDefinition(String, AnnotatedBeanDefinition, ResolvableType, List<Annotation>) - Method in class org.springframework.integration.config.InboundChannelAdapterAnnotationPostProcessor
- resolveHandlerBeanDefinition(String, AnnotatedBeanDefinition, ResolvableType, List<Annotation>) - Method in class org.springframework.integration.config.RouterAnnotationPostProcessor
- resolveHandlerBeanDefinition(String, AnnotatedBeanDefinition, ResolvableType, List<Annotation>) - Method in class org.springframework.integration.config.ServiceActivatorAnnotationPostProcessor
- resolveHandlerBeanDefinition(String, AnnotatedBeanDefinition, ResolvableType, List<Annotation>) - Method in class org.springframework.integration.config.SplitterAnnotationPostProcessor
- resolveHandlerBeanDefinition(String, AnnotatedBeanDefinition, ResolvableType, List<Annotation>) - Method in class org.springframework.integration.config.TransformerAnnotationPostProcessor
- resolveHttpStatusFromHeaders(MessageHeaders) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.ChainParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalWireTapParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.IntegrationManagementParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.PollerParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.hazelcast.config.xml.HazelcastClusterMonitorInboundChannelAdapterParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.hazelcast.config.xml.HazelcastContinuousQueryInboundChannelAdapterParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.hazelcast.config.xml.HazelcastEventDrivenInboundChannelAdapterParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
- resolvePrimitiveType(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
- 
Resolve the given class if it is a primitive wrapper class, returning the corresponding primitive type instead.
- resolveSessionId(Message<?>) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
- resolveSessionId(Message<?>) - Method in class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
- 
Resolves thesessionIdfor the givenmessageusing theSubProtocolHandler.resolveSessionId(org.springframework.messaging.Message<?>)algorithm.
- resourceHolder - Variable in class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
- ResourceInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
- 
Parser for 'resource-inbound-channel-adapter'.
- ResourceInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.ResourceInboundChannelAdapterParser
- ResourceKnownHostsServerKeyVerifier - Class in org.springframework.integration.sftp.session
- 
AServerKeyVerifierimplementation for aResourceabstraction.
- ResourceKnownHostsServerKeyVerifier(Resource) - Constructor for class org.springframework.integration.sftp.session.ResourceKnownHostsServerKeyVerifier
- ResourceRetrievingMessageSource - Class in org.springframework.integration.resource
- 
Implementation ofMessageSourcebased onResourcePatternResolverwhich will attempt to resolveResources based on the pattern specified.
- ResourceRetrievingMessageSource(String) - Constructor for class org.springframework.integration.resource.ResourceRetrievingMessageSource
- RESPONSE_TOPIC - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
- ResponseMessageExtractor() - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.ResponseMessageExtractor
- rest() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
- restartAckThread() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- 
If exposed as an MBean, can be used to restart the ack thread if a fatal (bind) error occurred, without bouncing the JVM.
- ResultFactory - Interface in org.springframework.integration.xml.result
- 
Factory to create aResultpossibly taking into account the provided message payload instance.
- ResultToDocumentTransformer - Class in org.springframework.integration.xml.transformer
- ResultToDocumentTransformer() - Constructor for class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
- ResultToDocumentTransformer(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
- ResultToStringTransformer - Class in org.springframework.integration.xml.transformer
- ResultToStringTransformer() - Constructor for class org.springframework.integration.xml.transformer.ResultToStringTransformer
- ResultToStringTransformer(TransformerFactory) - Constructor for class org.springframework.integration.xml.transformer.ResultToStringTransformer
- 
Construct an instance based on the providedTransformerFactory.
- ResultTransformer - Interface in org.springframework.integration.xml.transformer
- 
Implementations of this class allow for the transformation ofResultobjects to other formats.
- resume() - Method in interface org.springframework.integration.core.Pausable
- 
Resume the endpoint if paused.
- resume() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
- resume() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
- resume() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
- retainAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
- RETAINED - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
- retainOriginal - Variable in class org.springframework.integration.syslog.RFC5424SyslogParser
- retrieveMBeanNames() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
- 
Return a collection ofObjectNameofr providedNotificationListeningMessageProducer.mBeanObjectNames.
- RETRIEVING - Enum constant in enum class org.springframework.integration.jpa.support.OutboundGatewayType
- retrievingGateway(EntityManager) - Static method in class org.springframework.integration.jpa.dsl.Jpa
- 
Create aJpaRetrievingOutboundGatewaySpecbuilder instance for request-reply gateway based on the providedEntityManager.
- retrievingGateway(EntityManagerFactory) - Static method in class org.springframework.integration.jpa.dsl.Jpa
- 
Create aJpaRetrievingOutboundGatewaySpecbuilder instance for request-reply gateway based on the providedEntityManagerFactory.
- retrievingGateway(JpaOperations) - Static method in class org.springframework.integration.jpa.dsl.Jpa
- 
Create aJpaRetrievingOutboundGatewaySpecbuilder instance for request-reply gateway based on the providedJpaOperations.
- RetrievingJpaOutboundGatewayParser - Class in org.springframework.integration.jpa.config.xml
- 
The Parser for the Retrieving Jpa Outbound Gateway.
- RetrievingJpaOutboundGatewayParser() - Constructor for class org.springframework.integration.jpa.config.xml.RetrievingJpaOutboundGatewayParser
- RETRY_INTERVAL - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- RetryAdviceParser - Class in org.springframework.integration.config.xml
- RetryAdviceParser() - Constructor for class org.springframework.integration.config.xml.RetryAdviceParser
- retryConnection() - Method in interface org.springframework.integration.ip.tcp.connection.ClientModeCapable
- 
Immediately attempt to establish the connection.
- retryConnection() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- retryConnection() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
- retryConnection() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
- retryDelay(long) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
- 
Set an additional delay to apply when retrying after a release failure.
- RetryExceptionNotAvailableException(Message<?>, String) - Constructor for exception class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer.RetryExceptionNotAvailableException
- retryInterval(long) - Method in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
- retryInterval(long) - Method in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
- retryInterval(long) - Method in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
- retryOps - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- RetryStateGenerator - Interface in org.springframework.integration.handler.advice
- 
Strategy interface for generating aRetryStateinstance based on a message.
- retryTemplate(RetryTemplate) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundChannelAdapterSpec
- 
Set aRetryTemplateto use for retrying a message delivery within the adapter.
- retryTemplate(RetryTemplate) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
- 
Set aRetryTemplateto use for retrying a message delivery within the adapter.
- retryTemplate(RetryTemplate) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- 
Set aRetryTemplateto use for retrying a message delivery within the adapter.
- retryTemplate(RetryTemplate) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec
- 
Set aRetryTemplateto use for retrying a message delivery within the adapter.
- retryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
- 
Specify aRetryTemplateinstance to use for retrying deliveries.
- retryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
- 
Specify aRetryTemplateinstance to use for retrying deliveries.
- RETURN_VALUE_EXPRESSION - Static variable in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
- RETURN_VALUE_EXPRESSION - Static variable in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
- RETURN_VALUE_EXPRESSION - Static variable in class org.springframework.integration.aop.SimplePublisherMetadataSource
- RETURN_VALUE_VARIABLE_NAME - Static variable in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
- RETURN_VALUE_VARIABLE_NAME - Static variable in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
- RETURN_VALUE_VARIABLE_NAME - Static variable in class org.springframework.integration.aop.SimplePublisherMetadataSource
- returnChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- 
Set the channel to which returned messages are sent.
- ReturnedAmqpMessageException - Exception Class in org.springframework.integration.amqp.support
- 
A MessagingException for a returned message.
- ReturnedAmqpMessageException(Message<?>, Message, int, String, String, String) - Constructor for exception class org.springframework.integration.amqp.support.ReturnedAmqpMessageException
- returnedMessage(ReturnedMessage) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- ReversibleFileListFilter<F> - Interface in org.springframework.integration.file.filters
- 
AFileListFilterthat allows the caller to reverse (roll back) state changes.
- revertLogLevels(String, TestUtils.LevelsContainer) - Static method in class org.springframework.integration.test.util.TestUtils
- RFC5424MessageConverter - Class in org.springframework.integration.syslog
- 
MessageConverter; delegates to aRFC5424SyslogParserif necessary (TCP will have already done the syslog conversion because it needs to handle different message framing).
- RFC5424MessageConverter() - Constructor for class org.springframework.integration.syslog.RFC5424MessageConverter
- 
Construct an instance with a defaultRFC5424SyslogParser.
- RFC5424MessageConverter(RFC5424SyslogParser) - Constructor for class org.springframework.integration.syslog.RFC5424MessageConverter
- 
Construct an instance with a non-standard parser.
- RFC5424SyslogParser - Class in org.springframework.integration.syslog
- 
Parse for RFC 5424 syslog messages; when used with TCP, requires the use of aRFC6587SyslogDeserializerwhich decodes the framing.
- RFC5424SyslogParser() - Constructor for class org.springframework.integration.syslog.RFC5424SyslogParser
- 
Construct a default parser; do not retain the original message content unless there is an error.
- RFC5424SyslogParser(boolean) - Constructor for class org.springframework.integration.syslog.RFC5424SyslogParser
- RFC5424SyslogParser.Reader - Class in org.springframework.integration.syslog
- RFC5424SyslogParser.Severity - Enum Class in org.springframework.integration.syslog
- RFC6587SyslogDeserializer - Class in org.springframework.integration.syslog.inbound
- 
RFC5424/6587 Deserializer.
- RFC6587SyslogDeserializer() - Constructor for class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
- 
Construct an instance using aByteArrayLfSerializerfor non-transparent frames.
- RFC6587SyslogDeserializer(Deserializer<byte[]>) - Constructor for class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
- 
Construct an instance using the specifiedDeserializerfor non-transparent frames.
- rm(Message<?>, Session<F>, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- 
Perform remote delete for the provided path.
- rm(Message<?>, Session<FTPFile>, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- RM - Enum constant in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
- 
(rm) Remove a remote file (path - including wildcards).
- rmdir(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
- rmdir(String) - Method in interface org.springframework.integration.file.remote.session.Session
- 
Remove a remote directory.
- rmdir(String) - Method in class org.springframework.integration.ftp.session.FtpSession
- rmdir(String) - Method in class org.springframework.integration.sftp.session.SftpSession
- rmdir(String) - Method in class org.springframework.integration.smb.session.SmbSession
- role - Variable in class org.springframework.integration.hazelcast.leader.LeaderInitiator.LeaderSelector
- role(String) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
- role(String) - Method in class org.springframework.integration.dsl.EndpointSpec
- 
Specify the role for the endpoint.
- role(String) - Method in class org.springframework.integration.dsl.MessageProducerSpec
- 
Specify the role for the endpoint.
- role(String) - Method in class org.springframework.integration.dsl.SourcePollingChannelAdapterSpec
- Role - Annotation Interface in org.springframework.integration.annotation
- 
Annotate endpoints to assign them to a role.
- ROLE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- rollback(F, List<F>) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- 
Indicate that not all files previously passed by this filter (inFileListFilter.filterFiles(Object[])have been processed; the file must be in the list of files; it, and all files after it, will be considered to have not been processed and will be considered next time.
- rollback(F, List<F>) - Method in class org.springframework.integration.file.filters.AcceptOnceFileListFilter
- rollback(F, List<F>) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
- rollback(F, List<F>) - Method in interface org.springframework.integration.file.filters.ReversibleFileListFilter
- 
Indicate that not all files previously passed by this filter (inFileListFilter.filterFiles(Object[])have been processed; the file must be in the list of files; it, and all files after it, will be considered to have not been processed and will be considered next time.
- rollbackFromFileToListEnd(List<F>, F) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
- rollbackFromFileToListEnd(List<F>, F) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
- ROME_TOOLS_PRESENT - Static variable in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
- RotatingServerAdvice - Class in org.springframework.integration.file.remote.aop
- 
A smart poller advice that rotates across multiple remote servers/directories.
- RotatingServerAdvice(RotationPolicy) - Constructor for class org.springframework.integration.file.remote.aop.RotatingServerAdvice
- 
Construct an instance that rotates according to the suppliedRotationPolicy.
- RotatingServerAdvice(DelegatingSessionFactory<?>, List<RotationPolicy.KeyDirectory>) - Constructor for class org.springframework.integration.file.remote.aop.RotatingServerAdvice
- 
Create an instance that rotates to the next server/directory if no message is received.
- RotatingServerAdvice(DelegatingSessionFactory<?>, List<RotationPolicy.KeyDirectory>, boolean) - Constructor for class org.springframework.integration.file.remote.aop.RotatingServerAdvice
- 
Create an instance that rotates to the next server/directory depending on the fair argument.
- RotationPolicy - Interface in org.springframework.integration.file.remote.aop
- 
A strategy for rotating advices to allow reconfiguring the message source before and/or after a poll.
- RotationPolicy.KeyDirectory - Class in org.springframework.integration.file.remote.aop
- 
A key for a thread-local store and its related directory pair.
- RoundRobinLoadBalancingStrategy - Class in org.springframework.integration.dispatcher
- 
Round-robin implementation ofLoadBalancingStrategy.
- RoundRobinLoadBalancingStrategy() - Constructor for class org.springframework.integration.dispatcher.RoundRobinLoadBalancingStrategy
- route - Enum constant in enum class org.springframework.integration.graph.LinkNode.Type
- route(Class<P>, Function<P, T>, Consumer<RouterSpec<T, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMethodInvokingRouterfor providedFunctionand payload type and options fromRouterSpec.
- route(Class<S>, Function<S, T>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMethodInvokingRouterfor providedFunctionand payload type with default options.
- route(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMethodInvokingRouterfor the discovered method of the provided service and its method with default options.
- route(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMethodInvokingRouterfor the method of the provided service and its method with default options.
- route(Object, String, Consumer<RouterSpec<Object, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMethodInvokingRouterfor the method of the provided service and its method with provided options fromRouterSpec.
- route(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theExpressionEvaluatingRouterfor provided SpEL expression with default options.
- route(String, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMethodInvokingRouterfor provided bean and its method with default options.
- route(String, String, Consumer<RouterSpec<Object, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMethodInvokingRouterfor provided bean and its method with provided options fromRouterSpec.
- route(String, Consumer<RouterSpec<T, ExpressionEvaluatingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theExpressionEvaluatingRouterfor provided SpEL expression with provided options fromRouterSpec.
- route(Function<S, T>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
- 
Populate theMethodInvokingRouterfor providedFunctionwith default options.
- route(Function<S, T>, Consumer<RouterSpec<T, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
- route(LambdaRouteBuilder) - Static method in class org.springframework.integration.camel.dsl.Camel
- 
Create an instance ofCamelMessageHandlerSpecfor the providedLambdaRouteBuilderin aExchangePattern.InOutmode.
- route(LambdaRouteBuilder) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
- route(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMethodInvokingRouterfor theMessageProcessorfrom the providedMessageProcessorSpecwith default options.
- route(MessageProcessorSpec<?>, Consumer<RouterSpec<Object, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMethodInvokingRouterfor theMessageProcessorfrom the providedMessageProcessorSpecwith default options.
- route(AbstractMessageRouter) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate the providedAbstractMessageRouterimplementation to the current integration flow position.
- route(R, Consumer<GenericEndpointSpec<R>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate the providedAbstractMessageRouterimplementation to the current integration flow position.
- route(S, Consumer<S>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- routeByException(Consumer<RouterSpec<Class<? extends Throwable>, ErrorMessageExceptionTypeRouter>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theErrorMessageExceptionTypeRouterwith options from theRouterSpec.
- router - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- Router - Annotation Interface in org.springframework.integration.annotation
- 
Indicates that a method is capable of resolving to a channel or channel name based on a message, message header(s), or both.
- ROUTER_DEALER - Enum constant in enum class org.springframework.integration.zeromq.ZeroMqProxy.Type
- RouterAnnotationPostProcessor - Class in org.springframework.integration.config
- 
Post-processor for Methods annotated with@Router.
- RouterAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.RouterAnnotationPostProcessor
- RouterFactoryBean - Class in org.springframework.integration.config
- 
Factory bean for creating a Message Router.
- RouterFactoryBean() - Constructor for class org.springframework.integration.config.RouterFactoryBean
- Routers - Annotation Interface in org.springframework.integration.annotation
- 
The repeatable container forRouterannotations.
- RouterSpec<K,R> - Class in org.springframework.integration.dsl
- 
TheAbstractRouterSpecfor anAbstractMappingMessageRouter.
- RouterSpec(R) - Constructor for class org.springframework.integration.dsl.RouterSpec
- routeToRecipients(Consumer<RecipientListRouterSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theRecipientListRouterwith options from theRecipientListRouterSpec.
- ROUTING_SLIP - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
- routingKey(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- 
Configure an AMQP routing key for sending messages.
- routingKeyExpression(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- 
A SpEL expression to evaluate routing key at runtime.
- routingKeyExpression(Expression) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- 
A SpEL expression to evaluate routing key at runtime.
- routingKeyFunction(Function<Message<?>, String>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- 
A function to evaluate routing key at runtime.
- RoutingMessageHandlerNode - Class in org.springframework.integration.graph
- 
Represents an endpoint that can route to multiple channels.
- RoutingMessageHandlerNode(int, String, MessageHandler, String, String, Collection<String>) - Constructor for class org.springframework.integration.graph.RoutingMessageHandlerNode
- routingSlip(Boolean, Object...) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aIntegrationMessageHeaderAccessor.ROUTING_SLIPheader.
- routingSlip(Object...) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aIntegrationMessageHeaderAccessor.ROUTING_SLIPheader.
- RoutingSlipHeaderValueMessageProcessor - Class in org.springframework.integration.transformer.support
- 
TheRoutingSlipHeaderValueMessageProcessorspecific implementation.
- RoutingSlipHeaderValueMessageProcessor(Object...) - Constructor for class org.springframework.integration.transformer.support.RoutingSlipHeaderValueMessageProcessor
- RoutingSlipRouteStrategy - Interface in org.springframework.integration.routingslip
- 
TheRoutingSlipstrategy to determine the nextreplyChannel.
- ROWID - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- RSocketConnectedEvent - Class in org.springframework.integration.rsocket
- 
AnIntegrationEventto indicate thatRSocketfrom the client is connected to the server.
- RSocketConnectedEvent(Object, Map<String, Object>, DataBuffer, RSocketRequester) - Constructor for class org.springframework.integration.rsocket.RSocketConnectedEvent
- rsocketConnector(AbstractRSocketConnector) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
- 
Provide anAbstractRSocketConnectorreference for an explicit endpoint mapping.
- RSocketInboundGateway - Class in org.springframework.integration.rsocket.inbound
- 
TheMessagingGatewaySupportimplementation for theIntegrationRSocketEndpoint.
- RSocketInboundGateway(String...) - Constructor for class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
- 
Instantiate based on the provided path patterns to map this endpoint for incoming RSocket requests.
- RSocketInboundGatewayParser - Class in org.springframework.integration.rsocket.config
- 
Parser for the <inbound-gateway/> element of the 'rsocket' namespace.
- RSocketInboundGatewayParser() - Constructor for class org.springframework.integration.rsocket.config.RSocketInboundGatewayParser
- RSocketInboundGatewaySpec - Class in org.springframework.integration.rsocket.dsl
- 
TheMessagingGatewaySpecimplementation for theRSocketInboundGateway.
- RSocketInboundGatewaySpec(String...) - Constructor for class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
- RSocketInteractionModel - Enum Class in org.springframework.integration.rsocket
- 
The RSocket protocol interaction models.
- rSocketMessageHandler - Variable in class org.springframework.integration.rsocket.AbstractRSocketConnector
- RSocketNamespaceHandler - Class in org.springframework.integration.rsocket.config
- 
Namespace handler for Spring Integration XML configuration for RSocket support.
- RSocketNamespaceHandler() - Constructor for class org.springframework.integration.rsocket.config.RSocketNamespaceHandler
- RSocketOutboundGateway - Class in org.springframework.integration.rsocket.outbound
- 
An Outbound Messaging Gateway for RSocket requests.
- RSocketOutboundGateway(String, Object...) - Constructor for class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
- 
Instantiate based on the provided RSocket endpointrouteand optional variables to expand route template.
- RSocketOutboundGateway(Expression) - Constructor for class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
- 
Instantiate based on the provided SpEL expression to evaluate an RSocket endpointrouteat runtime against a request message.
- RSocketOutboundGatewayParser - Class in org.springframework.integration.rsocket.config
- 
Parser for the 'outbound-gateway' element of the rsocket namespace.
- RSocketOutboundGatewayParser() - Constructor for class org.springframework.integration.rsocket.config.RSocketOutboundGatewayParser
- RSocketOutboundGatewaySpec - Class in org.springframework.integration.rsocket.dsl
- 
TheMessageHandlerSpecimplementation for theRSocketOutboundGateway.
- RSocketOutboundGatewaySpec(String, Object...) - Constructor for class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
- RSocketOutboundGatewaySpec(Expression) - Constructor for class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
- RSockets - Class in org.springframework.integration.rsocket.dsl
- 
The RSocket components Factory.
- rsocketStrategies(RSocketStrategies) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
- 
Configure anRSocketStrategiesinstead of a default one.
- RubyScriptExecutor - Class in org.springframework.integration.scripting.jsr223
- 
ADefaultScriptExecutorextension for Ruby scripting support.
- RubyScriptExecutor() - Constructor for class org.springframework.integration.scripting.jsr223.RubyScriptExecutor
- run() - Method in class org.springframework.integration.channel.AbstractExecutorChannel.MessageHandlingTask
- run() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
- run() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
- 
Reads lines from stdout and sends in a message to the output channel.
- run() - Method in class org.springframework.integration.ip.tcp.connection.ClientModeConnectionManager
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
- 
If there is no listener, this method exits.
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
- 
If no listener registers, exits.
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
- 
If there is no listener, this method exits.
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
- 
If no listener registers, exits.
- run() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
- run() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- 
Process acknowledgments, if requested.
- run() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
- 
Expire all message groups older than thetimeoutprovided.
- run() - Method in interface org.springframework.integration.util.CheckedRunnable
- runReaper() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
- 
Cancel the scheduled reap task and run immediately; then reschedule.
- runReaper() - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
- 
Cancel the scheduled reap task and run immediately; then reschedule.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form