Skip navigation links
Spring Integration Java DSL
A B C D E F G H I J K L M N O P Q R S T U V W X _ 

A

AbstractRouterSpec<S extends AbstractRouterSpec<S,R>,R extends org.springframework.integration.router.AbstractMessageRouter> - Class in org.springframework.integration.dsl
A MessageHandlerSpec for AbstractMessageRouters.
accept(T) - Method in interface org.springframework.integration.dsl.support.Consumer
Execute the logic of the action, accepting the given parameter.
acceptMessagesWhileStopping(boolean) - Method in class org.springframework.integration.dsl.jms.JmsListenerContainerSpec
 
acceptMessagesWhileStopping(boolean) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
 
ackCount(int) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the number of outstanding record count after which offsets should be committed when AbstractMessageListenerContainer.AckMode#COUNT or AbstractMessageListenerContainer.AckMode#COUNT_TIME is being used.
ackMode(AbstractMessageListenerContainer.AckMode) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the ack mode to use when auto ack (in the configuration properties) is false.
acknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
acknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
acknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
ackOnError(boolean) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set whether the container should ack messages that throw exceptions or not.
ackTime(long) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the time (ms) after which outstanding offsets should be committed when AbstractMessageListenerContainer.AckMode#TIME or AbstractMessageListenerContainer.AckMode#COUNT_TIME is being used.
Adapters - Class in org.springframework.integration.dsl
 
addBean(Object) - Method in class org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
 
addBean(String, Object) - Method in class org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
 
addQueueNames(String...) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
addQueueNames(String...) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
addQueues(Queue...) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
addQueues(Queue...) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
advice(Advice...) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
advice(Advice...) - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
Configure a list of Advice objects to be applied, in nested order, to the endpoint's handler.
advice(Advice...) - Method in class org.springframework.integration.dsl.core.PollerSpec
Specify AOP Advices for the pollingTask.
adviceChain(Advice...) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
adviceChain(Advice...) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
adviceChain - Variable in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
 
adviceChain(Advice...) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
Configure a chain of Advice objects for message delivery.
afterShutdown() - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
afterShutdown() - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
afterSingletonsInstantiated() - Method in class org.springframework.integration.dsl.config.IntegrationFlowBeanPostProcessor
 
aggregate() - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the AggregatingMessageHandler with default options.
aggregate(Consumer<AggregatorSpec>, Consumer<GenericEndpointSpec<AggregatingMessageHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Deprecated.
aggregate(Consumer<AggregatorSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the AggregatingMessageHandler with provided options from AggregatorSpec.
AggregatorSpec - Class in org.springframework.integration.dsl
A CorrelationHandlerSpec for an AggregatingMessageHandler.
allowCredentials(Boolean) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec.CrossOriginSpec
 
allowedHeaders(String...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec.CrossOriginSpec
 
amqp(AmqpTemplate) - Method in class org.springframework.integration.dsl.Adapters
 
Amqp - Class in org.springframework.integration.dsl.amqp
Factory class for AMQP components.
amqp(ConnectionFactory) - Method in class org.springframework.integration.dsl.Channels
 
amqp(String, ConnectionFactory) - Method in class org.springframework.integration.dsl.Channels
 
amqp(ConnectionFactory, String...) - Method in class org.springframework.integration.dsl.MessageProducers
 
amqp(ConnectionFactory, Queue...) - Method in class org.springframework.integration.dsl.MessageProducers
 
amqp(SimpleMessageListenerContainer) - Method in class org.springframework.integration.dsl.MessageProducers
 
amqp(ConnectionFactory, String...) - Method in class org.springframework.integration.dsl.MessagingGateways
 
amqp(ConnectionFactory, Queue...) - Method in class org.springframework.integration.dsl.MessagingGateways
 
amqp(SimpleMessageListenerContainer) - Method in class org.springframework.integration.dsl.MessagingGateways
 
amqp(ConnectionFactory, AmqpTemplate, String...) - Method in class org.springframework.integration.dsl.MessagingGateways
 
amqp(ConnectionFactory, AmqpTemplate, Queue...) - Method in class org.springframework.integration.dsl.MessagingGateways
 
amqp(SimpleMessageListenerContainer, AmqpTemplate) - Method in class org.springframework.integration.dsl.MessagingGateways
 
AmqpAsyncOutboundGatewaySpec - Class in org.springframework.integration.dsl.amqp
 
AmqpBaseInboundChannelAdapterSpec<S extends AmqpBaseInboundChannelAdapterSpec<S>> - Class in org.springframework.integration.dsl.amqp
The base MessageProducerSpec implementation for a AmqpInboundChannelAdapter.
AmqpBaseInboundGatewaySpec<S extends AmqpBaseInboundGatewaySpec<S>> - Class in org.springframework.integration.dsl.amqp
A base MessagingGatewaySpec implementation for AmqpInboundGateway endpoint options.
AmqpBaseOutboundEndpointSpec<S extends AmqpBaseOutboundEndpointSpec<S,E>,E extends org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint> - Class in org.springframework.integration.dsl.amqp
The base MessageHandlerSpec for AbstractAmqpOutboundEndpoints.
AmqpBaseOutboundEndpointSpec() - Constructor for class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
amqpChannelFactoryBean - Variable in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
 
amqpGateway(AmqpTemplate) - Method in class org.springframework.integration.dsl.Adapters
 
AmqpInboundChannelAdapterSpec - Class in org.springframework.integration.dsl.amqp
A MessageProducerSpec for AmqpInboundChannelAdapters.
AmqpInboundGatewaySpec - Class in org.springframework.integration.dsl.amqp
An AmqpBaseInboundGatewaySpec implementation for a AmqpInboundGateway.
AmqpMessageChannelSpec<S extends AmqpMessageChannelSpec<S>> - Class in org.springframework.integration.dsl.amqp
An AmqpPollableMessageChannelSpec for a message-driven PointToPointSubscribableAmqpChannel.
amqpMessageConverter(MessageConverter) - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
 
AmqpOutboundEndpointSpec - Class in org.springframework.integration.dsl.amqp
 
amqpPollable(ConnectionFactory) - Method in class org.springframework.integration.dsl.Channels
 
amqpPollable(String, ConnectionFactory) - Method in class org.springframework.integration.dsl.Channels
 
AmqpPollableMessageChannelSpec<S extends AmqpPollableMessageChannelSpec<S>> - Class in org.springframework.integration.dsl.amqp
A MessageChannelSpec for a AbstractAmqpChannels.
amqpPublishSubscribe(ConnectionFactory) - Static method in class org.springframework.integration.dsl.Channels
 
amqpPublishSubscribe(String, ConnectionFactory) - Static method in class org.springframework.integration.dsl.Channels
 
AmqpPublishSubscribeMessageChannelSpec - Class in org.springframework.integration.dsl.amqp
A AmqpMessageChannelSpec for PublishSubscribeAmqpChannels.
appendNewLine(boolean) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
 
apply(T) - Method in interface org.springframework.integration.dsl.support.Function
Execute the logic of the action, accepting the given parameter.
applySequence(boolean) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
 
applySequence(boolean) - Method in class org.springframework.integration.dsl.channel.PublishSubscribeChannelSpec
 
applySequence(boolean) - Method in class org.springframework.integration.dsl.file.FileSplitterSpec
A boolean flag to indicate if sequenceDetails should be applied for messages based on the lines from file.
applySequence(boolean) - Method in class org.springframework.integration.dsl.SplitterEndpointSpec
Set the applySequence flag to the specified value.
assertHandler() - Method in class org.springframework.integration.dsl.core.EndpointSpec
 
assertReceiver() - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
 
async(boolean) - Method in class org.springframework.integration.dsl.BarrierSpec
 
async(boolean) - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
Allow async replies.
asyncOutboundGateway(AsyncRabbitTemplate) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpAsyncOutboundGatewaySpec.
attachmentFilename(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
attachmentFilenameExpression(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
attachmentFilenameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
autoCreateDirectory(boolean) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
 
autoCreateDirectory(boolean) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
autoCreateDirectory(boolean) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
 
autoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
Configure whether the local directory should be created by the adapter.
autoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
autoStartup(boolean) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
autoStartup(boolean) - Method in class org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
 
autoStartup(boolean) - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
 
autoStartup(boolean) - Method in class org.springframework.integration.dsl.core.EndpointSpec
 
autoStartup(boolean) - Method in class org.springframework.integration.dsl.core.MessageProducerSpec
 
autoStartup(boolean) - Method in class org.springframework.integration.dsl.core.MessagingGatewaySpec
An auto-startup flag.
autoStartup(boolean) - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
 
autoStartup(boolean) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
 
autoStartup(boolean) - Method in class org.springframework.integration.dsl.SourcePollingChannelAdapterSpec
 

B

backOff(BackOff) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
Specify a BackOff.
barrier(long) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a BarrierMessageHandler instance for provided timeout.
barrier(long, Consumer<BarrierSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a BarrierMessageHandler instance for provided timeout and options from BarrierSpec and endpoint options from GenericEndpointSpec.
BarrierSpec - Class in org.springframework.integration.dsl
A MessageHandlerSpec for the BarrierMessageHandler.
BaseHttpInboundEndpointSpec<S extends BaseHttpInboundEndpointSpec<S,E>,E extends org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport> - Class in org.springframework.integration.dsl.http
 
BaseHttpInboundEndpointSpec.CrossOriginSpec - Class in org.springframework.integration.dsl.http
A fluent API for the CrossOrigin.
BaseHttpInboundEndpointSpec.RequestMappingSpec - Class in org.springframework.integration.dsl.http
A fluent API for the RequestMapping.
batchMode(boolean) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec
 
bcc(String...) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
bccExpression(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
bccFunction(Function<Message<P>, String[]>) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
BeanNameMessageProcessor<T> - Class in org.springframework.integration.dsl.support
An "artificial" MessageProcessor for lazy-load of target bean by its name.
BeanNameMessageProcessor(String, String) - Constructor for class org.springframework.integration.dsl.support.BeanNameMessageProcessor
 
beforeShutdown() - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
beforeShutdown() - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
bridge(Consumer<GenericEndpointSpec<BridgeHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a BridgeHandler to the current integration flow position.
bufferSize(int) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
Set the buffer size to use while writing to files; default 8192.
build() - Method in class org.springframework.integration.dsl.transaction.TransactionInterceptorBuilder
 
buildFlow() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 

C

cacheLevel(int) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
Specify the level of caching that this listener container is allowed to apply.
cacheLevel(Integer) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
Only applies if the JmsMessageChannelSpec.containerType(Class) is a DefaultMessageListenerContainer.
cacheLevel(Integer) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
 
cacheLevelName(String) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
Specify the level of caching that this listener container is allowed to apply, in the form of the name of the corresponding constant: e.g.
capacity - Variable in class org.springframework.integration.dsl.channel.QueueChannelSpec
 
capacity(Integer) - Method in class org.springframework.integration.dsl.channel.QueueChannelSpec.MessageStoreSpec
 
cc(String...) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
ccExpression(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
ccFunction(Function<Message<P>, String[]>) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
channel(ConnectionFactory) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpMessageChannelSpec.
channel(String, ConnectionFactory) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpMessageChannelSpec.
channel - Variable in class org.springframework.integration.dsl.channel.MessageChannelSpec
 
channel(String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageChannelReference instance at the current IntegrationFlow chain position.
channel(Function<Channels, MessageChannelSpec<?, ?>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageChannel instance at the current IntegrationFlow chain position using the Channels factory fluent API.
channel(MessageChannelSpec<?, ?>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageChannel instance at the current IntegrationFlow chain position using the MessageChannelSpec fluent API.
channel(MessageChannel) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the provided MessageChannel instance at the current IntegrationFlow chain position.
channel(ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsMessageChannelSpec.
channel(String, ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsMessageChannelSpec.
channelMapping(K, String) - Method in class org.springframework.integration.dsl.RouterSpec
 
Channels - Class in org.springframework.integration.dsl
 
channelTransacted(boolean) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
channelTransacted(boolean) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
channelTransacted(boolean) - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
Configure channelTransacted on both the RabbitTemplate (for sends) and SimpleMessageListenerContainer (for receives) when using Spring Integration 4.0.
charset(String) - Method in class org.springframework.integration.dsl.file.FileSplitterSpec
 
charset(Charset) - Method in class org.springframework.integration.dsl.file.FileSplitterSpec
 
charset(String) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
charset(Charset) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
charset(String) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
 
charset(String) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
claimCheckIn(MessageStore) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler for the ClaimCheckInTransformer with provided MessageStore.
claimCheckIn(MessageStore, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler for the ClaimCheckInTransformer with provided MessageStore.
claimCheckOut(MessageStore) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler for the ClaimCheckOutTransformer with provided MessageStore.
claimCheckOut(MessageStore, boolean) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler for the ClaimCheckOutTransformer with provided MessageStore and removeMessage flag.
claimCheckOut(MessageStore, boolean, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler for the ClaimCheckOutTransformer with provided MessageStore and removeMessage flag.
clearOnFlush(boolean) - Method in class org.springframework.integration.dsl.jpa.JpaUpdatingOutboundEndpointSpec
 
clientId(String) - Method in class org.springframework.integration.dsl.jms.JmsListenerContainerSpec
 
clientId(String) - Method in class org.springframework.integration.dsl.jms.JmsPublishSubscribeMessageChannelSpec
 
commitCallback(OffsetCommitCallback) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the commit callback; by default a simple logging callback is used to log success at DEBUG level and failures at ERROR level.
ComponentsRegistration - Interface in org.springframework.integration.dsl.core
The marker interface for the IntegrationComponentSpec implementation, when there is need to register as beans not only the target spec's components, but some additional components, e.g.
componentToRegister - Variable in class org.springframework.integration.dsl.core.EndpointSpec
 
concurrency(String) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
The concurrency to use.
concurrency(int) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Specify a concurrency maximum number for the AbstractMessageListenerContainer.
concurrentConsumers(int) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
concurrentConsumers(int) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
concurrentConsumers(int) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
concurrentConsumers(int) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
The concurrent consumers number to use.
concurrentConsumers(int) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
Only applies if the JmsMessageChannelSpec.containerType(Class) is a DefaultMessageListenerContainer or a SimpleMessageListenerContainer.
concurrentConsumers(Integer) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
 
configure(IntegrationFlowDefinition<?>) - Method in interface org.springframework.integration.dsl.IntegrationFlow
 
configure(IntegrationFlowDefinition<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
configure(IntegrationFlowDefinition<?>) - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
configureJmsTemplate(Consumer<JmsTemplateSpec>) - Method in class org.springframework.integration.dsl.jms.JmsInboundChannelAdapterSpec.JmsInboundChannelSpecTemplateAware
Configure the channel adapter to use the template specification created by invoking the Consumer callback, passing in a JmsTemplateSpec.
configureJmsTemplate(Consumer<JmsTemplateSpec>) - Method in class org.springframework.integration.dsl.jms.JmsOutboundChannelAdapterSpec.JmsOutboundChannelSpecTemplateAware
 
configureListenerContainer(Consumer<JmsListenerContainerSpec<S, C>>) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec
 
configureListenerContainer(Consumer<JmsListenerContainerSpec<S, C>>) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
Configure a listener container by invoking the Consumer callback, with a JmsListenerContainerSpec argument.
configureListenerContainer(Consumer<KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec<K, V>>) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
Configure a listener container by invoking the Consumer callback, with a KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec argument.
confirmAckChannel(MessageChannel) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
confirmCorrelationExpression(String) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
confirmCorrelationExpression(Expression) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
confirmCorrelationFunction(Function<Message<?>, Object>) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
confirmNackChannel(MessageChannel) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
consecutiveActiveTrigger(int) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
consecutiveActiveTrigger(int) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
consecutiveIdleTrigger(int) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
consecutiveIdleTrigger(int) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
Consumer<T> - Interface in org.springframework.integration.dsl.support
Implementations accept a given value and perform work on the argument.
ConsumerEndpointSpec<S extends ConsumerEndpointSpec<S,H>,H extends org.springframework.messaging.MessageHandler> - Class in org.springframework.integration.dsl.core
A EndpointSpec for consumer endpoints.
ConsumerEndpointSpec(H) - Constructor for class org.springframework.integration.dsl.core.ConsumerEndpointSpec
 
consumerRebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the user defined ConsumerRebalanceListener implementation.
consumerTaskExecutor(AsyncListenableTaskExecutor) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the executor for threads that poll the consumer.
consumes(String...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec.RequestMappingSpec
 
container(ConnectionFactory, Destination) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsListenerContainerSpec.
container(ConnectionFactory, String) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsListenerContainerSpec.
containerType(Class<? extends AbstractMessageListenerContainer>) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
Configure the type of the container.
contentType(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
contentTypeExpression(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
contentTypeFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
controlBus() - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the Control Bus EI Pattern specific MessageHandler implementation at the current IntegrationFlow chain position.
controlBus(Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the Control Bus EI Pattern specific MessageHandler implementation at the current IntegrationFlow chain position.
converter(Converter<T, U>) - Static method in class org.springframework.integration.dsl.support.Transformers
 
convertExceptions(boolean) - Method in class org.springframework.integration.dsl.http.HttpRequestHandlerEndpointSpec
 
correlationExpression(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with an ExpressionEvaluatingCorrelationStrategy for the given expression.
CorrelationHandlerSpec<S extends CorrelationHandlerSpec<S,H>,H extends org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler> - Class in org.springframework.integration.dsl
A MessageHandlerSpec for an AbstractCorrelatingMessageHandler.
CorrelationHandlerSpec(H) - Constructor for class org.springframework.integration.dsl.CorrelationHandlerSpec
 
correlationKey(String) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
correlationKey(String) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
correlationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.dsl.BarrierSpec
 
correlationStrategy(Object, String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with an MethodInvokingCorrelationStrategy for the target object and method name.
correlationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
credentials(String, String) - Method in class org.springframework.integration.dsl.mail.MailSendingMessageHandlerSpec
 
cron(String) - Method in class org.springframework.integration.dsl.core.PollerFactory
 
cron(String, TimeZone) - Method in class org.springframework.integration.dsl.core.PollerFactory
 
cron(String) - Static method in class org.springframework.integration.dsl.core.Pollers
 
cron(String, TimeZone) - Static method in class org.springframework.integration.dsl.core.Pollers
 
crossOrigin(Consumer<BaseHttpInboundEndpointSpec.CrossOriginSpec>) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
currentComponent - Variable in class org.springframework.integration.dsl.IntegrationFlowDefinition
 
currentMessageChannel - Variable in class org.springframework.integration.dsl.IntegrationFlowDefinition
 

D

datatype(Class<?>...) - Method in class org.springframework.integration.dsl.channel.MessageChannelSpec
 
decoding(Codec, Class<T>) - Static method in class org.springframework.integration.dsl.support.Transformers
The factory method for the DecodingTransformer.
decoding(Codec, String) - Static method in class org.springframework.integration.dsl.support.Transformers
The factory method for the DecodingTransformer.
decoding(Codec, Function<Message<?>, Class<T>>) - Static method in class org.springframework.integration.dsl.support.Transformers
The factory method for the DecodingTransformer.
decoding(Codec, Expression) - Static method in class org.springframework.integration.dsl.support.Transformers
The factory method for the DecodingTransformer.
defaultDelay(long) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
 
defaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
defaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
Configure the delivery mode for messages that don't have an AmqpHeaders.DELIVERY_MODE header.
defaultEncoding(String) - Method in class org.springframework.integration.dsl.mail.MailSendingMessageHandlerSpec
 
defaultFileTypeMap(FileTypeMap) - Method in class org.springframework.integration.dsl.mail.MailSendingMessageHandlerSpec
 
defaultOutputChannel(String) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
Specify a MessageChannel bean name as a default output from the router.
defaultOutputChannel(MessageChannel) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
Specify a MessageChannel as a default output from the router.
defaultOutputToParentFlow() - Method in class org.springframework.integration.dsl.AbstractRouterSpec
Make a default output mapping of the router to the parent flow.
defaultOverwrite(boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Determine the default action to take when setting individual header specifications without an explicit 'overwrite' argument.
defaultReplyDestination(Destination) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
defaultReplyQueueName(String) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
defaultReplyTo(String) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseInboundGatewaySpec
The defaultReplyTo address with the form
 (exchange)/(routingKey)
defaultReplyTopicName(String) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
defaultRequeueRejected(boolean) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
defaultRequeueRejected(boolean) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
defaultSubFlowMapping(IntegrationFlow) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
Specify an IntegrationFlow as an output from the router when no any other mapping has matched.
delay(long) - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
 
delay(String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a DelayHandler to the current integration flow position with default options.
delay(String, Consumer<DelayerEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a DelayHandler to the current integration flow position with provided options.
delay(String, String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a DelayHandler to the current integration flow position with provided delayExpression.
delay(String, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a DelayHandler to the current integration flow position with provided delayFunction.
delay(String, Function<Message<P>, Object>, Consumer<DelayerEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a DelayHandler to the current integration flow position with provided delayFunction.
delay(String, String, Consumer<DelayerEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a DelayHandler to the current integration flow position with provided delayExpression.
delayedAdvice(Advice...) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
Configure a list of Advice objects that will be applied, in nested order, when delayed messages are sent.
DelayerEndpointSpec - Class in org.springframework.integration.dsl
A ConsumerEndpointSpec for a DelayHandler.
deleteAfterPoll(boolean) - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
deleteAfterPoll(boolean) - Method in class org.springframework.integration.dsl.jpa.JpaRetrievingOutboundGatewaySpec
 
deleteInBatch(boolean) - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
deleteInBatch(boolean) - Method in class org.springframework.integration.dsl.jpa.JpaRetrievingOutboundGatewaySpec
 
deleteRemoteFiles(boolean) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
 
deleteSourceFiles(boolean) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
 
delimiters(String) - Method in class org.springframework.integration.dsl.SplitterEndpointSpec
Set delimiters to tokenize String values.
deliveryPersistent(boolean) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
deliveryPersistent(boolean) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
 
deliveryPersistent(boolean) - Method in class org.springframework.integration.dsl.jms.JmsTemplateSpec
 
deserializer() - Static method in class org.springframework.integration.dsl.support.Transformers
 
deserializer(Deserializer<Object>) - Static method in class org.springframework.integration.dsl.support.Transformers
 
destination(Destination) - Method in class org.springframework.integration.dsl.jms.JmsInboundChannelAdapterSpec
Configure the destination from which to receive messages.
destination(String) - Method in class org.springframework.integration.dsl.jms.JmsInboundChannelAdapterSpec
Configure the name of destination from which to receive messages.
destination(Destination) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec
 
destination(String) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec
 
destination(Destination) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
 
destination(String) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
Specify a destination name to use.
destination(Destination) - Method in class org.springframework.integration.dsl.jms.JmsOutboundChannelAdapterSpec
Configure the destination to which this adapter will send messages.
destination(String) - Method in class org.springframework.integration.dsl.jms.JmsOutboundChannelAdapterSpec
Configure the name of the destination to which this adapter will send messages.
destination(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.jms.JmsOutboundChannelAdapterSpec
Configure a Function that will be invoked at run time to determine the destination to which a message will be sent.
destination(String) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
Configure the destination name that backs this channel.
destination(Destination) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
Configure the destination that backs this channel.
destinationExpression(String) - Method in class org.springframework.integration.dsl.jms.JmsOutboundChannelAdapterSpec
Configure a SpEL expression that will evaluate, at run time, the destination to which a message will be sent.
destinationResolver(DestinationResolver) - Method in class org.springframework.integration.dsl.jms.JmsDestinationAccessorSpec
A DestinationResolver to use.
destinationResolver(DestinationResolver) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
destinationResolver(DestinationResolver) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
destinationResolver(DestinationResolver) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
 
destroy() - Method in class org.springframework.integration.dsl.context.IntegrationFlowRegistration
Destroy the IntegrationFlow bean (as well as all its dependant beans) and clean up all the local cache for it.
destroy() - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
destroy() - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
direct() - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
direct(String) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
direct() - Method in class org.springframework.integration.dsl.Channels
 
direct(String) - Method in class org.springframework.integration.dsl.Channels
 
DirectChannelSpec - Class in org.springframework.integration.dsl.channel
 
discardChannel(MessageChannel) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
discardChannel(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
discardChannel(MessageChannel) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
Specify a channel where rejected Messages should be sent.
discardChannel(String) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
Specify a channel name where rejected Messages should be sent.
discardFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
Configure a subflow to run for discarded messages instead of a FilterEndpointSpec.discardChannel(MessageChannel).
discardWithinAdvice(boolean) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
Set to 'true' if you wish the discard processing to occur within any request handler advice applied to this filter.
doGet() - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.BarrierSpec
 
doGet() - Method in class org.springframework.integration.dsl.channel.DirectChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.channel.ExecutorChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.channel.MessageChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.channel.PriorityChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.channel.QueueChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.channel.QueueChannelSpec.MessageStoreSpec
 
doGet() - Method in class org.springframework.integration.dsl.channel.WireTapSpec
 
doGet() - Method in class org.springframework.integration.dsl.core.EndpointSpec
 
doGet() - Method in class org.springframework.integration.dsl.core.IntegrationComponentSpec
 
doGet() - Method in class org.springframework.integration.dsl.EnricherSpec
 
doGet() - Method in class org.springframework.integration.dsl.feed.FeedEntryMessageSourceSpec
 
doGet() - Method in class org.springframework.integration.dsl.file.FileSplitterSpec
 
doGet() - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
 
doGet() - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
doGet() - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
 
doGet() - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
doGet() - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec
 
doGet() - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
 
doGet() - Method in class org.springframework.integration.dsl.scripting.ScriptMessageSourceSpec
 
doGet() - Method in class org.springframework.integration.dsl.scripting.ScriptSpec
 
doReceive() - Method in class org.springframework.integration.dsl.support.MessageProcessorMessageSource
 
doStart() - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
doStart() - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
doStop() - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
doStop() - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
DslIntegrationConfigurationInitializer - Class in org.springframework.integration.dsl.config
The Java DSL Integration infrastructure beanFactory initializer.
DslIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.dsl.config.DslIntegrationConfigurationInitializer
 
durableSubscriptionName(String) - Method in class org.springframework.integration.dsl.jms.JmsListenerContainerSpec
 
durableSubscriptionName(String) - Method in class org.springframework.integration.dsl.jms.JmsPublishSubscribeMessageChannelSpec
 

E

embeddedPartsAsBytes(boolean) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
When a header mapper is provided determine whether an embedded Part (e.g Message or Multipart content is rendered as a byte[] in the payload.
embeddedPartsAsBytes(boolean) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
When a header mapper is provided determine whether an embedded Part (e.g Message or Multipart content is rendered as a byte[] in the payload.
empty - Static variable in class org.springframework.integration.dsl.support.tuple.Tuple
 
empty() - Static method in class org.springframework.integration.dsl.support.tuple.Tuples
Build an empty Tuple instance.
encodeUri(boolean) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
encoding(String) - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
 
encoding(Codec) - Static method in class org.springframework.integration.dsl.support.Transformers
The factory method for the EncodingPayloadTransformer.
end(boolean) - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
 
endpointFactoryBean - Variable in class org.springframework.integration.dsl.core.EndpointSpec
 
EndpointSpec<S extends EndpointSpec<S,F,H>,F extends org.springframework.beans.factory.BeanNameAware,H> - Class in org.springframework.integration.dsl.core
An IntegrationComponentSpec for endpoints.
EndpointSpec(H) - Constructor for class org.springframework.integration.dsl.core.EndpointSpec
 
enrich(Consumer<EnricherSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ContentEnricher to the current integration flow position with provided options.
enrich(Consumer<EnricherSpec>, Consumer<GenericEndpointSpec<ContentEnricher>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ContentEnricher to the current integration flow position with provided options.
EnricherSpec - Class in org.springframework.integration.dsl
The MessageHandlerSpec implementation for the ContentEnricher.
enrichHeaders(MapBuilder<?, String, Object>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageTransformingHandler for a HeaderEnricher using header values from provided MapBuilder.
enrichHeaders(MapBuilder<?, String, Object>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageTransformingHandler for a HeaderEnricher using header values from provided MapBuilder.
enrichHeaders(Map<String, Object>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Accept a Map of values to be used for the Message header enrichment.
enrichHeaders(Map<String, Object>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Accept a Map of values to be used for the Message header enrichment.
enrichHeaders(Consumer<HeaderEnricherSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageTransformingHandler for a HeaderEnricher as the result of provided Consumer.
enrichHeaders(Consumer<HeaderEnricherSpec>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageTransformingHandler for a HeaderEnricher as the result of provided Consumer.
entityClass(Class<?>) - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
entityClass(Class<?>) - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
equals(Object) - Method in class org.springframework.integration.dsl.support.tuple.Tuple
 
equals(Object) - Method in class org.springframework.integration.dsl.support.tuple.Tuple1
 
equals(Object) - Method in class org.springframework.integration.dsl.support.tuple.Tuple2
 
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.core.MessageProducerSpec
Configure the MessageChannel to which error messages will be sent.
errorChannel(String) - Method in class org.springframework.integration.dsl.core.MessageProducerSpec
Configure the bean name of the MessageChannel to which error messages will be sent.
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.core.MessagingGatewaySpec
An error channel to use.
errorChannel(String) - Method in class org.springframework.integration.dsl.core.MessagingGatewaySpec
An error channel name to use.
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.core.PollerSpec
Specify a MessageChannel to use for sending error message in case of polling failures.
errorChannel(String) - Method in class org.springframework.integration.dsl.core.PollerSpec
Specify a bean name for the MessageChannel to use for sending error message in case of polling failures.
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
 
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
 
errorChannel(String) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
 
errorCode(String) - Method in class org.springframework.integration.dsl.http.HttpControllerEndpointSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.dsl.channel.PublishSubscribeChannelSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.dsl.core.PollerSpec
Specify the ErrorHandler to wrap a taskExecutor to the ErrorHandlingTaskExecutor.
errorHandler(ResponseErrorHandler) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.dsl.jms.JmsListenerContainerSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Specify an ErrorHandler for the AbstractMessageListenerContainer.
errorsKey(String) - Method in class org.springframework.integration.dsl.http.HttpControllerEndpointSpec
 
exceptionListener(ExceptionListener) - Method in class org.springframework.integration.dsl.jms.JmsListenerContainerSpec
 
exchange(FanoutExchange) - Method in class org.springframework.integration.dsl.amqp.AmqpPublishSubscribeMessageChannelSpec
 
exchangeName(String) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
exchangeNameExpression(String) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
exchangeNameExpression(Expression) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
exchangeNameFunction(Function<Message<?>, String>) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
exclusive(boolean) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
exclusive(boolean) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
executor(Executor) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
executor(String, Executor) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
executor(Executor) - Method in class org.springframework.integration.dsl.Channels
 
executor(String, Executor) - Method in class org.springframework.integration.dsl.Channels
 
ExecutorChannelSpec - Class in org.springframework.integration.dsl.channel
 
expectedResponseType(Class<?>) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
expectedResponseType(ParameterizedTypeReference<?>) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
expectedResponseTypeExpression(Expression) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
expectedResponseTypeFunction(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
expectSingleResult(boolean) - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
expectSingleResult(boolean) - Method in class org.springframework.integration.dsl.jpa.JpaRetrievingOutboundGatewaySpec
 
expireGroupsUponCompletion(boolean) - Method in class org.springframework.integration.dsl.AggregatorSpec
 
expireGroupsUponTimeout(boolean) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Expire (completely remove) a group if it is completed due to timeout.
explicitQosEnabled(boolean) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
explicitQosEnabled(boolean) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
 
explicitQosEnabled(boolean) - Method in class org.springframework.integration.dsl.jms.JmsTemplateSpec
 
explicitQosEnabledForReplies(boolean) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
exposedHeaders(String...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec.CrossOriginSpec
 
exposeListenerChannel(boolean) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
exposeListenerSession(boolean) - Method in class org.springframework.integration.dsl.jms.JmsListenerContainerSpec
 
exposeListenerSession(boolean) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
 
externalReceiver - Variable in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
 
externalReceiver - Variable in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
 
extractPayload(boolean) - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
Configure whether normal spring-messaging to AMQP message mapping is enabled.
extractPayload(boolean) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
extractPayload(boolean) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapterSpec
 
extractPayload(boolean) - Method in class org.springframework.integration.dsl.jms.JmsOutboundChannelAdapterSpec
 
extractReplyPayload(boolean) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
extractReplyPayload(boolean) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
extractReplyPayload(boolean) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
extractRequestPayload(boolean) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
extractRequestPayload(boolean) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 

F

failover - Variable in class org.springframework.integration.dsl.channel.LoadBalancingChannelSpec
 
failover(Boolean) - Method in class org.springframework.integration.dsl.channel.LoadBalancingChannelSpec
 
Feed - Class in org.springframework.integration.dsl.feed
The Spring Integration Feed components Factory.
feed(URL, String) - Method in class org.springframework.integration.dsl.MessageSources
Factory for the FeedEntryMessageSourceSpec based on the feedUrl and metadataKey.
FeedEntryMessageSourceSpec - Class in org.springframework.integration.dsl.feed
A MessageSourceSpec for a FeedEntryMessageSource.
feedFetcher(FeedFetcher) - Method in class org.springframework.integration.dsl.feed.FeedEntryMessageSourceSpec
 
file(File) - Method in class org.springframework.integration.dsl.Adapters
 
file(String) - Method in class org.springframework.integration.dsl.Adapters
 
file(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.Adapters
 
file(File) - Method in class org.springframework.integration.dsl.MessageSources
file(File, Comparator<File>) - Method in class org.springframework.integration.dsl.MessageSources
fileDelay(long) - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
 
fileExistsMode(FileExistsMode) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
 
fileGateway(File) - Method in class org.springframework.integration.dsl.Adapters
 
fileGateway(String) - Method in class org.springframework.integration.dsl.Adapters
 
fileGateway(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.Adapters
 
FileInboundChannelAdapterSpec - Class in org.springframework.integration.dsl.file
A MessageSourceSpec for a FileReadingMessageSource.
fileNameExpression(String) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
fileNameExpression(String) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
 
fileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
fileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
 
Files - Class in org.springframework.integration.dsl.file
The Spring Integration File components Factory.
Files() - Constructor for class org.springframework.integration.dsl.file.Files
 
FileSplitterSpec - Class in org.springframework.integration.dsl.file
The MessageHandlerSpec for the FileSplitter.
fileToByteArray() - Static method in class org.springframework.integration.dsl.support.Transformers
 
fileToString() - Static method in class org.springframework.integration.dsl.support.Transformers
 
fileToString(String) - Static method in class org.springframework.integration.dsl.support.Transformers
 
FileTransferringMessageHandlerSpec<F,S extends FileTransferringMessageHandlerSpec<F,S>> - Class in org.springframework.integration.dsl.file
 
FileTransferringMessageHandlerSpec(SessionFactory<F>) - Constructor for class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
FileTransferringMessageHandlerSpec(RemoteFileTemplate<F>) - Constructor for class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
FileTransferringMessageHandlerSpec(RemoteFileTemplate<F>, FileExistsMode) - Constructor for class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
FileWritingMessageHandlerSpec - Class in org.springframework.integration.dsl.file
 
filter(FileListFilter<File>) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
Configure the filter.
filter(FileListFilter<File>, boolean) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
Deprecated.
since 1.1 in favor of the bunch of methods usage.
filter(FileListFilter<F>) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
Configure a FileListFilter to be applied to the remote files before copying them.
filter(FileListFilter<F>) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
filter(String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MessageSelector for the provided SpEL expression.
filter(String, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MessageSelector for the provided SpEL expression.
filter(Object) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the discovered method of the provided service.
filter(Object, String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the method of the provided service.
filter(Object, String, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the method of the provided service.
filter(GenericSelector<P>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the provided GenericSelector.
filter(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the MessageProcessor from the provided MessageProcessorSpec.
filter(MessageProcessorSpec<?>, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the MessageProcessor from the provided MessageProcessorSpec.
filter(Class<P>, GenericSelector<P>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the provided GenericSelector.
filter(GenericSelector<P>, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the provided GenericSelector.
filter(Class<P>, GenericSelector<P>, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a MessageFilter with MethodInvokingSelector for the provided GenericSelector.
FilterEndpointSpec - Class in org.springframework.integration.dsl
A ConsumerEndpointSpec implementation for the MessageFilter.
firstResult(int) - Method in class org.springframework.integration.dsl.jpa.JpaRetrievingOutboundGatewaySpec
 
firstResultExpression(String) - Method in class org.springframework.integration.dsl.jpa.JpaRetrievingOutboundGatewaySpec
 
firstResultExpression(Expression) - Method in class org.springframework.integration.dsl.jpa.JpaRetrievingOutboundGatewaySpec
 
fixedDelay(long, TimeUnit, long) - Method in class org.springframework.integration.dsl.core.PollerFactory
 
fixedDelay(long, TimeUnit) - Method in class org.springframework.integration.dsl.core.PollerFactory
 
fixedDelay(long, long) - Method in class org.springframework.integration.dsl.core.PollerFactory
 
fixedDelay(long) - Method in class org.springframework.integration.dsl.core.PollerFactory
 
fixedDelay(long) - Static method in class org.springframework.integration.dsl.core.Pollers
 
fixedDelay(long, TimeUnit) - Static method in class org.springframework.integration.dsl.core.Pollers
 
fixedDelay(long, long) - Static method in class org.springframework.integration.dsl.core.Pollers
 
fixedDelay(long, TimeUnit, long) - Static method in class org.springframework.integration.dsl.core.Pollers
 
fixedRate(long) - Method in class org.springframework.integration.dsl.core.PollerFactory
 
fixedRate(long, TimeUnit) - Method in class org.springframework.integration.dsl.core.PollerFactory
 
fixedRate(long, long) - Method in class org.springframework.integration.dsl.core.PollerFactory
 
fixedRate(long, TimeUnit, long) - Method in class org.springframework.integration.dsl.core.PollerFactory
 
fixedRate(long) - Static method in class org.springframework.integration.dsl.core.Pollers
 
fixedRate(long, TimeUnit) - Static method in class org.springframework.integration.dsl.core.Pollers
 
fixedRate(long, long) - Static method in class org.springframework.integration.dsl.core.Pollers
 
fixedRate(long, TimeUnit, long) - Static method in class org.springframework.integration.dsl.core.Pollers
 
fixedSubscriberChannel() - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate an FixedSubscriberChannel instance at the current IntegrationFlow chain position.
fixedSubscriberChannel(String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate an FixedSubscriberChannel instance at the current IntegrationFlow chain position.
FixedSubscriberChannelPrototype - Class in org.springframework.integration.dsl.support
An "artificial" MessageChannel implementation which will be unwrapped to the FixedSubscriberChannel on the bean registration phase.
FixedSubscriberChannelPrototype() - Constructor for class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
FixedSubscriberChannelPrototype(String) - Constructor for class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
flush(boolean) - Method in class org.springframework.integration.dsl.jpa.JpaUpdatingOutboundEndpointSpec
 
flushAfterDelete(boolean) - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
flushAfterDelete(boolean) - Method in class org.springframework.integration.dsl.jpa.JpaRetrievingOutboundGatewaySpec
 
flushInterval(long) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
Set the frequency to flush buffers when FileExistsMode.APPEND_NO_FLUSH is being used.
flushPredicate(FileWritingMessageHandler.MessageFlushPredicate) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
Specify a FileWritingMessageHandler.MessageFlushPredicate for flush task when the FileExistsMode.APPEND_NO_FLUSH is in use.
flushSize(int) - Method in class org.springframework.integration.dsl.jpa.JpaUpdatingOutboundEndpointSpec
 
forceReleaseAdvice(Advice...) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure a list of Advice objects to be applied to the forceComplete() operation.
from(String) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageChannel) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(String, boolean) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageSourceSpec<?, ? extends MessageSource<?>>, Consumer<SourcePollingChannelAdapterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageSource<?>, Consumer<SourcePollingChannelAdapterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(IntegrationFlows.MessageSourcesFunction, Consumer<SourcePollingChannelAdapterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(IntegrationFlows.ChannelsFunction) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageProducerSupport) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageSource<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(IntegrationFlows.MessageSourcesFunction) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessagingGatewaySupport) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageChannelSpec<?, ?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(IntegrationFlows.MessageProducersFunction) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageProducerSpec<?, ?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessageSourceSpec<?, ? extends MessageSource<?>>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(MessagingGatewaySpec<?, ?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(IntegrationFlows.MessagingGatewaysFunction) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(Object, String) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(Object, String, Consumer<SourcePollingChannelAdapterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
from(String) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageChannel name to the new IntegrationFlowBuilder chain.
from(String, boolean) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageChannel name to the new IntegrationFlowBuilder chain.
from(IntegrationFlows.ChannelsFunction) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageChannel object to the IntegrationFlowBuilder chain using the fluent API from Channels factory.
from(MessageChannelSpec<?, ?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageChannel object to the IntegrationFlowBuilder chain using the fluent API from MessageChannelSpec.
from(MessageChannel) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the provided MessageChannel object to the IntegrationFlowBuilder chain.
from(IntegrationFlows.MessageSourcesFunction) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageSource object to the IntegrationFlowBuilder chain using the fluent API from MessageSources factory.
from(IntegrationFlows.MessageSourcesFunction, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageSource object to the IntegrationFlowBuilder chain using the fluent API from the MessageSources factory.
from(MessageSourceSpec<?, ? extends MessageSource<?>>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageSource object to the IntegrationFlowBuilder chain using the fluent API from the provided MessageSourceSpec.
from(MessageSourceSpec<?, ? extends MessageSource<?>>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageSource object to the IntegrationFlowBuilder chain using the fluent API from the provided MessageSourceSpec.
from(Object, String) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the provided MethodInvokingMessageSource for the method of the provided service.
from(Object, String, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the provided MethodInvokingMessageSource for the method of the provided service.
from(MessageSource<?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the provided MessageSource object to the IntegrationFlowBuilder chain.
from(MessageSource<?>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the provided MessageSource object to the IntegrationFlowBuilder chain.
from(IntegrationFlows.MessageProducersFunction) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageProducerSupport object to the IntegrationFlowBuilder chain using the fluent API from the MessageProducers factory.
from(MessageProducerSpec<?, ?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessageProducerSupport object to the IntegrationFlowBuilder chain using the fluent API from the MessageProducerSpec.
from(MessageProducerSupport) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the provided MessageProducerSupport object to the IntegrationFlowBuilder chain.
from(IntegrationFlows.MessagingGatewaysFunction) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessagingGatewaySupport object to the IntegrationFlowBuilder chain using the fluent API from the MessagingGateways factory.
from(MessagingGatewaySpec<?, ?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the MessagingGatewaySupport object to the IntegrationFlowBuilder chain using the fluent API from the MessagingGatewaySpec.
from(MessagingGatewaySupport) - Static method in class org.springframework.integration.dsl.IntegrationFlows
Populate the provided MessagingGatewaySupport object to the IntegrationFlowBuilder chain.
from(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
fromExpression(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
fromFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
fromJson() - Static method in class org.springframework.integration.dsl.support.Transformers
 
fromJson(Class<?>) - Static method in class org.springframework.integration.dsl.support.Transformers
 
fromJson(JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.support.Transformers
 
fromJson(Class<?>, JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.support.Transformers
 
fromMail() - Static method in class org.springframework.integration.dsl.support.Transformers
 
fromMail(String) - Static method in class org.springframework.integration.dsl.support.Transformers
 
fromMap(Class<?>) - Static method in class org.springframework.integration.dsl.support.Transformers
 
fromMap(String) - Static method in class org.springframework.integration.dsl.support.Transformers
 
ftp(SessionFactory<FTPFile>) - Method in class org.springframework.integration.dsl.Adapters
 
ftp(SessionFactory<FTPFile>, FileExistsMode) - Method in class org.springframework.integration.dsl.Adapters
 
ftp(RemoteFileTemplate<FTPFile>) - Method in class org.springframework.integration.dsl.Adapters
 
ftp(RemoteFileTemplate<FTPFile>, FileExistsMode) - Method in class org.springframework.integration.dsl.Adapters
 
Ftp - Class in org.springframework.integration.dsl.ftp
The factory for Spring Integration FTP components.
ftp(SessionFactory<FTPFile>) - Method in class org.springframework.integration.dsl.MessageSources
ftp(SessionFactory<FTPFile>, Comparator<File>) - Method in class org.springframework.integration.dsl.MessageSources
ftpGateway(SessionFactory<FTPFile>, AbstractRemoteFileOutboundGateway.Command, String) - Method in class org.springframework.integration.dsl.Adapters
 
ftpGateway(SessionFactory<FTPFile>, String, String) - Method in class org.springframework.integration.dsl.Adapters
 
FtpInboundChannelAdapterSpec - Class in org.springframework.integration.dsl.ftp
A RemoteFileInboundChannelAdapterSpec for a FtpInboundFileSynchronizingMessageSource.
FtpMessageHandlerSpec - Class in org.springframework.integration.dsl.ftp
 
FtpOutboundGatewaySpec - Class in org.springframework.integration.dsl.ftp
 
ftps(SessionFactory<ChannelSftp.LsEntry>) - Method in class org.springframework.integration.dsl.Adapters
Deprecated.
Function<T,R> - Interface in org.springframework.integration.dsl.support
Implementations of this class perform work on the given parameter and return a result of an optionally different type.
FunctionExpression<S> - Class in org.springframework.integration.dsl.support
An Expression that simply invokes Function.apply(Object) on its provided Function.
FunctionExpression(Function<S, ?>) - Constructor for class org.springframework.integration.dsl.support.FunctionExpression
 

G

gateway(String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided requestChannel to send a request with default options.
gateway(String, Consumer<GatewayEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided requestChannel to send a request with options from GatewayEndpointSpec.
gateway(MessageChannel) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided requestChannel to send a request with default options.
gateway(MessageChannel, Consumer<GatewayEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided requestChannel to send a request with options from GatewayEndpointSpec.
gateway(IntegrationFlow) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided subflow.
gateway(IntegrationFlow, Consumer<GatewayEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided subflow with options from GatewayEndpointSpec.
GatewayEndpointSpec - Class in org.springframework.integration.dsl
A ConsumerEndpointSpec implementation for a mid-flow GatewayMessageHandler.
gatherChannel(MessageChannel) - Method in class org.springframework.integration.dsl.ScatterGatherSpec
Specify a MessageChannel (optional) which is used internally in the ScatterGatherHandler for gathering (aggregate) results for scattered requests.
gatherTimeout(long) - Method in class org.springframework.integration.dsl.ScatterGatherSpec
Specify a timeout (in milliseconds) for the PollableChannel.receive(long) operation to wait for gathering results to output.
GenericEndpointSpec<H extends org.springframework.messaging.MessageHandler> - Class in org.springframework.integration.dsl
A ConsumerEndpointSpec for a MessageHandler implementations.
GenericHandler<P> - Interface in org.springframework.integration.dsl.support
A functional interface to specify MessageHandler logic with Java 8 Lambda expression:
 .<Integer>handle((p, h) -> p / 2)
 
get() - Method in class org.springframework.integration.dsl.core.IntegrationComponentSpec
 
get() - Method in class org.springframework.integration.dsl.IntegrationFlowBuilder
 
get() - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
 
get() - Method in class org.springframework.integration.dsl.support.MapBuilder
 
get() - Method in class org.springframework.integration.dsl.support.PropertiesBuilder
 
get(int) - Method in class org.springframework.integration.dsl.support.tuple.Tuple
 
get(int) - Method in class org.springframework.integration.dsl.support.tuple.Tuple1
 
get(int) - Method in class org.springframework.integration.dsl.support.tuple.Tuple2
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.AbstractRouterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.channel.MessageChannelSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.channel.WireTapSpec
 
getComponentsToRegister() - Method in interface org.springframework.integration.dsl.core.ComponentsRegistration
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.core.EndpointSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.core.PollerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.PublishSubscribeSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.RouterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.scripting.ScriptMessageSourceSpec
 
getComponentType() - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
getComponentType() - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.dsl.support.MessageProcessorMessageSource
 
getExpressionString() - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getId() - Method in class org.springframework.integration.dsl.context.IntegrationFlowRegistration
 
getId() - Method in class org.springframework.integration.dsl.core.IntegrationComponentSpec
 
getInputChannel() - Method in class org.springframework.integration.dsl.context.IntegrationFlowRegistration
 
getIntegrationComponents() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
getIntegrationFlow() - Method in class org.springframework.integration.dsl.context.IntegrationFlowRegistration
 
getMessagingTemplate() - Method in class org.springframework.integration.dsl.context.IntegrationFlowRegistration
Obtain a MessagingTemplate with its default destination set to the input channel of the IntegrationFlow.
getName() - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
getName() - Method in class org.springframework.integration.dsl.support.MessageChannelReference
 
getObject() - Method in class org.springframework.integration.dsl.core.IntegrationComponentSpec
 
getObjectType() - Method in class org.springframework.integration.dsl.core.IntegrationComponentSpec
 
getPhase() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
getPhase() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
getRegistrationById(String) - Method in class org.springframework.integration.dsl.context.IntegrationFlowContext
Obtain an IntegrationFlowRegistration for the IntegrationFlow associated with the provided flowId.
getT1() - Method in class org.springframework.integration.dsl.support.tuple.Tuple1
Type-safe way to get the first object of this Tuple.
getT2() - Method in class org.springframework.integration.dsl.support.tuple.Tuple2
Type-safe way to get the second object of this Tuple.
getValue() - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValue(Object) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValue(Class<T>) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValue(Object, Class<T>) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValue(EvaluationContext) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValue(EvaluationContext, Class<T>) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValue(EvaluationContext, Object, Class<T>) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValueType() - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValueType(Object) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValueType(EvaluationContext) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValueType(EvaluationContext, Object) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValueTypeDescriptor() - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValueTypeDescriptor(Object) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
groupTimeout(long) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with a group timeout expression that evaluates to this constant value.
groupTimeout(Function<MessageGroup, Long>) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with a function that will be invoked to resolve the group timeout, based on the message group.
groupTimeoutExpression(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 

H

handle(MessageHandlerSpec<?, H>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the selected protocol specific MessageHandler implementation from Namespace Factory:
 .handle(Amqp.outboundAdapter(this.amqpTemplate).routingKeyExpression("headers.routingKey"))
 
handle(MessageHandler) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the provided MessageHandler implementation.
handle(String, String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the method for provided bean at runtime.
handle(String, String, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the method for provided bean at runtime.
handle(Object) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the discovered method for provided service at runtime.
handle(Object, String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the method for provided bean at runtime.
handle(Object, String, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the method for provided bean at runtime.
handle(GenericHandler<P>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the provided GenericHandler at runtime.
handle(GenericHandler<P>, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the provided GenericHandler at runtime.
handle(Class<P>, GenericHandler<P>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the provided GenericHandler at runtime.
handle(Class<P>, GenericHandler<P>, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MethodInvokingMessageProcessor to invoke the provided GenericHandler at runtime.
handle(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MessageProcessor from the provided MessageProcessorSpec.
handle(MessageProcessorSpec<?>, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the MessageProcessor from the provided MessageProcessorSpec.
handle(MessageHandlerSpec<?, H>, Consumer<GenericEndpointSpec<H>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the selected protocol specific MessageHandler implementation from Namespace Factory: In addition accept options for the integration endpoint using GenericEndpointSpec.
handle(H, Consumer<GenericEndpointSpec<H>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the provided MessageHandler implementation.
handle(P, Map<String, Object>) - Method in interface org.springframework.integration.dsl.support.GenericHandler
 
handler - Variable in class org.springframework.integration.dsl.core.EndpointSpec
 
handleWithAdapter(Function<Adapters, MessageHandlerSpec<?, H>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the selected protocol specific MessageHandler implementation from Adapters factory.
handleWithAdapter(Function<Adapters, MessageHandlerSpec<?, H>>, Consumer<GenericEndpointSpec<H>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler for the selected protocol specific MessageHandler implementation from Adapters factory.
hashCode() - Method in class org.springframework.integration.dsl.support.tuple.Tuple
 
hashCode() - Method in class org.springframework.integration.dsl.support.tuple.Tuple1
 
hashCode() - Method in class org.springframework.integration.dsl.support.tuple.Tuple2
 
header(String, V) - Method in class org.springframework.integration.dsl.EnricherSpec
Set a header with the value if it is not already present.
header(String, V, Boolean) - Method in class org.springframework.integration.dsl.EnricherSpec
 
header(String, HeaderValueMessageProcessor<V>) - Method in class org.springframework.integration.dsl.EnricherSpec
Set a header value using an explicit HeaderValueMessageProcessor.
header(String, V) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification.
header(String, V, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification.
header(String, HeaderValueMessageProcessor<V>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification where the value is obtained by calling the HeaderValueMessageProcessor.
headerChannelsToString() - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications to automatically convert header channels (reply, error channels) to Strings and store them in a header channel registry.
HeaderEnricherSpec - Class in org.springframework.integration.dsl
An IntegrationComponentSpec for a HeaderEnricher.
headerExpression(String, String) - Method in class org.springframework.integration.dsl.EnricherSpec
Set a header with the expression evaluation if the header is not already present.
headerExpression(String, String, Boolean) - Method in class org.springframework.integration.dsl.EnricherSpec
 
headerExpression(String, String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification where the value is a String representation of a SpEL Expression.
headerExpression(String, String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification where the value is a String representation of a SpEL Expression.
headerExpression(String, Expression) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
headerExpression(String, String) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
headerExpressions(MapBuilder<?, String, String>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications from the MapBuilder; the Map values must be String representations of SpEL expressions that will be evaluated at run time when the message headers are enriched.
headerExpressions(MapBuilder<?, String, String>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications from the MapBuilder; the Map values must be String representations of SpEL expressions that will be evaluated at run time when the message headers are enriched.
headerExpressions(Consumer<StringStringMapBuilder>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications via the consumer callback, which receives a StringStringMapBuilder; the Map values must be String representations of SpEL expressions that will be evaluated at run time when the message headers are enriched.
headerExpressions(Consumer<StringStringMapBuilder>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications via the consumer callback, which receives a StringStringMapBuilder; the Map values must be String representations of SpEL expressions that will be evaluated at run time when the message headers are enriched.
headerExpressions(Map<String, String>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications; the Map values must be String representations of SpEL expressions that will be evaluated at run time when the message headers are enriched.
headerExpressions(Map<String, String>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications; the Map values must be String representations of SpEL expressions that will be evaluated at run time when the message headers are enriched.
headerExpressions(Map<String, Expression>) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
headerFilter(String...) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Provide the HeaderFilter to the current StandardIntegrationFlow.
headerFilter(String, boolean) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Provide the HeaderFilter to the current StandardIntegrationFlow.
headerFilter(HeaderFilter, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the provided MessageTransformingHandler for the provided HeaderFilter.
headerFunction(String, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.EnricherSpec
Set a header with the function return value if the header is not already present.
headerFunction(String, Function<Message<P>, Object>, Boolean) - Method in class org.springframework.integration.dsl.EnricherSpec
 
headerFunction(String, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification where the value is obtained by invoking the Function callback.
headerFunction(String, Function<Message<P>, Object>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a single header specification where the value is obtained by invoking the Function callback.
headerFunction(String, Function<HttpEntity<?>, ?>) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseInboundChannelAdapterSpec
Configure the adapter's AmqpHeaderMapper; defaults to DefaultAmqpHeaderMapper.
headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseInboundGatewaySpec
Configure the gateway's AmqpHeaderMapper; defaults to DefaultAmqpHeaderMapper.
headerMapper - Variable in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
headerMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
headerMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
headerMapper(JmsHeaderMapper) - Method in class org.springframework.integration.dsl.jms.JmsInboundChannelAdapterSpec
Configure a JmsHeaderMapper to map from JMS headers and properties to Spring Integration headers.
headerMapper(JmsHeaderMapper) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapterSpec
 
headerMapper(JmsHeaderMapper) - Method in class org.springframework.integration.dsl.jms.JmsOutboundChannelAdapterSpec
 
headerMapper(JmsHeaderMapper) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
headerMapper(HeaderMapper<MimeMessage>) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
Set the header mapper; if a header mapper is not provided, the message payload is a MimeMessage, when provided, the headers are mapped and the payload is the MimeMessage content.
headerMapper(HeaderMapper<MimeMessage>) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
Set the header mapper; if a header mapper is not provided, the message payload is a MimeMessage, when provided, the headers are mapped and the payload is the MimeMessage content.
headers(MapBuilder<?, String, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications from the MapBuilder; if a map value is an Expression, it will be evaluated at run time when the message headers are enriched.
headers(MapBuilder<?, String, Object>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications from the MapBuilder; if a map value is an Expression, it will be evaluated at run time when the message headers are enriched.
headers(Map<String, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications from the Map; if a map value is an Expression, it will be evaluated at run time when the message headers are enriched.
headers(Map<String, Object>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add header specifications from the Map; if a map value is an Expression, it will be evaluated at run time when the message headers are enriched.
headers(String...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec.RequestMappingSpec
 
headers() - Static method in class org.springframework.integration.dsl.mail.Mail
 
http(URI) - Method in class org.springframework.integration.dsl.Adapters
 
http(String) - Method in class org.springframework.integration.dsl.Adapters
 
http(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.Adapters
 
http(Function<Message<P>, ?>, RestTemplate) - Method in class org.springframework.integration.dsl.Adapters
 
http(Expression) - Method in class org.springframework.integration.dsl.Adapters
 
http(URI, RestTemplate) - Method in class org.springframework.integration.dsl.Adapters
 
http(String, RestTemplate) - Method in class org.springframework.integration.dsl.Adapters
 
http(Expression, RestTemplate) - Method in class org.springframework.integration.dsl.Adapters
 
Http - Class in org.springframework.integration.dsl.http
The HTTP components Factory.
http(String, String...) - Method in class org.springframework.integration.dsl.MessageProducers
 
http(Expression, String...) - Method in class org.springframework.integration.dsl.MessageProducers
 
http(String, String...) - Method in class org.springframework.integration.dsl.MessagingGateways
 
http(Expression, String...) - Method in class org.springframework.integration.dsl.MessagingGateways
 
httpChannelAdapter(String...) - Method in class org.springframework.integration.dsl.MessageProducers
 
HttpControllerEndpointSpec - Class in org.springframework.integration.dsl.http
The BaseHttpInboundEndpointSpec implementation for the HttpRequestHandlingController.
httpGateway(URI) - Method in class org.springframework.integration.dsl.Adapters
 
httpGateway(String) - Method in class org.springframework.integration.dsl.Adapters
 
httpGateway(Expression) - Method in class org.springframework.integration.dsl.Adapters
 
httpGateway(URI, RestTemplate) - Method in class org.springframework.integration.dsl.Adapters
 
httpGateway(String, RestTemplate) - Method in class org.springframework.integration.dsl.Adapters
 
httpGateway(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.Adapters
 
httpGateway(Function<Message<P>, ?>, RestTemplate) - Method in class org.springframework.integration.dsl.Adapters
 
httpGateway(Expression, RestTemplate) - Method in class org.springframework.integration.dsl.Adapters
 
httpGateway(String...) - Method in class org.springframework.integration.dsl.MessagingGateways
 
HttpMessageHandlerSpec - Class in org.springframework.integration.dsl.http
The MessageHandlerSpec implementation for the HttpRequestExecutingMessageHandler.
httpMethod(HttpMethod) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
httpMethodExpression(Expression) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
httpMethodFunction(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
HttpRequestHandlerEndpointSpec - Class in org.springframework.integration.dsl.http
The BaseHttpInboundEndpointSpec implementation for the HttpRequestHandlingMessagingGateway.

I

id(String) - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
 
id(String) - Method in class org.springframework.integration.dsl.channel.MessageChannelSpec
 
id(String) - Method in class org.springframework.integration.dsl.channel.QueueChannelSpec.MessageStoreSpec
 
id(String) - Method in class org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
 
id(String) - Method in class org.springframework.integration.dsl.core.EndpointSpec
 
id(String) - Method in class org.springframework.integration.dsl.core.IntegrationComponentSpec
Configure the component identifier.
id(String) - Method in class org.springframework.integration.dsl.core.MessageProducerSpec
Configure the component identifier.
id(String) - Method in class org.springframework.integration.dsl.core.MessagingGatewaySpec
 
id(String) - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
 
id(String) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
 
id(String) - Method in class org.springframework.integration.dsl.PublishSubscribeSpec
 
idExpression(String) - Method in class org.springframework.integration.dsl.jpa.JpaRetrievingOutboundGatewaySpec
 
idExpression(Expression) - Method in class org.springframework.integration.dsl.jpa.JpaRetrievingOutboundGatewaySpec
 
idleConsumerLimit(int) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
The max for concurrent consumers number to use.
idleConsumerLimit(Integer) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
 
idleEventInterval(Long) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the idle event interval; when set, an event is emitted if a poll returns no records and this interval has elapsed since a record was returned.
idleReplyContainerTimeout(long) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
 
idleTaskExecutionLimit(int) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
The the limit for idle task.
idleTaskExecutionLimit(int) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
Only applies if the JmsMessageChannelSpec.containerType(Class) is a DefaultMessageListenerContainer.
idleTaskExecutionLimit(Integer) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
 
ignoreExpressionFailures(boolean) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
 
ignoreFailures(boolean) - Method in class org.springframework.integration.dsl.channel.PublishSubscribeChannelSpec
 
ignoreHidden() - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
Deprecated.
ignoreHidden(boolean) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
/** Configure an IgnoreHiddenFileListFilter if ignoreHidden == true.
ignoreSendFailures(boolean) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
 
imap(String) - Method in class org.springframework.integration.dsl.MessageProducers
 
imap() - Method in class org.springframework.integration.dsl.MessageSources
imap(String) - Method in class org.springframework.integration.dsl.MessageSources
imapIdleAdapter() - Static method in class org.springframework.integration.dsl.mail.Mail
 
imapIdleAdapter(String) - Static method in class org.springframework.integration.dsl.mail.Mail
 
imapIdleAdapter(ImapMailReceiver) - Static method in class org.springframework.integration.dsl.mail.Mail
An ImapIdleChannelAdapterSpec factory based on the provided ImapMailReceiver.
ImapIdleChannelAdapterSpec - Class in org.springframework.integration.dsl.mail
A MessageProducerSpec for a ImapIdleChannelAdapter.
imapInboundAdapter() - Static method in class org.springframework.integration.dsl.mail.Mail
 
imapInboundAdapter(ImapMailReceiver) - Static method in class org.springframework.integration.dsl.mail.Mail
An ImapMailInboundChannelAdapterSpec factory based on the provided ImapMailReceiver.
imapInboundAdapter(String) - Static method in class org.springframework.integration.dsl.mail.Mail
 
ImapMailInboundChannelAdapterSpec - Class in org.springframework.integration.dsl.mail
inboundAdapter(ConnectionFactory, String...) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpInboundChannelAdapterSpec.
inboundAdapter(ConnectionFactory, Queue...) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpInboundChannelAdapterSpec.
inboundAdapter(SimpleMessageListenerContainer) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpInboundChannelAdapterSpec.
inboundAdapter(URL, String) - Static method in class org.springframework.integration.dsl.feed.Feed
 
inboundAdapter(File) - Static method in class org.springframework.integration.dsl.file.Files
 
inboundAdapter(File, Comparator<File>) - Static method in class org.springframework.integration.dsl.file.Files
 
inboundAdapter(SessionFactory<FTPFile>) - Static method in class org.springframework.integration.dsl.ftp.Ftp
 
inboundAdapter(SessionFactory<FTPFile>, Comparator<File>) - Static method in class org.springframework.integration.dsl.ftp.Ftp
 
inboundAdapter(JmsTemplate) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsInboundChannelAdapterSpec.
inboundAdapter(ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsInboundChannelAdapterSpec.
inboundAdapter(EntityManagerFactory) - Static method in class org.springframework.integration.dsl.jpa.Jpa
 
inboundAdapter(EntityManager) - Static method in class org.springframework.integration.dsl.jpa.Jpa
 
inboundAdapter(JpaOperations) - Static method in class org.springframework.integration.dsl.jpa.Jpa
 
inboundAdapter(SimpleMessageListenerContainer) - Method in class org.springframework.integration.dsl.MessageProducers
Deprecated.
since 1.1.1 in favor of MessageProducers.amqp(SimpleMessageListenerContainer) as factory method with an inconvenient name.
inboundAdapter(SessionFactory<ChannelSftp.LsEntry>) - Static method in class org.springframework.integration.dsl.sftp.Sftp
 
inboundAdapter(SessionFactory<ChannelSftp.LsEntry>, Comparator<File>) - Static method in class org.springframework.integration.dsl.sftp.Sftp
 
inboundChannelAdapter(String...) - Static method in class org.springframework.integration.dsl.http.Http
 
inboundControllerAdapter(String, String...) - Static method in class org.springframework.integration.dsl.http.Http
 
inboundControllerAdapter(Expression, String...) - Static method in class org.springframework.integration.dsl.http.Http
 
inboundControllerGateway(String, String...) - Static method in class org.springframework.integration.dsl.http.Http
 
inboundControllerGateway(Expression, String...) - Static method in class org.springframework.integration.dsl.http.Http
 
inboundGateway(ConnectionFactory, String...) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpInboundGatewaySpec.
inboundGateway(ConnectionFactory, AmqpTemplate, String...) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpInboundGatewaySpec.
inboundGateway(ConnectionFactory, Queue...) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpInboundGatewaySpec.
inboundGateway(ConnectionFactory, AmqpTemplate, Queue...) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpInboundGatewaySpec.
inboundGateway(SimpleMessageListenerContainer) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpBaseInboundGatewaySpec with provided SimpleMessageListenerContainer.
inboundGateway(SimpleMessageListenerContainer, AmqpTemplate) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpBaseInboundGatewaySpec with provided SimpleMessageListenerContainer.
inboundGateway(String...) - Static method in class org.springframework.integration.dsl.http.Http
 
inboundGateway(AbstractMessageListenerContainer) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsOutboundGatewaySpec.
inboundGateway(ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsOutboundGatewaySpec.
inboundGateway(ConnectionFactory, Class<C>) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsOutboundGatewaySpec.
inboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
Configure the inbound header mapper to use when AmqpPollableMessageChannelSpec.extractPayload(boolean) is true.
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.dsl.config.DslIntegrationConfigurationInitializer
 
integrationComponents - Variable in class org.springframework.integration.dsl.IntegrationFlowDefinition
 
IntegrationComponentSpec<S extends IntegrationComponentSpec<S,T>,T> - Class in org.springframework.integration.dsl.core
The common Builder abstraction.
IntegrationComponentSpec() - Constructor for class org.springframework.integration.dsl.core.IntegrationComponentSpec
 
IntegrationFlow - Interface in org.springframework.integration.dsl
The main Integration DSL abstraction.
IntegrationFlowAdapter - Class in org.springframework.integration.dsl
The base Adapter class for the IntegrationFlow abstraction.
IntegrationFlowAdapter() - Constructor for class org.springframework.integration.dsl.IntegrationFlowAdapter
 
IntegrationFlowBeanPostProcessor - Class in org.springframework.integration.dsl.config
A BeanPostProcessor to parse IntegrationFlow beans and register their components as beans in the provided BeanFactory, if necessary.
IntegrationFlowBeanPostProcessor() - Constructor for class org.springframework.integration.dsl.config.IntegrationFlowBeanPostProcessor
 
IntegrationFlowBuilder - Class in org.springframework.integration.dsl
 
IntegrationFlowContext - Class in org.springframework.integration.dsl.context
A public API for dynamic (manual) registration of IntegrationFlow, not via standard bean registration phase.
IntegrationFlowContext.IntegrationFlowRegistrationBuilder - Class in org.springframework.integration.dsl.context
A Builder pattern implementation for the options to register IntegrationFlow in the application context.
IntegrationFlowDefinition<B extends IntegrationFlowDefinition<B>> - Class in org.springframework.integration.dsl
The Builder pattern implementation for the EIP-method chain.
IntegrationFlowRegistration - Class in org.springframework.integration.dsl.context
Instances of this classes are returned as a result of IntegrationFlowContext.registration(IntegrationFlow) invocation and provide an API for some useful IntegrationFlow options and its lifecycle.
IntegrationFlows - Class in org.springframework.integration.dsl
The central factory for fluent IntegrationFlowBuilder API.
IntegrationFlows.ChannelsFunction - Interface in org.springframework.integration.dsl
The Channels-specific Function.
IntegrationFlows.MessageProducersFunction - Interface in org.springframework.integration.dsl
IntegrationFlows.MessageSourcesFunction - Interface in org.springframework.integration.dsl
The MessageSources-specific Function.
IntegrationFlows.MessagingGatewaysFunction - Interface in org.springframework.integration.dsl
interceptor(ChannelInterceptor...) - Method in class org.springframework.integration.dsl.channel.MessageChannelSpec
 
isAutoStartup() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
isAutoStartup() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
isolation(Isolation) - Method in class org.springframework.integration.dsl.transaction.TransactionInterceptorBuilder
 
isRegisterComponents() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
isRunning() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
isRunning() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
isSingleton() - Method in class org.springframework.integration.dsl.core.IntegrationComponentSpec
 
isWritable(EvaluationContext) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
isWritable(EvaluationContext, Object) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
isWritable(Object) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
iterator() - Method in class org.springframework.integration.dsl.support.tuple.Tuple
 

J

javaMailAuthenticator(Authenticator) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
 
javaMailAuthenticator(Authenticator) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
The Java Mail Authenticator.
javaMailProperties(Properties) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
 
javaMailProperties(Consumer<PropertiesBuilder>) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
Configure the javaMailProperties by invoking a Consumer callback which is invoked with a PropertiesBuilder.
javaMailProperties(Properties) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
The Java Mail properties.
javaMailProperties(Consumer<PropertiesBuilder>) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
Configure the javaMailProperties by invoking a Consumer callback which is invoked with a PropertiesBuilder.
javaMailProperties(Properties) - Method in class org.springframework.integration.dsl.mail.MailSendingMessageHandlerSpec
 
javaMailProperties(Consumer<PropertiesBuilder>) - Method in class org.springframework.integration.dsl.mail.MailSendingMessageHandlerSpec
 
jms(ConnectionFactory) - Method in class org.springframework.integration.dsl.Adapters
 
jms(JmsTemplate) - Method in class org.springframework.integration.dsl.Adapters
 
jms(ConnectionFactory) - Method in class org.springframework.integration.dsl.Channels
 
jms(String, ConnectionFactory) - Method in class org.springframework.integration.dsl.Channels
 
Jms - Class in org.springframework.integration.dsl.jms
Factory class for JMS components.
jms(AbstractMessageListenerContainer) - Method in class org.springframework.integration.dsl.MessageProducers
 
jms(ConnectionFactory) - Method in class org.springframework.integration.dsl.MessageProducers
 
jms(ConnectionFactory, Class<C>) - Method in class org.springframework.integration.dsl.MessageProducers
 
jms(JmsTemplate) - Method in class org.springframework.integration.dsl.MessageSources
jms(ConnectionFactory) - Method in class org.springframework.integration.dsl.MessageSources
jms(ConnectionFactory) - Method in class org.springframework.integration.dsl.MessagingGateways
 
jms(ConnectionFactory, Class<C>) - Method in class org.springframework.integration.dsl.MessagingGateways
 
jms(AbstractMessageListenerContainer) - Method in class org.springframework.integration.dsl.MessagingGateways
 
jmsChannelFactoryBean - Variable in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
 
JmsDefaultListenerContainerSpec - Class in org.springframework.integration.dsl.jms
A DefaultMessageListenerContainer specific JmsListenerContainerSpec extension.
JmsDestinationAccessorSpec<S extends JmsDestinationAccessorSpec<S,A>,A extends org.springframework.jms.support.destination.JmsDestinationAccessor> - Class in org.springframework.integration.dsl.jms
A base IntegrationComponentSpec for JmsDestinationAccessors.
JmsDestinationAccessorSpec(A) - Constructor for class org.springframework.integration.dsl.jms.JmsDestinationAccessorSpec
 
jmsGateway(ConnectionFactory) - Method in class org.springframework.integration.dsl.Adapters
 
JmsInboundChannelAdapterSpec<S extends JmsInboundChannelAdapterSpec<S>> - Class in org.springframework.integration.dsl.jms
A MessageSourceSpec for a JmsDestinationPollingSource.
JmsInboundChannelAdapterSpec.JmsInboundChannelSpecTemplateAware - Class in org.springframework.integration.dsl.jms
A JmsTemplate-based JmsInboundChannelAdapterSpec extension.
JmsInboundGateway - Class in org.springframework.integration.dsl.jms
 
JmsInboundGateway(AbstractMessageListenerContainer, ChannelPublishingJmsMessageListener) - Constructor for class org.springframework.integration.dsl.jms.JmsInboundGateway
 
JmsInboundGatewaySpec<S extends JmsInboundGatewaySpec<S>> - Class in org.springframework.integration.dsl.jms
JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec<S extends JmsListenerContainerSpec<S,C>,C extends org.springframework.jms.listener.AbstractMessageListenerContainer> - Class in org.springframework.integration.dsl.jms
An AbstractMessageListenerContainer-based JmsInboundGatewaySpec extension.
JmsListenerContainerSpec<S extends JmsListenerContainerSpec<S,C>,C extends org.springframework.jms.listener.AbstractMessageListenerContainer> - Class in org.springframework.integration.dsl.jms
JmsMessageChannelSpec<S extends JmsMessageChannelSpec<S>> - Class in org.springframework.integration.dsl.jms
A JmsMessageChannelSpec for subscribable AbstractJmsChannels.
jmsMessageConverter(MessageConverter) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
jmsMessageConverter(MessageConverter) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapterSpec
 
jmsMessageConverter(MessageConverter) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
jmsMessageConverter(MessageConverter) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
Configure the MessageConverter used for both sending and receiving.
jmsMessageConverter(MessageConverter) - Method in class org.springframework.integration.dsl.jms.JmsTemplateSpec
 
JmsMessageDrivenChannelAdapter - Class in org.springframework.integration.dsl.jms
 
JmsMessageDrivenChannelAdapter(AbstractMessageListenerContainer, ChannelPublishingJmsMessageListener) - Constructor for class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
JmsMessageDrivenChannelAdapterSpec<S extends JmsMessageDrivenChannelAdapterSpec<S>> - Class in org.springframework.integration.dsl.jms
JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec<S extends JmsListenerContainerSpec<S,C>,C extends org.springframework.jms.listener.AbstractMessageListenerContainer> - Class in org.springframework.integration.dsl.jms
 
JmsOutboundChannelAdapterSpec<S extends JmsOutboundChannelAdapterSpec<S>> - Class in org.springframework.integration.dsl.jms
A MessageHandlerSpec for a JmsSendingMessageHandler.
JmsOutboundChannelAdapterSpec.JmsOutboundChannelSpecTemplateAware - Class in org.springframework.integration.dsl.jms
A JmsTemplate-based JmsOutboundChannelAdapterSpec extension.
JmsOutboundGatewaySpec - Class in org.springframework.integration.dsl.jms
A MessageHandlerSpec for a JmsOutboundGateway.
JmsOutboundGatewaySpec.ReplyContainerSpec - Class in org.springframework.integration.dsl.jms
An IntegrationComponentSpec for JmsOutboundGateway.ReplyContainerProperties.
jmsPollable(ConnectionFactory) - Method in class org.springframework.integration.dsl.Channels
 
jmsPollable(String, ConnectionFactory) - Method in class org.springframework.integration.dsl.Channels
 
JmsPollableMessageChannelSpec<S extends JmsPollableMessageChannelSpec<S>> - Class in org.springframework.integration.dsl.jms
A MessageChannelSpec for an AbstractJmsChannel.
jmsPublishSubscribe(ConnectionFactory) - Method in class org.springframework.integration.dsl.Channels
 
jmsPublishSubscribe(String, ConnectionFactory) - Method in class org.springframework.integration.dsl.Channels
 
JmsPublishSubscribeMessageChannelSpec - Class in org.springframework.integration.dsl.jms
A JmsMessageChannelSpec for a SubscribableJmsChannel configured with a topic.
jmsTemplateSpec - Variable in class org.springframework.integration.dsl.jms.JmsOutboundChannelAdapterSpec
 
JmsTemplateSpec - Class in org.springframework.integration.dsl.jms
A JmsDestinationAccessorSpec for a DynamicJmsTemplate.
Jpa - Class in org.springframework.integration.dsl.jpa
Factory class for JPA components.
JpaBaseOutboundEndpointSpec<S extends JpaBaseOutboundEndpointSpec<S>> - Class in org.springframework.integration.dsl.jpa
The base MessageHandlerSpec for JPA Outbound endpoints.
JpaBaseOutboundEndpointSpec(JpaExecutor) - Constructor for class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
jpaExecutor - Variable in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
JpaInboundChannelAdapterSpec - Class in org.springframework.integration.dsl.jpa
A MessageSourceSpec for a JpaPollingChannelAdapter.
jpaOutboundGatewayFactoryBean - Variable in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
jpaQuery(String) - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
jpaQuery(String) - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
JpaRetrievingOutboundGatewaySpec - Class in org.springframework.integration.dsl.jpa
A JpaBaseOutboundEndpointSpec extension for the JpaOutboundGateway with OutboundGatewayType.RETRIEVING mode.
JpaUpdatingOutboundEndpointSpec - Class in org.springframework.integration.dsl.jpa
A JpaBaseOutboundEndpointSpec extension for the updating JpaOutboundGateway mode.

K

Kafka - Class in org.springframework.integration.dsl.kafka
Factory class for Apache Kafka components.
KafkaMessageDrivenChannelAdapterSpec<K,V,S extends KafkaMessageDrivenChannelAdapterSpec<K,V,S>> - Class in org.springframework.integration.dsl.kafka
A MessageProducerSpec implementation for the KafkaMessageDrivenChannelAdapter.
KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec<K,V> - Class in org.springframework.integration.dsl.kafka
A ConcurrentMessageListenerContainer configuration KafkaMessageDrivenChannelAdapterSpec extension.
KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec<K,V> - Class in org.springframework.integration.dsl.kafka
A helper class in the Builder pattern style to delegate options to the ConcurrentMessageListenerContainer.
KafkaProducerMessageHandlerSpec<K,V> - Class in org.springframework.integration.dsl.kafka
A MessageHandlerSpec implementation for the KafkaProducerMessageHandler.
KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec<K,V> - Class in org.springframework.integration.dsl.kafka
A KafkaTemplate-based KafkaProducerMessageHandlerSpec extension.
kafkaTemplate - Variable in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
 

L

lang(String) - Method in class org.springframework.integration.dsl.scripting.ScriptMessageSourceSpec
The script lang (Groovy, ruby, python etc.).
lang(String) - Method in class org.springframework.integration.dsl.scripting.ScriptSpec
The script lang (Groovy, ruby, python etc.).
listenerTaskExecutor(AsyncListenableTaskExecutor) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the executor for threads that invoke the listener.
loadBalancer(LoadBalancingStrategy) - Method in class org.springframework.integration.dsl.channel.LoadBalancingChannelSpec
 
LoadBalancingChannelSpec<S extends MessageChannelSpec<S,C>,C extends org.springframework.integration.channel.AbstractMessageChannel> - Class in org.springframework.integration.dsl.channel
 
LoadBalancingChannelSpec() - Constructor for class org.springframework.integration.dsl.channel.LoadBalancingChannelSpec
 
loadBalancingStrategy - Variable in class org.springframework.integration.dsl.channel.LoadBalancingChannelSpec
 
localDirectory(File) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
Configure the local directory to copy files to.
localDirectory(File) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
localDirectory(Function<Message<P>, String>) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
localDirectoryExpression(String) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
localDirectoryExpression(Expression) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
localFilename(Function<String, String>) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
Configure a Function to be invoked to generate the local file name; argument passed to the apply method is the remote file name.
localFilename(Function<Message<P>, String>) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
localFilenameExpression(String) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
Configure a SpEL expression to generate the local file name; the root object for the evaluation is the remote file name.
localFilenameExpression(Expression) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
Configure a SpEL expression to generate the local file name; the root object for the evaluation is the remote file name.
localFilenameExpression(String) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
localFilenameExpression(Expression) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
localFilter(FileListFilter<File>) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
 
locker(FileLocker) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
 
lockRegistry(LockRegistry) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Used to obtain a Lock based on the groupId for concurrent operations on the MessageGroup.
log() - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the INFO logging level and org.springframework.integration.handler.LoggingHandler as a default logging category.
log(LoggingHandler.Level) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for provided LoggingHandler.Level logging level and org.springframework.integration.handler.LoggingHandler as a default logging category.
log(String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided logging category and INFO logging level.
log(LoggingHandler.Level, String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level and logging category.
log(LoggingHandler.Level, String, String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, logging category and SpEL expression for the log message.
log(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the INFO logging level, the org.springframework.integration.handler.LoggingHandler as a default logging category and Function for the log message.
log(Expression) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the INFO logging level, the org.springframework.integration.handler.LoggingHandler as a default logging category and SpEL expression to evaluate logger message at runtime against the request Message.
log(LoggingHandler.Level, Expression) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, the org.springframework.integration.handler.LoggingHandler as a default logging category and SpEL expression to evaluate logger message at runtime against the request Message.
log(String, Expression) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the INFO LoggingHandler.Level logging level, the provided logging category and SpEL expression to evaluate logger message at runtime against the request Message.
log(LoggingHandler.Level, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, the org.springframework.integration.handler.LoggingHandler as a default logging category and Function for the log message.
log(String, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, the provided logging category and Function for the log message.
log(LoggingHandler.Level, String, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, logging category and Function for the log message.
log(LoggingHandler.Level, String, Expression) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a WireTap for the IntegrationFlowDefinition.currentMessageChannel with the LoggingHandler subscriber for the provided LoggingHandler.Level logging level, logging category and SpEL expression for the log message.
logger - Variable in class org.springframework.integration.dsl.core.IntegrationComponentSpec
 

M

mail(String) - Method in class org.springframework.integration.dsl.Adapters
 
Mail - Class in org.springframework.integration.dsl.mail
The factory for Spring Integration Mail components.
MailHeadersBuilder - Class in org.springframework.integration.dsl.mail
The Mail specific MapBuilder implementation.
MailInboundChannelAdapterSpec<S extends MailInboundChannelAdapterSpec<S,R>,R extends org.springframework.integration.mail.AbstractMailReceiver> - Class in org.springframework.integration.dsl.mail
A MessageSourceSpec for a MailReceivingMessageSource.
MailInboundChannelAdapterSpec(R) - Constructor for class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
 
MailInboundChannelAdapterSpec(R, boolean) - Constructor for class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
 
MailSendingMessageHandlerSpec - Class in org.springframework.integration.dsl.mail
 
MapBuilder<B extends MapBuilder<B,K,V>,K,V> - Class in org.springframework.integration.dsl.support
A Builder pattern implementation for the Map.
MapBuilder() - Constructor for class org.springframework.integration.dsl.support.MapBuilder
 
mappedReplyHeaders(String...) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseInboundGatewaySpec
Only applies if the default header mapper is used.
mappedReplyHeaders(String...) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
mappedReplyHeaders(String...) - Method in class org.springframework.integration.dsl.amqp.AmqpOutboundEndpointSpec
 
mappedRequestHeaders(String...) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseInboundChannelAdapterSpec
Only applies if the default header mapper is used.
mappedRequestHeaders(String...) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseInboundGatewaySpec
Only applies if the default header mapper is used.
mappedRequestHeaders(String...) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
mappedRequestHeaders(String...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
mappedRequestHeaders(String...) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
mappedResponseHeaders(String...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
mappedResponseHeaders(String...) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
markers() - Method in class org.springframework.integration.dsl.file.FileSplitterSpec
Specify if FileSplitter should emit FileSplitter.FileMarkers Defaults to false.
markers(boolean) - Method in class org.springframework.integration.dsl.file.FileSplitterSpec
Specify if FileSplitter should emit FileSplitter.FileMarkers and if they should be converted to the JSON string representation.
marshaller(Marshaller) - Static method in class org.springframework.integration.dsl.support.Transformers
 
marshaller(Marshaller, ResultTransformer) - Static method in class org.springframework.integration.dsl.support.Transformers
 
marshaller(Marshaller, ResultFactory) - Static method in class org.springframework.integration.dsl.support.Transformers
 
marshaller(Marshaller, boolean) - Static method in class org.springframework.integration.dsl.support.Transformers
 
marshaller(Marshaller, ResultFactory, boolean) - Static method in class org.springframework.integration.dsl.support.Transformers
 
marshaller(Marshaller, ResultTransformer, boolean) - Static method in class org.springframework.integration.dsl.support.Transformers
 
marshaller(Marshaller, ResultTransformer, ResultFactory) - Static method in class org.springframework.integration.dsl.support.Transformers
 
marshaller(Marshaller, ResultTransformer, ResultFactory, boolean) - Static method in class org.springframework.integration.dsl.support.Transformers
 
maxAge(long) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec.CrossOriginSpec
 
maxConcurrentConsumers(int) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
maxConcurrentConsumers(int) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
maxConcurrentConsumers(int) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
The max for concurrent consumers number to use.
maxConcurrentConsumers(Integer) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
 
maxFetchSize(int) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
 
maxFetchSize(int) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
The maximum for fetch size.
maxMessagesPerPoll(long) - Method in class org.springframework.integration.dsl.core.PollerSpec
 
maxMessagesPerTask(int) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
The max messages per task.
maxMessagesPerTask(int) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
Only applies if the JmsMessageChannelSpec.containerType(Class) is a DefaultMessageListenerContainer.
maxMessagesPerTask(Integer) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
 
maxResults(int) - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
maxResults(int) - Method in class org.springframework.integration.dsl.jpa.JpaRetrievingOutboundGatewaySpec
 
maxResultsExpression(String) - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
maxResultsExpression(Expression) - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
maxResultsExpression(String) - Method in class org.springframework.integration.dsl.jpa.JpaRetrievingOutboundGatewaySpec
 
maxResultsExpression(Expression) - Method in class org.springframework.integration.dsl.jpa.JpaRetrievingOutboundGatewaySpec
 
maxSubscribers(int) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
maxSubscribers - Variable in class org.springframework.integration.dsl.channel.LoadBalancingChannelSpec
 
maxSubscribers(Integer) - Method in class org.springframework.integration.dsl.channel.LoadBalancingChannelSpec
 
maxSubscribers(Integer) - Method in class org.springframework.integration.dsl.channel.PublishSubscribeChannelSpec
 
maxSubscribers(int) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
 
mergeWithDefaultConverters(boolean) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
MessageChannelReference - Class in org.springframework.integration.dsl.support
An "artificial" MessageChannel implementation which will be unwrapped to the MessageChannel bean on the bean registration phase.
MessageChannelReference(String) - Constructor for class org.springframework.integration.dsl.support.MessageChannelReference
 
MessageChannels - Class in org.springframework.integration.dsl.channel
 
MessageChannelSpec<S extends MessageChannelSpec<S,C>,C extends org.springframework.integration.channel.AbstractMessageChannel> - Class in org.springframework.integration.dsl.channel
 
MessageChannelSpec() - Constructor for class org.springframework.integration.dsl.channel.MessageChannelSpec
 
messageConverter(MessageConverter) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseInboundChannelAdapterSpec
Configure the adapter's MessageConverter; defaults to SimpleMessageConverter.
messageConverter(MessageConverter) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseInboundGatewaySpec
Configure the gateway's MessageConverter; defaults to SimpleMessageConverter.
messageConverter(MessageConverter) - Method in class org.springframework.integration.dsl.channel.MessageChannelSpec
 
messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
 
messageConverters(HttpMessageConverter<?>...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
messageConverters(HttpMessageConverter<?>...) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
messageDrivenChannelAdapter(AbstractMessageListenerContainer) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsMessageDrivenChannelAdapterSpec.
messageDrivenChannelAdapter(ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsMessageDrivenChannelAdapterSpec.
messageDrivenChannelAdapter(ConnectionFactory, Class<C>) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsMessageDrivenChannelAdapterSpec.
messageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>) - Static method in class org.springframework.integration.dsl.kafka.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, ContainerProperties) - Static method in class org.springframework.integration.dsl.kafka.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, TopicPartitionInitialOffset...) - Static method in class org.springframework.integration.dsl.kafka.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, String...) - Static method in class org.springframework.integration.dsl.kafka.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, Pattern) - Static method in class org.springframework.integration.dsl.kafka.Kafka
messageDriverChannelAdapter(AbstractMessageListenerContainer) - Static method in class org.springframework.integration.dsl.jms.Jms
messageDriverChannelAdapter(ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
messageDriverChannelAdapter(ConnectionFactory, Class<C>) - Static method in class org.springframework.integration.dsl.jms.Jms
MessageHandlerSpec<S extends MessageHandlerSpec<S,H>,H extends org.springframework.messaging.MessageHandler> - Class in org.springframework.integration.dsl.core
An IntegrationComponentSpec for MessageHandlers.
MessageHandlerSpec() - Constructor for class org.springframework.integration.dsl.core.MessageHandlerSpec
 
messageIdEnabled(boolean) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
 
messageKey(String) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Configure the message key to store message in Kafka topic.
messageKey(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Configure a Function that will be invoked at run time to determine the message key under which a message will be stored in the topic.
messageKeyExpression(String) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Configure a SpEL expression to determine the Kafka message key to store at runtime against request Message as a root object of evaluation context.
messageKeyExpression(Expression) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Configure an Expression to determine the Kafka message key to store at runtime against request Message as a root object of evaluation context.
messageProcessor(MessageProcessor<?>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Configure an optional custom MessageProcessor for the enricher.
messageProcessor(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Configure an ExpressionEvaluatingMessageProcessor that evaluates to a Map of additional headers.
messageProcessor(String, String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Configure an MethodInvokingMessageProcessor that invokes the method on the bean - the method must return a Map of headers.
MessageProcessorMessageSource - Class in org.springframework.integration.dsl.support
The MessageSource strategy implementation to produce a Message from underlying MessageProcessorMessageSource.messageProcessor for polling endpoints.
MessageProcessorMessageSource(MessageProcessor<?>) - Constructor for class org.springframework.integration.dsl.support.MessageProcessorMessageSource
 
MessageProcessorSpec<S extends MessageProcessorSpec<S>> - Class in org.springframework.integration.dsl.core
The IntegrationComponentSpec specific base class for MessageProcessors.
MessageProcessorSpec() - Constructor for class org.springframework.integration.dsl.core.MessageProcessorSpec
 
MessageProducers - Class in org.springframework.integration.dsl
 
MessageProducerSpec<S extends MessageProducerSpec<S,P>,P extends org.springframework.integration.endpoint.MessageProducerSupport> - Class in org.springframework.integration.dsl.core
An IntegrationComponentSpec for MessageProducers.
MessageProducerSpec(P) - Constructor for class org.springframework.integration.dsl.core.MessageProducerSpec
 
messagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
Configure messagePropertiesConverter on both the RabbitTemplate (for sends) and SimpleMessageListenerContainer (for receives).
messageSelector(String) - Method in class org.springframework.integration.dsl.jms.JmsInboundChannelAdapterSpec
 
messageSelector(String) - Method in class org.springframework.integration.dsl.jms.JmsListenerContainerSpec
 
messageSelector(String) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
Configure a message selector in the DefaultMessageListenerContainer (when message driven) or the JmsTemplate (when polled).
MessageSources - Class in org.springframework.integration.dsl
Provides various factory methods for MessageSourceSpecs from Namespace Factories.
MessageSourceSpec<S extends MessageSourceSpec<S,H>,H extends org.springframework.integration.core.MessageSource<?>> - Class in org.springframework.integration.dsl.core
An IntegrationComponentSpec for MessageSources.
MessageSourceSpec() - Constructor for class org.springframework.integration.dsl.core.MessageSourceSpec
 
messageStore(MessageGroupStore) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
messageStore(MessageGroupStore) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
 
messageTimestampEnabled(boolean) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
 
MessagingGateways - Class in org.springframework.integration.dsl
 
MessagingGatewaySpec<S extends MessagingGatewaySpec<S,G>,G extends org.springframework.integration.gateway.MessagingGatewaySupport> - Class in org.springframework.integration.dsl.core
An IntegrationComponentSpec for MessagingGatewaySupports.
MessagingGatewaySpec(G) - Constructor for class org.springframework.integration.dsl.core.MessagingGatewaySpec
 
messagingTemplateFor(String) - Method in class org.springframework.integration.dsl.context.IntegrationFlowContext
Obtain a MessagingTemplate with its default destination set to the input channel of the IntegrationFlow for provided flowId.
metadataStore(MetadataStore) - Method in class org.springframework.integration.dsl.feed.FeedEntryMessageSourceSpec
 
method(RequestMethod...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec.CrossOriginSpec
 
methods(HttpMethod...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec.RequestMappingSpec
 
minimumTimeoutForEmptyGroups(long) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
minSubscribers(int) - Method in class org.springframework.integration.dsl.channel.PublishSubscribeChannelSpec
 
mputFilter(FileListFilter<File>) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
multipartMode(int) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
A multipart mode ro use.
multipartModeExpression(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
multipartModeFunction(Function<Message<P>, Integer>) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
multipartResolver(MultipartResolver) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 

N

namedQuery(String) - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
namedQuery(String) - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
nativeOptions(String) - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
 
nativeQuery(String) - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
nativeQuery(String) - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
nioLocker() - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
Configure an NioFileLocker.

O

objectToString() - Static method in class org.springframework.integration.dsl.support.Transformers
 
objectToString(String) - Static method in class org.springframework.integration.dsl.support.Transformers
 
of(T1) - Static method in class org.springframework.integration.dsl.support.tuple.Tuples
Create a Tuple1 with the given object.
of(T1, T2) - Static method in class org.springframework.integration.dsl.support.tuple.Tuples
Create a Tuple2 with the given objects.
onInit() - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
onInit() - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
options(String) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
options(AbstractRemoteFileOutboundGateway.Option...) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
order(int) - Method in class org.springframework.integration.dsl.BarrierSpec
 
order(int) - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
 
org.springframework.integration.dsl - package org.springframework.integration.dsl
Root package of the Spring Integration Java DSL.
org.springframework.integration.dsl.amqp - package org.springframework.integration.dsl.amqp
Provides AMQP Components support for Spring Integration Java DSL.
org.springframework.integration.dsl.channel - package org.springframework.integration.dsl.channel
Contains MessageChannel Builders DSL.
org.springframework.integration.dsl.config - package org.springframework.integration.dsl.config
Provides config classes of the Spring Integration Java DSL.
org.springframework.integration.dsl.context - package org.springframework.integration.dsl.context
The context support classes for Spring Integration Java DSL.
org.springframework.integration.dsl.core - package org.springframework.integration.dsl.core
Provides core classes of the Spring Integration Java DSL.
org.springframework.integration.dsl.feed - package org.springframework.integration.dsl.feed
Provides Feed Components support for Spring Integration Java DSL.
org.springframework.integration.dsl.file - package org.springframework.integration.dsl.file
Provides File Components support for Spring Integration Java DSL.
org.springframework.integration.dsl.ftp - package org.springframework.integration.dsl.ftp
Provides FTP Components support for Spring Integration Java DSL.
org.springframework.integration.dsl.http - package org.springframework.integration.dsl.http
Provides HTTP Components support for Spring Integration Java DSL.
org.springframework.integration.dsl.jms - package org.springframework.integration.dsl.jms
Provides JMS Components support for Spring Integration Java DSL.
org.springframework.integration.dsl.jpa - package org.springframework.integration.dsl.jpa
Provides JPA Components support for Spring Integration Java DSL.
org.springframework.integration.dsl.kafka - package org.springframework.integration.dsl.kafka
Provides Kafka Components support for Spring Integration Java DSL.
org.springframework.integration.dsl.mail - package org.springframework.integration.dsl.mail
Provides Mail Components support for Spring Integration Java DSL.
org.springframework.integration.dsl.scripting - package org.springframework.integration.dsl.scripting
Provides Scripting Components support for Spring Integration Java DSL.
org.springframework.integration.dsl.sftp - package org.springframework.integration.dsl.sftp
Provides SFTP Components support for Spring Integration Java DSL.
org.springframework.integration.dsl.support - package org.springframework.integration.dsl.support
Provides various support classes used across Spring Integration Java DSL Components.
org.springframework.integration.dsl.support.tuple - package org.springframework.integration.dsl.support.tuple
Tuples provide a type-safe way to specify multiple parameters.
org.springframework.integration.dsl.transaction - package org.springframework.integration.dsl.transaction
Provides classes supporting Transactions.
origin(String...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec.CrossOriginSpec
 
outboundAdapter(AmqpTemplate) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpOutboundEndpointSpec (adapter).
outboundAdapter(File) - Static method in class org.springframework.integration.dsl.file.Files
 
outboundAdapter(String) - Static method in class org.springframework.integration.dsl.file.Files
 
outboundAdapter(Expression) - Static method in class org.springframework.integration.dsl.file.Files
 
outboundAdapter(Function<Message<P>, ?>) - Static method in class org.springframework.integration.dsl.file.Files
 
outboundAdapter(SessionFactory<FTPFile>) - Static method in class org.springframework.integration.dsl.ftp.Ftp
 
outboundAdapter(SessionFactory<FTPFile>, FileExistsMode) - Static method in class org.springframework.integration.dsl.ftp.Ftp
 
outboundAdapter(RemoteFileTemplate<FTPFile>) - Static method in class org.springframework.integration.dsl.ftp.Ftp
 
outboundAdapter(RemoteFileTemplate<FTPFile>, FileExistsMode) - Static method in class org.springframework.integration.dsl.ftp.Ftp
 
outboundAdapter(JmsTemplate) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsOutboundChannelAdapterSpec.
outboundAdapter(ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsOutboundChannelAdapterSpec.
outboundAdapter(EntityManagerFactory) - Static method in class org.springframework.integration.dsl.jpa.Jpa
 
outboundAdapter(EntityManager) - Static method in class org.springframework.integration.dsl.jpa.Jpa
 
outboundAdapter(JpaOperations) - Static method in class org.springframework.integration.dsl.jpa.Jpa
 
outboundAdapter(String) - Static method in class org.springframework.integration.dsl.mail.Mail
 
outboundAdapter(SessionFactory<ChannelSftp.LsEntry>) - Static method in class org.springframework.integration.dsl.sftp.Sftp
 
outboundAdapter(SessionFactory<ChannelSftp.LsEntry>, FileExistsMode) - Static method in class org.springframework.integration.dsl.sftp.Sftp
 
outboundAdapter(RemoteFileTemplate<ChannelSftp.LsEntry>) - Static method in class org.springframework.integration.dsl.sftp.Sftp
 
outboundAdapter(RemoteFileTemplate<ChannelSftp.LsEntry>, FileExistsMode) - Static method in class org.springframework.integration.dsl.sftp.Sftp
 
outboundChannelAdapter(URI) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundChannelAdapter(String) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundChannelAdapter(Function<Message<P>, ?>) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundChannelAdapter(Expression) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundChannelAdapter(URI, RestTemplate) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundChannelAdapter(String, RestTemplate) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundChannelAdapter(Function<Message<P>, ?>, RestTemplate) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundChannelAdapter(Expression, RestTemplate) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundChannelAdapter(KafkaTemplate<K, V>) - Static method in class org.springframework.integration.dsl.kafka.Kafka
outboundChannelAdapter(ProducerFactory<K, V>) - Static method in class org.springframework.integration.dsl.kafka.Kafka
Create an initial KafkaProducerMessageHandlerSpec with ProducerFactory.
outboundGateway(AmqpTemplate) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpOutboundEndpointSpec (gateway).
outboundGateway(File) - Static method in class org.springframework.integration.dsl.file.Files
 
outboundGateway(String) - Static method in class org.springframework.integration.dsl.file.Files
 
outboundGateway(Expression) - Static method in class org.springframework.integration.dsl.file.Files
 
outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.dsl.file.Files
 
outboundGateway(SessionFactory<FTPFile>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.dsl.ftp.Ftp
 
outboundGateway(SessionFactory<FTPFile>, String, String) - Static method in class org.springframework.integration.dsl.ftp.Ftp
 
outboundGateway(RemoteFileTemplate<FTPFile>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.dsl.ftp.Ftp
Produce a FtpOutboundGatewaySpec based on the RemoteFileTemplate, AbstractRemoteFileOutboundGateway.Command and expression for the remoteFilePath.
outboundGateway(RemoteFileTemplate<FTPFile>, String, String) - Static method in class org.springframework.integration.dsl.ftp.Ftp
Produce a FtpOutboundGatewaySpec based on the RemoteFileTemplate, AbstractRemoteFileOutboundGateway.Command and expression for the remoteFilePath.
outboundGateway(SessionFactory<FTPFile>, MessageSessionCallback<FTPFile, ?>) - Static method in class org.springframework.integration.dsl.ftp.Ftp
Produce a FtpOutboundGatewaySpec based on the MessageSessionCallback.
outboundGateway(URI) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundGateway(String) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundGateway(Expression) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundGateway(URI, RestTemplate) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundGateway(String, RestTemplate) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundGateway(Function<Message<P>, ?>, RestTemplate) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundGateway(Expression, RestTemplate) - Static method in class org.springframework.integration.dsl.http.Http
 
outboundGateway(ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsOutboundGatewaySpec.
outboundGateway(SessionFactory<ChannelSftp.LsEntry>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.dsl.sftp.Sftp
 
outboundGateway(SessionFactory<ChannelSftp.LsEntry>, String, String) - Static method in class org.springframework.integration.dsl.sftp.Sftp
 
outboundGateway(RemoteFileTemplate<ChannelSftp.LsEntry>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.dsl.sftp.Sftp
Produce a SftpOutboundGatewaySpec based on the RemoteFileTemplate, AbstractRemoteFileOutboundGateway.Command and expression for the remoteFilePath.
outboundGateway(RemoteFileTemplate<ChannelSftp.LsEntry>, String, String) - Static method in class org.springframework.integration.dsl.sftp.Sftp
Produce a SftpOutboundGatewaySpec based on the RemoteFileTemplate, AbstractRemoteFileOutboundGateway.Command and expression for the remoteFilePath.
outboundGateway(SessionFactory<ChannelSftp.LsEntry>, MessageSessionCallback<ChannelSftp.LsEntry, ?>) - Static method in class org.springframework.integration.dsl.sftp.Sftp
Produce a SftpOutboundGatewaySpec based on the MessageSessionCallback.
outboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
Configure the outbound header mapper to use when AmqpPollableMessageChannelSpec.extractPayload(boolean) is true.
outputChannel(MessageChannel) - Method in class org.springframework.integration.dsl.core.MessageProducerSpec
Specify the outputChannel for the MessageProducer
outputChannel(String) - Method in class org.springframework.integration.dsl.core.MessageProducerSpec
Specify the bean name of the outputChannel for the MessageProducer
outputChannel(MessageChannel) - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
 
outputExpression(String) - Method in class org.springframework.integration.dsl.AggregatorSpec
An expression to determine the output message from the released group.
outputProcessor(MessageGroupProcessor) - Method in class org.springframework.integration.dsl.AggregatorSpec
A processor to determine the output message from the released group.
outputProcessor(MessageGroupProcessor) - Method in class org.springframework.integration.dsl.BarrierSpec
 

P

parameter(Object) - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
parameter(String, Object) - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
parameter(JpaParameter) - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
parameterExpression(String) - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
parameterExpression(String, String) - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
parameterSource(ParameterSource) - Method in class org.springframework.integration.dsl.jpa.JpaInboundChannelAdapterSpec
 
parameterSourceFactory(ParameterSourceFactory) - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
params(String...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec.RequestMappingSpec
 
PARSER - Static variable in class org.springframework.integration.dsl.core.IntegrationComponentSpec
 
PARSER - Static variable in class org.springframework.integration.dsl.support.MapBuilder
 
partitionId(Integer) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Configure a partitionId of Kafka topic.
partitionId(Function<Message<P>, Integer>) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Configure a Function that will be invoked at run time to determine the partition id under which a message will be stored in the topic.
partitionIdExpression(String) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Configure a SpEL expression to determine the topic partitionId at runtime against request Message as a root object of evaluation context.
partitionIdExpression(Expression) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Configure an Expression to determine the topic partitionId at runtime against request Message as a root object of evaluation context.
patternFileNameFilter(String) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
patternFileNameFilter(String) - Method in class org.springframework.integration.dsl.ftp.FtpOutboundGatewaySpec
 
patternFileNameFilter(String) - Method in class org.springframework.integration.dsl.sftp.SftpOutboundGatewaySpec
 
patternFilter(String) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
Configure a SimplePatternFileListFilter.
patternFilter(String, boolean) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
Deprecated.
since 1.1 in favor of the bunch of methods usage.
patternFilter(String) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
Configure a simple pattern filter (e.g.
patternFilter(String) - Method in class org.springframework.integration.dsl.ftp.FtpInboundChannelAdapterSpec
 
patternFilter(String) - Method in class org.springframework.integration.dsl.sftp.SftpInboundChannelAdapterSpec
 
patternMputFilter(String) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
pauseAfter(long) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
When using Kafka group management and KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec.pauseEnabled(boolean) is true, set the delay after which the consumer should be paused.
pauseEnabled(boolean) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set to true to avoid rebalancing when this consumer is slow or throws a qualifying exception - pause the consumer.
payloadExpression(String) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
payloadExpression(Expression) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
payloadFunction(Function<HttpEntity<P>, ?>) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
persistMode(PersistMode) - Method in class org.springframework.integration.dsl.jpa.JpaUpdatingOutboundEndpointSpec
 
phase(int) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
phase(int) - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
 
phase(int) - Method in class org.springframework.integration.dsl.core.EndpointSpec
 
phase(int) - Method in class org.springframework.integration.dsl.core.MessageProducerSpec
 
phase(int) - Method in class org.springframework.integration.dsl.core.MessagingGatewaySpec
A lifecycle phase to use.
phase(int) - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
 
phase(int) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
 
phase(int) - Method in class org.springframework.integration.dsl.SourcePollingChannelAdapterSpec
 
pollableChannel(ConnectionFactory) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpPollableMessageChannelSpec.
pollableChannel(String, ConnectionFactory) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpPollableMessageChannelSpec.
pollableChannel(ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsPollableMessageChannelSpec.
pollableChannel(String, ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsPollableMessageChannelSpec.
poller(PollerMetadata) - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
 
poller(Function<PollerFactory, PollerSpec>) - Method in class org.springframework.integration.dsl.core.EndpointSpec
 
poller(PollerSpec) - Method in class org.springframework.integration.dsl.core.EndpointSpec
 
poller(PollerMetadata) - Method in class org.springframework.integration.dsl.core.EndpointSpec
 
poller(PollerMetadata) - Method in class org.springframework.integration.dsl.SourcePollingChannelAdapterSpec
 
PollerFactory - Class in org.springframework.integration.dsl.core
An Adapter class for the Pollers factory.
Pollers - Class in org.springframework.integration.dsl.core
An utility class to provide PollerSpecs for PollerMetadata configuration variants.
PollerSpec - Class in org.springframework.integration.dsl.core
An IntegrationComponentSpec for PollerMetadatas.
pollTimeout(long) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the max time to block in the consumer waiting for records.
pop3() - Method in class org.springframework.integration.dsl.MessageSources
pop3(String) - Method in class org.springframework.integration.dsl.MessageSources
pop3(String, String, String) - Method in class org.springframework.integration.dsl.MessageSources
pop3(String, int, String, String) - Method in class org.springframework.integration.dsl.MessageSources
pop3InboundAdapter() - Static method in class org.springframework.integration.dsl.mail.Mail
 
pop3InboundAdapter(Pop3MailReceiver) - Static method in class org.springframework.integration.dsl.mail.Mail
A Pop3MailInboundChannelAdapterSpec factory based on the provided Pop3MailReceiver.
pop3InboundAdapter(String) - Static method in class org.springframework.integration.dsl.mail.Mail
 
pop3InboundAdapter(String, String, String) - Static method in class org.springframework.integration.dsl.mail.Mail
 
pop3InboundAdapter(String, int, String, String) - Static method in class org.springframework.integration.dsl.mail.Mail
 
Pop3MailInboundChannelAdapterSpec - Class in org.springframework.integration.dsl.mail
port(int) - Method in class org.springframework.integration.dsl.mail.MailSendingMessageHandlerSpec
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.dsl.config.IntegrationFlowBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.dsl.config.IntegrationFlowBeanPostProcessor
 
prefetchCount(int) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
prefetchCount(int) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
prefetchCount(int) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
prefix(String) - Method in class org.springframework.integration.dsl.RouterSpec
preserveTimestamp(boolean) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
Set to true to preserve the destination file timestamp.
preserveTimestamp(boolean) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
 
preventDuplicates(boolean) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
Configure an AcceptOnceFileListFilter if preventDuplicates == true, otherwise - AcceptAllFileListFilter.
preventDuplicates() - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
preventDuplicatesFilter(boolean) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
Deprecated.
since 1.1 in favor of the bunch of methods usage.
priority() - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
priority(String) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
priority(PriorityCapableChannelMessageStore, Object) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
priority(String, PriorityCapableChannelMessageStore, Object) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
priority() - Method in class org.springframework.integration.dsl.Channels
 
priority(String) - Method in class org.springframework.integration.dsl.Channels
 
priority(String, PriorityCapableChannelMessageStore, Object) - Method in class org.springframework.integration.dsl.Channels
 
priority(PriorityCapableChannelMessageStore, Object) - Method in class org.springframework.integration.dsl.Channels
 
priority(int) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
Default priority.
priority(int) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
Default priority.
priority(int) - Method in class org.springframework.integration.dsl.jms.JmsTemplateSpec
May be overridden at run time by the message priority header.
PriorityChannelSpec - Class in org.springframework.integration.dsl.channel
 
processMessage(Message<?>) - Method in class org.springframework.integration.dsl.support.BeanNameMessageProcessor
 
processor(Object) - Method in class org.springframework.integration.dsl.AggregatorSpec
Configure the handler with MethodInvokingCorrelationStrategy and MethodInvokingReleaseStrategy using the target object which should have methods annotated appropriately for each function.
processor(Object, String) - Method in class org.springframework.integration.dsl.AggregatorSpec
Configure the handler with MethodInvokingCorrelationStrategy and MethodInvokingReleaseStrategy using the target object which should have methods annotated appropriately for each function.
processor(Object) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with MethodInvokingCorrelationStrategy and MethodInvokingReleaseStrategy using the target object which should have methods annotated appropriately for each function.
producerListener(ProducerListener<K, V>) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
 
produces(String...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec.RequestMappingSpec
 
propagation(Propagation) - Method in class org.springframework.integration.dsl.transaction.TransactionInterceptorBuilder
 
PropertiesBuilder - Class in org.springframework.integration.dsl.support
A Builder pattern implementation for the Properties.
PropertiesBuilder() - Constructor for class org.springframework.integration.dsl.support.PropertiesBuilder
 
property(String, V) - Method in class org.springframework.integration.dsl.EnricherSpec
 
propertyExpression(String, String) - Method in class org.springframework.integration.dsl.EnricherSpec
 
propertyFunction(String, Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.EnricherSpec
 
protocol(String) - Method in class org.springframework.integration.dsl.mail.MailSendingMessageHandlerSpec
 
publishSubscribe() - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
publishSubscribe(String) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
publishSubscribe(Executor) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
publishSubscribe(String, Executor) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
publishSubscribe() - Method in class org.springframework.integration.dsl.Channels
 
publishSubscribe(Executor) - Method in class org.springframework.integration.dsl.Channels
 
publishSubscribe(String, Executor) - Method in class org.springframework.integration.dsl.Channels
 
publishSubscribe(String) - Method in class org.springframework.integration.dsl.Channels
 
publishSubscribeChannel(ConnectionFactory) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpPublishSubscribeMessageChannelSpec.
publishSubscribeChannel(String, ConnectionFactory) - Static method in class org.springframework.integration.dsl.amqp.Amqp
Create an initial AmqpPublishSubscribeMessageChannelSpec.
publishSubscribeChannel(Consumer<PublishSubscribeSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
The PublishSubscribeChannel IntegrationFlowDefinition.channel(java.lang.String) method specific implementation to allow the use of the 'subflow' subscriber capability.
publishSubscribeChannel(Executor, Consumer<PublishSubscribeSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
The PublishSubscribeChannel IntegrationFlowDefinition.channel(java.lang.String) method specific implementation to allow the use of the 'subflow' subscriber capability.
publishSubscribeChannel(ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsPublishSubscribeMessageChannelSpec.
publishSubscribeChannel(String, ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
The factory to produce a JmsPublishSubscribeMessageChannelSpec.
PublishSubscribeChannelSpec<S extends PublishSubscribeChannelSpec<S>> - Class in org.springframework.integration.dsl.channel
 
PublishSubscribeChannelSpec() - Constructor for class org.springframework.integration.dsl.channel.PublishSubscribeChannelSpec
 
PublishSubscribeChannelSpec(Executor) - Constructor for class org.springframework.integration.dsl.channel.PublishSubscribeChannelSpec
 
PublishSubscribeSpec - Class in org.springframework.integration.dsl
 
pubSubDomain(boolean) - Method in class org.springframework.integration.dsl.jms.JmsDestinationAccessorSpec
A pubSubDomain flag.
pubSubNoLocal(boolean) - Method in class org.springframework.integration.dsl.jms.JmsPublishSubscribeMessageChannelSpec
Only applies if the JmsMessageChannelSpec.containerType(Class) is a DefaultMessageListenerContainer or a SimpleMessageListenerContainer.
put(K, V) - Method in class org.springframework.integration.dsl.support.MapBuilder
 
put(Object, Object) - Method in class org.springframework.integration.dsl.support.PropertiesBuilder
 

Q

queue() - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
queue(String) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
queue(Queue<Message<?>>) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
queue(String, Queue<Message<?>>) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
queue(Integer) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
queue(String, Integer) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
queue(ChannelMessageStore, Object) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
queue(String, ChannelMessageStore, Object) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
queue - Variable in class org.springframework.integration.dsl.channel.QueueChannelSpec
 
queue() - Method in class org.springframework.integration.dsl.Channels
 
queue(String) - Method in class org.springframework.integration.dsl.Channels
 
queue(Integer) - Method in class org.springframework.integration.dsl.Channels
 
queue(String, Integer) - Method in class org.springframework.integration.dsl.Channels
 
queue(Queue<Message<?>>) - Method in class org.springframework.integration.dsl.Channels
 
queue(String, Queue<Message<?>>) - Method in class org.springframework.integration.dsl.Channels
 
queue(ChannelMessageStore, Object) - Method in class org.springframework.integration.dsl.Channels
 
queue(String, ChannelMessageStore, Object) - Method in class org.springframework.integration.dsl.Channels
 
QueueChannelSpec - Class in org.springframework.integration.dsl.channel
 
QueueChannelSpec.MessageStoreSpec - Class in org.springframework.integration.dsl.channel
The ChannelMessageStore-specific QueueChannelSpec extension.
queueDepth(int) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the queue depth for handoffs from the consumer thread to the listener thread.
queueName(String) - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
Also implicitly sets the AmqpPollableMessageChannelSpec.id(String) (if not explicitly set).

R

readOnly(boolean) - Method in class org.springframework.integration.dsl.transaction.TransactionInterceptorBuilder
 
receiver - Variable in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
 
receiveTimeout(long) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
receiveTimeout(long) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
receiveTimeout(long) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
receiveTimeout(long) - Method in class org.springframework.integration.dsl.core.PollerSpec
Specify a timeout in milliseconds to wait for a message in the MessageChannel.
receiveTimeout(long) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
A receive timeout.
receiveTimeout(long) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
receiveTimeout(Long) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
 
receiveTimeout(long) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
 
receiveTimeout(long) - Method in class org.springframework.integration.dsl.jms.JmsTemplateSpec
 
recipient(String) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that always will be selected.
recipient(String, String) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the expression evaluates to 'true'.
recipient(String, Expression) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the expression evaluates to 'true'.
recipient(String, MessageSelector) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the selector's accept method returns 'true'.
recipient(String, GenericSelector<P>) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the selector's accept method returns 'true'.
recipient(MessageChannel) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that always will be selected.
recipient(MessageChannel, String) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the expression evaluates to 'true'.
recipient(MessageChannel, Expression) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the expression evaluates to 'true'.
recipient(MessageChannel, MessageSelector) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the selector's accept method returns 'true'.
recipient(MessageChannel, GenericSelector<P>) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a recipient channel that will be selected if the the selector's accept method returns 'true'.
recipientFlow(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'.
recipientFlow(GenericSelector<P>, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a subflow that will be invoked if the selector's accept methods returns 'true'.
recipientFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a subflow that will be invoked as a recipient.
recipientFlow(String, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a subflow that will be invoked if the expression evaluates to 'true'.
recipientFlow(Expression, IntegrationFlow) - Method in class org.springframework.integration.dsl.RecipientListRouterSpec
Adds a subflow that will be invoked if the expression evaluates to 'true'.
RecipientListRouterSpec - Class in org.springframework.integration.dsl
An AbstractRouterSpec for a RecipientListRouter.
recoveryInterval(long) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
recoveryInterval(long) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
recoveryInterval(long) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
recoveryInterval(long) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
Specify a recovery interval.
recoveryInterval(long) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
Only applies if the JmsMessageChannelSpec.containerType(Class) is a DefaultMessageListenerContainer.
recoveryInterval(Long) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
 
refreshCheckDelay(long) - Method in class org.springframework.integration.dsl.scripting.ScriptMessageSourceSpec
The refreshCheckDelay in milliseconds for refreshable script resource.
refreshCheckDelay(long) - Method in class org.springframework.integration.dsl.scripting.ScriptSpec
The refreshCheckDelay in milliseconds for refreshable script resource.
regexFileNameFilter(String) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
regexFileNameFilter(String) - Method in class org.springframework.integration.dsl.ftp.FtpOutboundGatewaySpec
 
regexFileNameFilter(String) - Method in class org.springframework.integration.dsl.sftp.SftpOutboundGatewaySpec
 
regexFilter(String) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
Configure a RegexPatternFileListFilter.
regexFilter(String, boolean) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
Deprecated.
since 1.1 in favor of the bunch of methods usage.
regexFilter(String) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
Configure a regex pattern filter (e.g.
regexFilter(String) - Method in class org.springframework.integration.dsl.ftp.FtpInboundChannelAdapterSpec
 
regexFilter(String) - Method in class org.springframework.integration.dsl.sftp.SftpInboundChannelAdapterSpec
 
regexMpuFilter(String) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
register() - Method in class org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
 
registration(IntegrationFlow) - Method in class org.springframework.integration.dsl.context.IntegrationFlowContext
Associate provided IntegrationFlow with an IntegrationFlowContext.IntegrationFlowRegistrationBuilder for additional options and farther registration in the application context.
releaseExpression(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with an ExpressionEvaluatingReleaseStrategy for the given expression.
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 an MethodInvokingReleaseStrategy for the target object and method name.
releaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
remoteDirectory(String) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
remoteDirectory(Function<Message<P>, String>) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
remoteDirectory(String) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
 
remoteDirectoryExpression(String) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
remoteDirectoryExpression(Expression) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
Specify an expression that evaluates to the full path to the remote directory.
RemoteFileInboundChannelAdapterSpec<F,S extends RemoteFileInboundChannelAdapterSpec<F,S,MS>,MS extends org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource<F>> - Class in org.springframework.integration.dsl.file
A MessageSourceSpec for an AbstractInboundFileSynchronizingMessageSource.
RemoteFileInboundChannelAdapterSpec(AbstractInboundFileSynchronizer<F>) - Constructor for class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
 
RemoteFileOutboundGatewaySpec<F,S extends RemoteFileOutboundGatewaySpec<F,S>> - Class in org.springframework.integration.dsl.file
 
RemoteFileOutboundGatewaySpec(AbstractRemoteFileOutboundGateway<F>) - Constructor for class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
remoteFileSeparator(String) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
remoteFileSeparator(String) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
Configure the file name path separator used by the remote system.
remoteFileSeparator(String) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
remove(String) - Method in class org.springframework.integration.dsl.context.IntegrationFlowContext
Destroy an IntegrationFlow bean (as well as all its dependant beans) for provided flowId and clean up all the local cache for it.
renameExpression(String) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
rendezvous() - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
rendezvous(String) - Static method in class org.springframework.integration.dsl.channel.MessageChannels
 
rendezvous() - Method in class org.springframework.integration.dsl.Channels
 
rendezvous(String) - Method in class org.springframework.integration.dsl.Channels
 
RendezvousChannelSpec - Class in org.springframework.integration.dsl.channel
 
reopen(boolean) - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
 
replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.core.MessagingGatewaySpec
A reply channel to use.
replyChannel(String) - Method in class org.springframework.integration.dsl.core.MessagingGatewaySpec
A reply channel name to use.
replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.EnricherSpec
 
replyChannel(String) - Method in class org.springframework.integration.dsl.EnricherSpec
 
replyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
 
replyChannel(String) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
 
replyContainer() - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
Configure a reply container with default properties.
replyContainer(Consumer<JmsOutboundGatewaySpec.ReplyContainerSpec>) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
Configure a reply container with a reply container specification determined by invoking the Consumer callback with a JmsOutboundGatewaySpec.ReplyContainerSpec.
replyDeliveryPersistent(boolean) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
replyDestination(Destination) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
replyDestination(String) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
replyDestination(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
Configure a Function that will be invoked at run time to determine the destination from which a reply will be received.
replyDestinationExpression(String) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
replyKey(String) - Method in class org.springframework.integration.dsl.http.HttpControllerEndpointSpec
 
replyMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.dsl.core.MessagingGatewaySpec
An OutboundMessageMapper to use.
replyPriority(int) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
replyPubSubDomain(boolean) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
replyTimeout(long) - Method in class org.springframework.integration.dsl.core.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
 
replyTimeToLive(long) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
replyTo(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
replyToExpression(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
replyToFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
requestChannel(MessageChannel) - Method in class org.springframework.integration.dsl.core.MessagingGatewaySpec
A request channel to use.
requestChannel(String) - Method in class org.springframework.integration.dsl.core.MessagingGatewaySpec
A request channel name to use.
requestChannel(MessageChannel) - Method in class org.springframework.integration.dsl.EnricherSpec
 
requestChannel(String) - Method in class org.springframework.integration.dsl.EnricherSpec
 
requestDestination(Destination) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
requestDestination(String) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
requestDestination(Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
Configure a Function that will be invoked at run time to determine the destination to which a message will be sent.
requestDestinationExpression(String) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
requestFactory(ClientHttpRequestFactory) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
requestMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.dsl.core.MessagingGatewaySpec
An InboundMessageMapper to use.
requestMapping(Consumer<BaseHttpInboundEndpointSpec.RequestMappingSpec>) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
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.dsl.http.BaseHttpInboundEndpointSpec
 
requestPubSubDomain(boolean) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
requestTimeout(long) - Method in class org.springframework.integration.dsl.core.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
 
requiresReply(boolean) - Method in class org.springframework.integration.dsl.BarrierSpec
 
requiresReply(boolean) - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
 
resequence() - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the ResequencingMessageHandler with default options.
resequence(Consumer<ResequencerSpec>, Consumer<GenericEndpointSpec<ResequencingMessageHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Deprecated.
resequence(Consumer<ResequencerSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the ResequencingMessageHandler with provided options from ResequencerSpec.
ResequencerSpec - Class in org.springframework.integration.dsl
 
resolutionRequired(boolean) - Method in class org.springframework.integration.dsl.RouterSpec
 
retrievingGateway(EntityManagerFactory) - Static method in class org.springframework.integration.dsl.jpa.Jpa
 
retrievingGateway(EntityManager) - Static method in class org.springframework.integration.dsl.jpa.Jpa
 
retrievingGateway(JpaOperations) - Static method in class org.springframework.integration.dsl.jpa.Jpa
 
returnChannel(MessageChannel) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
route(String, String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for provided bean and its method with default options.
route(String, String, Consumer<RouterSpec<Object, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for provided bean and its method with provided options from RouterSpec.
route(String, String, Consumer<RouterSpec<Object, MethodInvokingRouter>>, Consumer<GenericEndpointSpec<MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for provided bean and its method with provided options from RouterSpec.
route(Object) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for the discovered method of the provided service and its method with default options.
route(Object, String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for the method of the provided service and its method with default options.
route(Object, String, Consumer<RouterSpec<Object, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for the method of the provided service and its method with provided options from RouterSpec.
route(Object, String, Consumer<RouterSpec<Object, MethodInvokingRouter>>, Consumer<GenericEndpointSpec<MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for the method of the provided service and its method with provided options from RouterSpec.
route(String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the ExpressionEvaluatingRouter for provided SpEL expression with default options.
route(String, Consumer<RouterSpec<T, ExpressionEvaluatingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the ExpressionEvaluatingRouter for provided SpEL expression with provided options from RouterSpec.
route(String, Consumer<RouterSpec<T, ExpressionEvaluatingRouter>>, Consumer<GenericEndpointSpec<ExpressionEvaluatingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the ExpressionEvaluatingRouter for provided bean and its method with provided options from RouterSpec.
route(Function<S, T>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for provided Function with default options.
route(Function<S, T>, Consumer<RouterSpec<T, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for provided Function with provided options from RouterSpec.
route(Class<S>, Function<S, T>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for provided Function and payload type with default options.
route(Class<S>, Function<S, T>, Consumer<RouterSpec<T, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for provided Function and payload type and options from RouterSpec.
route(Function<S, T>, Consumer<RouterSpec<T, MethodInvokingRouter>>, Consumer<GenericEndpointSpec<MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for provided Function with provided options from RouterSpec.
route(Class<P>, Function<P, T>, Consumer<RouterSpec<T, MethodInvokingRouter>>, Consumer<GenericEndpointSpec<MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for provided Function and payload type and options from RouterSpec.
route(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for the MessageProcessor from the provided MessageProcessorSpec with default options.
route(MessageProcessorSpec<?>, Consumer<RouterSpec<Object, MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for the MessageProcessor from the provided MessageProcessorSpec with default options.
route(MessageProcessorSpec<?>, Consumer<RouterSpec<Object, MethodInvokingRouter>>, Consumer<GenericEndpointSpec<MethodInvokingRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingRouter for the MessageProcessor from the provided MessageProcessorSpec with default options.
route(R, Consumer<RouterSpec<K, R>>, Consumer<GenericEndpointSpec<R>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the provided AbstractMappingMessageRouter implementation with options from RouterSpec and endpoint options from GenericEndpointSpec.
route(AbstractMessageRouter) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the provided AbstractMessageRouter implementation to the current integration flow position.
route(R, Consumer<GenericEndpointSpec<R>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the provided AbstractMessageRouter implementation to the current integration flow position.
RouterSpec<K,R extends org.springframework.integration.router.AbstractMappingMessageRouter> - Class in org.springframework.integration.dsl
The AbstractRouterSpec for an AbstractMappingMessageRouter.
routeToRecipients(Consumer<RecipientListRouterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the RecipientListRouter options from RecipientListRouterSpec.
routeToRecipients(Consumer<RecipientListRouterSpec>, Consumer<GenericEndpointSpec<RecipientListRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the RecipientListRouter options from RecipientListRouterSpec.
routingKey(String) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
routingKeyExpression(String) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
routingKeyExpression(Expression) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 
routingKeyFunction(Function<Message<?>, String>) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseOutboundEndpointSpec
 

S

scanEachPoll(boolean) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
 
scanner(DirectoryScanner) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
 
scatterGather(MessageChannel) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ScatterGatherHandler to the current integration flow position based on the provided MessageChannel for scattering function and default AggregatorSpec for gathering function.
scatterGather(MessageChannel, Consumer<AggregatorSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ScatterGatherHandler to the current integration flow position based on the provided MessageChannel for scattering function and AggregatorSpec for gathering function.
scatterGather(MessageChannel, Consumer<AggregatorSpec>, Consumer<ScatterGatherSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ScatterGatherHandler to the current integration flow position based on the provided MessageChannel for scattering function and AggregatorSpec for gathering function.
scatterGather(Consumer<RecipientListRouterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ScatterGatherHandler to the current integration flow position based on the provided RecipientListRouterSpec for scattering function and default AggregatorSpec for gathering function.
scatterGather(Consumer<RecipientListRouterSpec>, Consumer<AggregatorSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ScatterGatherHandler to the current integration flow position based on the provided RecipientListRouterSpec for scattering function and AggregatorSpec for gathering function.
scatterGather(Consumer<RecipientListRouterSpec>, Consumer<AggregatorSpec>, Consumer<ScatterGatherSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ScatterGatherHandler to the current integration flow position based on the provided RecipientListRouterSpec for scattering function and AggregatorSpec for gathering function.
ScatterGatherSpec - Class in org.springframework.integration.dsl
A GenericEndpointSpec extension for the ScatterGatherHandler.
script(Resource) - Method in class org.springframework.integration.dsl.MessageSources
Factory for the ScriptMessageSourceSpec based on the Resource.
script(String) - Method in class org.springframework.integration.dsl.MessageSources
Factory for the ScriptMessageSourceSpec based on the script location.
script(Resource) - Static method in class org.springframework.integration.dsl.scripting.Scripts
The factory method to produce ScriptSpec based on the Resource.
script(String) - Static method in class org.springframework.integration.dsl.scripting.Scripts
The factory method to produce ScriptSpec based on the script file location.
ScriptMessageSourceSpec - Class in org.springframework.integration.dsl.scripting
The MessageSourceSpec for Dynamic Language Scripts.
ScriptMessageSourceSpec(Resource) - Constructor for class org.springframework.integration.dsl.scripting.ScriptMessageSourceSpec
 
ScriptMessageSourceSpec(String) - Constructor for class org.springframework.integration.dsl.scripting.ScriptMessageSourceSpec
 
Scripts - Class in org.springframework.integration.dsl.scripting
The factory for Dynamic Language Scripts (Groovy, Ruby, Python, JavaScript etc.).
ScriptSpec - Class in org.springframework.integration.dsl.scripting
The MessageProcessorSpec implementation for the DslScriptExecutingMessageProcessor.
searchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
 
searchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.dsl.mail.ImapMailInboundChannelAdapterSpec
A SearchTermStrategy to use.
selector(String) - Method in class org.springframework.integration.dsl.channel.WireTapSpec
 
selector(Expression) - Method in class org.springframework.integration.dsl.channel.WireTapSpec
Specify an Expression for selector.
selector(MessageSelector) - Method in class org.springframework.integration.dsl.channel.WireTapSpec
 
selector(Function<MimeMessage, Boolean>) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
Configure a Function to select messages.
selector(Function<MimeMessage, Boolean>) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
Configure a Function to select messages.
selectorExpression(String) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
Configure a SpEL expression to select messages.
selectorExpression(Expression) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
Configure an Expression to select messages.
selectorExpression(String) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
Configure a SpEL expression to select messages.
selectorExpression(Expression) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
Configure a SpEL expression to select messages.
send(Message<?>) - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
send(Message<?>, long) - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
send(Message<?>) - Method in class org.springframework.integration.dsl.support.MessageChannelReference
 
send(Message<?>, long) - Method in class org.springframework.integration.dsl.support.MessageChannelReference
 
sendingTaskExecutor(Executor) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
 
sendPartialResultOnExpiry(boolean) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
sendTimeout(long) - Method in class org.springframework.integration.dsl.BarrierSpec
 
sendTimeout(long) - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
 
sendTimeout(long) - Method in class org.springframework.integration.dsl.core.PollerSpec
 
sendTimeout(long) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Specify a timeout in milliseconds how long KafkaProducerMessageHandler should wait wait for send operation results.
serializer() - Static method in class org.springframework.integration.dsl.support.Transformers
 
serializer(Serializer<Object>) - Static method in class org.springframework.integration.dsl.support.Transformers
 
session(Session) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
A Java Mail Session to use.
session(Session) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
Provide the Java Mail Session to use.
sessionAcknowledgeMode(int) - Method in class org.springframework.integration.dsl.jms.JmsDestinationAccessorSpec
A session acknowledgement mode.
sessionAcknowledgeMode(Integer) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
 
sessionAcknowledgeMode(int) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
 
sessionAcknowledgeModeName(String) - Method in class org.springframework.integration.dsl.jms.JmsDestinationAccessorSpec
A session acknowledgement mode name.
sessionTransacted(boolean) - Method in class org.springframework.integration.dsl.jms.JmsDestinationAccessorSpec
A session transaction mode.
sessionTransacted(Boolean) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
 
sessionTransacted(boolean) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
Configure transactional sessions for both the JmsTemplate (sends and polled receives) and DefaultMessageListenerContainer (message-driven receives).
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.dsl.config.IntegrationFlowBeanPostProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.dsl.context.IntegrationFlowContext
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.dsl.support.BeanNameMessageProcessor
 
setCapacity(int) - Method in class org.springframework.integration.dsl.channel.PriorityChannelSpec
 
setComparator(Comparator<Message<?>>) - Method in class org.springframework.integration.dsl.channel.PriorityChannelSpec
 
setComponentName(String) - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
setComponentName(String) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
setErrorChannelName(String) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
 
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapterSpec
setIntegrationComponents(List<Object>) - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
setOutputChannelName(String) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
setReplyTimeout(long) - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
setRequestTimeout(long) - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
setSendTimeout(long) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
setShouldTrack(boolean) - Method in class org.springframework.integration.dsl.jms.JmsInboundGateway
 
setShouldTrack(boolean) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapter
 
setValue(EvaluationContext, Object) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
setValue(Object, Object) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.dsl.support.FunctionExpression
 
sftp(SessionFactory<ChannelSftp.LsEntry>) - Method in class org.springframework.integration.dsl.Adapters
sftp(SessionFactory<ChannelSftp.LsEntry>, FileExistsMode) - Method in class org.springframework.integration.dsl.Adapters
 
sftp(RemoteFileTemplate<ChannelSftp.LsEntry>) - Method in class org.springframework.integration.dsl.Adapters
 
sftp(RemoteFileTemplate<ChannelSftp.LsEntry>, FileExistsMode) - Method in class org.springframework.integration.dsl.Adapters
 
sftp(SessionFactory<ChannelSftp.LsEntry>) - Method in class org.springframework.integration.dsl.MessageSources
sftp(SessionFactory<ChannelSftp.LsEntry>, Comparator<File>) - Method in class org.springframework.integration.dsl.MessageSources
Sftp - Class in org.springframework.integration.dsl.sftp
 
Sftp() - Constructor for class org.springframework.integration.dsl.sftp.Sftp
 
sftpGateway(SessionFactory<ChannelSftp.LsEntry>, AbstractRemoteFileOutboundGateway.Command, String) - Method in class org.springframework.integration.dsl.Adapters
 
sftpGateway(SessionFactory<ChannelSftp.LsEntry>, String, String) - Method in class org.springframework.integration.dsl.Adapters
 
SftpInboundChannelAdapterSpec - Class in org.springframework.integration.dsl.sftp
A RemoteFileInboundChannelAdapterSpec for a SftpInboundFileSynchronizingMessageSource.
SftpMessageHandlerSpec - Class in org.springframework.integration.dsl.sftp
 
SftpOutboundGatewaySpec - Class in org.springframework.integration.dsl.sftp
 
shouldClonePayload(boolean) - Method in class org.springframework.integration.dsl.EnricherSpec
 
shouldDeleteMessages(boolean) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
 
shouldDeleteMessages(boolean) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
A flag to specify if messages should be deleted after receive.
shouldMarkMessagesAsRead(boolean) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
 
shouldMarkMessagesAsRead(boolean) - Method in class org.springframework.integration.dsl.mail.ImapMailInboundChannelAdapterSpec
A flag to determine if message should be marked as read.
shouldReconnectAutomatically(boolean) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
 
shouldSkipNulls(boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
 
shutdownTimeout(long) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
shutdownTimeout(long) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
shutdownTimeout(long) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
 
shutdownTimeout(long) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the timeout for shutting down the container.
size - Variable in class org.springframework.integration.dsl.support.tuple.Tuple
 
size() - Method in class org.springframework.integration.dsl.support.tuple.Tuple
Return the number of elements in this Tuple.
SourcePollingChannelAdapterSpec - Class in org.springframework.integration.dsl
 
split() - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the DefaultMessageSplitter with default options to the current integration flow position.
split(Consumer<SplitterEndpointSpec<DefaultMessageSplitter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the DefaultMessageSplitter with provided options to the current integration flow position.
split(String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the ExpressionEvaluatingSplitter with provided SpEL expression.
split(String, Consumer<SplitterEndpointSpec<ExpressionEvaluatingSplitter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the ExpressionEvaluatingSplitter with provided SpEL expression.
split(Object) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the discovered method of the service at runtime.
split(Object, String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided method of the service at runtime.
split(Object, String, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided method of the bean at runtime.
split(String, String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided method of the bean at runtime.
split(String, String, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided method of the bean at runtime.
split(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the MessageProcessor at runtime from provided MessageProcessorSpec.
split(MessageProcessorSpec<?>, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the MessageProcessor at runtime from provided MessageProcessorSpec.
split(Class<P>, Function<P, ?>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided Function at runtime.
split(Function<P, ?>, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided Function at runtime.
split(Class<P>, Function<P, ?>, Consumer<SplitterEndpointSpec<MethodInvokingSplitter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MethodInvokingSplitter to evaluate the provided Function at runtime.
split(MessageHandlerSpec<?, S>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the provided AbstractMessageSplitter to the current integration flow position.
split(MessageHandlerSpec<?, S>, Consumer<SplitterEndpointSpec<S>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the provided AbstractMessageSplitter to the current integration flow position.
split(AbstractMessageSplitter) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the provided AbstractMessageSplitter to the current integration flow position.
split(S, Consumer<SplitterEndpointSpec<S>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the provided AbstractMessageSplitter to the current integration flow position.
splitter() - Static method in class org.springframework.integration.dsl.file.Files
The FileSplitterSpec builder factory method with default arguments.
splitter(boolean) - Static method in class org.springframework.integration.dsl.file.Files
The FileSplitterSpec builder factory method with iterator flag specified.
splitter(boolean, boolean) - Static method in class org.springframework.integration.dsl.file.Files
The FileSplitterSpec builder factory method with iterator and markers flags specified.
SplitterEndpointSpec<S extends org.springframework.integration.splitter.AbstractMessageSplitter> - Class in org.springframework.integration.dsl
A ConsumerEndpointSpec for a AbstractMessageSplitter implementations.
StandardIntegrationFlow - Class in org.springframework.integration.dsl
 
start() - Method in class org.springframework.integration.dsl.context.IntegrationFlowRegistration
 
start() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
start() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
startConsumerMinInterval(long) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
startConsumerMinInterval(long) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
statusCodeExpression(Expression) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
statusCodeFunction(Function<Void, ?>) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
 
stop() - Method in class org.springframework.integration.dsl.context.IntegrationFlowRegistration
 
stop(Runnable) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
stop() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
stop(Runnable) - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
stop() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
stopConsumerMinInterval(long) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
stopConsumerMinInterval(long) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
storeLock(Lock) - Method in class org.springframework.integration.dsl.channel.QueueChannelSpec.MessageStoreSpec
 
StringStringMapBuilder - Class in org.springframework.integration.dsl.support
A map builder creating a map with String keys and values.
StringStringMapBuilder() - Constructor for class org.springframework.integration.dsl.support.StringStringMapBuilder
 
subFlowMapping(K, IntegrationFlow) - Method in class org.springframework.integration.dsl.RouterSpec
Add a subflow as an alternative to a RouterSpec.channelMapping(Object, String).
subFlows - Variable in class org.springframework.integration.dsl.AbstractRouterSpec
 
subject(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
subjectExpression(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
subjectFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
subscribe(IntegrationFlow) - Method in class org.springframework.integration.dsl.PublishSubscribeSpec
 
subscriptionDurable(boolean) - Method in class org.springframework.integration.dsl.jms.JmsListenerContainerSpec
 
subscriptionDurable(boolean) - Method in class org.springframework.integration.dsl.jms.JmsPublishSubscribeMessageChannelSpec
 
subscriptionShared(boolean) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
 
suffix(String) - Method in class org.springframework.integration.dsl.RouterSpec
sync(boolean) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
A boolean indicating if the KafkaProducerMessageHandler should wait for the send operation results or not.
syncCommits(boolean) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set whether or not to call consumer.commitSync() or commitAsync() when the container is responsible for commits.
synchronizer - Variable in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
 
syslogToMap() - Static method in class org.springframework.integration.dsl.support.Transformers
 

T

t1 - Variable in class org.springframework.integration.dsl.support.tuple.Tuple1
 
t2 - Variable in class org.springframework.integration.dsl.support.tuple.Tuple2
 
tail(File) - Method in class org.springframework.integration.dsl.MessageProducers
 
tailAdapter(File) - Static method in class org.springframework.integration.dsl.file.Files
 
TailAdapterSpec - Class in org.springframework.integration.dsl.file
A MessageProducerSpec for file tailing adapters.
target - Variable in class org.springframework.integration.dsl.core.IntegrationComponentSpec
 
taskExecutor(Executor) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
Configure an Executor used to invoke the message listener.
taskExecutor(Executor) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
Configure an Executor used to invoke the message listener.
taskExecutor(Executor) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
Configure an Executor used to invoke the message listener.
taskExecutor(Executor) - Method in class org.springframework.integration.dsl.core.PollerSpec
Specify an Executor to perform the pollingTask.
taskExecutor(TaskExecutor) - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
Configure a task executor.
taskExecutor(Executor) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
Specify an Executor.
taskExecutor(Executor) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
Only applies if the JmsMessageChannelSpec.containerType(Class) is a DefaultMessageListenerContainer or a SimpleMessageListenerContainer.
taskExecutor(Executor) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
 
taskScheduler(TaskScheduler) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
 
taskScheduler(TaskScheduler) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
Specify a TaskScheduler for flush task when the FileExistsMode.APPEND_NO_FLUSH is in use.
taskScheduler(TaskScheduler) - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
Set a task scheduler - defaults to the integration 'taskScheduler'.
templateChannelTransacted(boolean) - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
Configure channelTransacted on the RabbitTemplate used when sending messages to the channel.
temporaryFileSuffix(String) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
temporaryFileSuffix(String) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
 
temporaryFileSuffix(String) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
Configure a suffix to temporarily apply to the local filename; when copied the file is renamed to its final name.
temporaryFileSuffix(String) - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
 
temporaryRemoteDirectory(String) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
temporaryRemoteDirectory(Function<Message<P>, String>) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
temporaryRemoteDirectoryExpression(String) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
throwExceptionOnRejection(boolean) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
The default value is false meaning that rejected Messages will be quietly dropped or sent to the discard channel if available.
timeout(long) - Method in class org.springframework.integration.dsl.channel.WireTapSpec
 
timeout(int) - Method in class org.springframework.integration.dsl.transaction.TransactionInterceptorBuilder
 
timeToLive(long) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
 
timeToLive(long) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
 
timeToLive(long) - Method in class org.springframework.integration.dsl.jms.JmsTemplateSpec
 
to(String...) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
toArray() - Method in class org.springframework.integration.dsl.support.tuple.Tuple
Turn this Tuple into a plain Object array.
toArray() - Method in class org.springframework.integration.dsl.support.tuple.Tuple1
 
toArray() - Method in class org.springframework.integration.dsl.support.tuple.Tuple2
 
toExpression(String) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
toFunction(Function<Message<P>, String[]>) - Method in class org.springframework.integration.dsl.mail.MailHeadersBuilder
 
toJson() - Static method in class org.springframework.integration.dsl.support.Transformers
 
toJson(JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.support.Transformers
 
toJson(JsonObjectMapper<?, ?>, ObjectToJsonTransformer.ResultType) - Static method in class org.springframework.integration.dsl.support.Transformers
 
toJson(String) - Static method in class org.springframework.integration.dsl.support.Transformers
 
toJson(JsonObjectMapper<?, ?>, String) - Static method in class org.springframework.integration.dsl.support.Transformers
 
toJson(ObjectToJsonTransformer.ResultType, String) - Static method in class org.springframework.integration.dsl.support.Transformers
 
toJson(JsonObjectMapper<?, ?>, ObjectToJsonTransformer.ResultType, String) - Static method in class org.springframework.integration.dsl.support.Transformers
 
toList() - Method in class org.springframework.integration.dsl.support.tuple.Tuple
Turn this Tuple into a plain Object list.
toMap() - Static method in class org.springframework.integration.dsl.support.Transformers
 
toMap(boolean) - Static method in class org.springframework.integration.dsl.support.Transformers
 
topic(String) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Configure the Kafka topic to send messages.
topic(Function<Message<P>, String>) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Configure a Function that will be invoked at run time to determine the topic to which a message will be sent.
topicExpression(String) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Configure a SpEL expression to determine the Kafka topic at runtime against request Message as a root object of evaluation context.
topicExpression(Expression) - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
Configure an Expression to determine the Kafka topic at runtime against request Message as a root object of evaluation context.
toReactivePublisher() - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Represent an Integration Flow as a Reactive Streams Publisher bean.
toReactivePublisher(Executor) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Represent an Integration Flow as a Reactive Streams Publisher bean.
toString() - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
toString() - Method in class org.springframework.integration.dsl.support.tuple.Tuple1
 
toString() - Method in class org.springframework.integration.dsl.support.tuple.Tuple2
 
transactional(PlatformTransactionManager) - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
Specify a TransactionInterceptor Advice with the provided PlatformTransactionManager and default DefaultTransactionAttribute for the pollingTask.
transactional(PlatformTransactionManager, boolean) - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
Specify a TransactionInterceptor Advice with the provided PlatformTransactionManager and default DefaultTransactionAttribute for the pollingTask.
transactional(TransactionInterceptor) - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
Specify a TransactionInterceptor Advice for the pollingTask.
transactional() - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
Specify a TransactionInterceptor Advice with default PlatformTransactionManager and DefaultTransactionAttribute for the pollingTask.
transactional(boolean) - Method in class org.springframework.integration.dsl.core.ConsumerEndpointSpec
Specify a TransactionInterceptor Advice with default PlatformTransactionManager and DefaultTransactionAttribute for the pollingTask.
transactional(PlatformTransactionManager) - Method in class org.springframework.integration.dsl.core.PollerSpec
Specify a TransactionInterceptor Advice with the provided PlatformTransactionManager and default DefaultTransactionAttribute for the pollingTask.
transactional() - Method in class org.springframework.integration.dsl.core.PollerSpec
Specify a TransactionInterceptor Advice with default PlatformTransactionManager and DefaultTransactionAttribute for the pollingTask.
transactional(TransactionInterceptor) - Method in class org.springframework.integration.dsl.core.PollerSpec
Specify a TransactionInterceptor Advice for the pollingTask.
transactionAttribute(TransactionAttribute) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
Configure a TransactionAttribute to be used with the AmqpMessageChannelSpec.transactionManager(PlatformTransactionManager).
transactionAttribute(TransactionAttribute) - Method in class org.springframework.integration.dsl.transaction.TransactionInterceptorBuilder
 
TransactionHandleMessageAdvice - Class in org.springframework.integration.dsl.transaction
A TransactionInterceptor extension with HandleMessageAdvice marker.
TransactionHandleMessageAdvice() - Constructor for class org.springframework.integration.dsl.transaction.TransactionHandleMessageAdvice
 
TransactionHandleMessageAdvice(PlatformTransactionManager, Properties) - Constructor for class org.springframework.integration.dsl.transaction.TransactionHandleMessageAdvice
 
TransactionHandleMessageAdvice(PlatformTransactionManager, TransactionAttributeSource) - Constructor for class org.springframework.integration.dsl.transaction.TransactionHandleMessageAdvice
 
TransactionInterceptorBuilder - Class in org.springframework.integration.dsl.transaction
Provides a fluent API to build a transaction interceptor.
TransactionInterceptorBuilder() - Constructor for class org.springframework.integration.dsl.transaction.TransactionInterceptorBuilder
 
TransactionInterceptorBuilder(boolean) - Constructor for class org.springframework.integration.dsl.transaction.TransactionInterceptorBuilder
 
transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
Configure a PlatformTransactionManager; used to synchronize the rabbit transaction with some other transaction(s).
transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
Configure a PlatformTransactionManager; used to synchronize the rabbit transaction with some other transaction(s).
transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
Configure a PlatformTransactionManager; used to synchronize the rabbit transaction with some other transaction(s).
transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
A PlatformTransactionManager reference.
transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
Only applies if the JmsMessageChannelSpec.containerType(Class) is a DefaultMessageListenerContainer.
transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.dsl.transaction.TransactionInterceptorBuilder
 
transactionName(String) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
A name for transaction.
transactionName(String) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
Only applies if the JmsMessageChannelSpec.containerType(Class) is a DefaultMessageListenerContainer.
transactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.dsl.core.PollerSpec
Specify the TransactionSynchronizationFactory to attach a TransactionSynchronization to the transaction around poll operation.
transactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
Configure a TransactionSynchronizationFactory.
transactionTimeout(int) - Method in class org.springframework.integration.dsl.jms.JmsDefaultListenerContainerSpec
A transaction timeout.
transactionTimeout(int) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
Only applies if the JmsMessageChannelSpec.containerType(Class) is a DefaultMessageListenerContainer.
transferCookies(boolean) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
transform(String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the Transformer EI Pattern specific MessageHandler implementation for the SpEL Expression.
transform(String, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the Transformer EI Pattern specific MessageHandler implementation for the SpEL Expression.
transform(Object) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler for the MethodInvokingTransformer to invoke the discovered service method at runtime.
transform(Object, String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler for the MethodInvokingTransformer to invoke the service method at runtime.
transform(Object, String, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler for the MethodInvokingTransformer to invoke the service method at runtime.
transform(GenericTransformer<S, T>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the provided GenericTransformer.
transform(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the MessageProcessor from provided MessageProcessorSpec.
transform(MessageProcessorSpec<?>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the MessageProcessor from provided MessageProcessorSpec.
transform(Class<P>, GenericTransformer<P, T>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the provided GenericTransformer for the specific payloadType to convert at runtime.
transform(GenericTransformer<S, T>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the provided GenericTransformer.
transform(Class<P>, GenericTransformer<P, T>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the MessageTransformingHandler instance for the provided GenericTransformer for the specific payloadType to convert at runtime.
Transformers - Class in org.springframework.integration.dsl.support
An utility class to provide methods for out-of-the-box Transformers.
Transformers() - Constructor for class org.springframework.integration.dsl.support.Transformers
 
trigger(Trigger) - Method in class org.springframework.integration.dsl.core.PollerFactory
 
trigger(Trigger) - Static method in class org.springframework.integration.dsl.core.Pollers
 
trigger(String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler instance to perform MessageTriggerAction.
trigger(String, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler instance to perform MessageTriggerAction and endpoint options from GenericEndpointSpec.
trigger(MessageTriggerAction) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler instance to perform MessageTriggerAction.
trigger(MessageTriggerAction, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate a ServiceActivatingHandler instance to perform MessageTriggerAction and endpoint options from GenericEndpointSpec.
Tuple - Class in org.springframework.integration.dsl.support.tuple
A Tuple is an immutable Collection of objects, each of which can be of an arbitrary type.
Tuple(int) - Constructor for class org.springframework.integration.dsl.support.tuple.Tuple
Creates a new Tuple that holds the given values.
Tuple1<T1> - Class in org.springframework.integration.dsl.support.tuple
A tuple that holds a single value.
Tuple2<T1,T2> - Class in org.springframework.integration.dsl.support.tuple
A tuple that holds two values.
Tuples - Class in org.springframework.integration.dsl.support.tuple
The Tuple factory.
Tuples() - Constructor for class org.springframework.integration.dsl.support.tuple.Tuples
 
txSize(int) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
 
txSize(int) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
 
txSize(int) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
Configure the txSize.

U

unmarshaller(Unmarshaller) - Static method in class org.springframework.integration.dsl.support.Transformers
 
unmarshaller(Unmarshaller, SourceFactory) - Static method in class org.springframework.integration.dsl.support.Transformers
 
unmarshaller(Unmarshaller, boolean) - Static method in class org.springframework.integration.dsl.support.Transformers
 
unmarshaller(Unmarshaller, SourceFactory, boolean) - Static method in class org.springframework.integration.dsl.support.Transformers
 
updatingGateway(EntityManagerFactory) - Static method in class org.springframework.integration.dsl.jpa.Jpa
 
updatingGateway(EntityManager) - Static method in class org.springframework.integration.dsl.jpa.Jpa
 
updatingGateway(JpaOperations) - Static method in class org.springframework.integration.dsl.jpa.Jpa
 
uriVariable(String, Expression) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
uriVariable(String, String) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
uriVariable(String, Function<Message<P>, ?>) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
uriVariableExpressions(Map<String, Expression>) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
uriVariablesExpression(Expression) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
uriVariablesExpression(String) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
uriVariablesFunction(Function<Message<P>, Map<String, ?>>) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
 
usePayloadAsParameterSource(Boolean) - Method in class org.springframework.integration.dsl.jpa.JpaBaseOutboundEndpointSpec
 
userFlag(String) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
Set the name of the flag to use to flag messages when the server does not support \Recent but supports user flags; default .
userFlag(String) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
Set the name of the flag to use to flag messages when the server does not support \Recent but supports user flags; default .
useTemporaryFileName(boolean) - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
 
useWatchService(boolean) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
Switch this FileReadingMessageSource to use its internal WatchService directory scanner.

V

variable(String, Object) - Method in class org.springframework.integration.dsl.scripting.ScriptMessageSourceSpec
The script variable to use.
variable(String, Object) - Method in class org.springframework.integration.dsl.scripting.ScriptSpec
The script variable to use.
variableGenerator(ScriptVariableGenerator) - Method in class org.springframework.integration.dsl.scripting.ScriptMessageSourceSpec
The ScriptVariableGenerator to use.
variableGenerator(ScriptVariableGenerator) - Method in class org.springframework.integration.dsl.scripting.ScriptSpec
The ScriptVariableGenerator to use.
variables(MapBuilder<?, String, Object>) - Method in class org.springframework.integration.dsl.scripting.ScriptMessageSourceSpec
The script variables to use.
variables(Map<String, Object>) - Method in class org.springframework.integration.dsl.scripting.ScriptMessageSourceSpec
The script variables to use.
variables(MapBuilder<?, String, Object>) - Method in class org.springframework.integration.dsl.scripting.ScriptSpec
The script variables to use.
variables(Map<String, Object>) - Method in class org.springframework.integration.dsl.scripting.ScriptSpec
The script variables to use

W

watchEvents(FileReadingMessageSource.WatchEventType...) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
The WatchService event types.
wireTap(String) - Method in class org.springframework.integration.dsl.channel.MessageChannelSpec
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation.
wireTap(MessageChannel) - Method in class org.springframework.integration.dsl.channel.MessageChannelSpec
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation.
wireTap(WireTapSpec) - Method in class org.springframework.integration.dsl.channel.MessageChannelSpec
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation.
wireTap(IntegrationFlow) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current IntegrationFlowDefinition.currentMessageChannel.
wireTap(String) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current IntegrationFlowDefinition.currentMessageChannel.
wireTap(MessageChannel) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current IntegrationFlowDefinition.currentMessageChannel.
wireTap(IntegrationFlow, Consumer<WireTapSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current IntegrationFlowDefinition.currentMessageChannel.
wireTap(String, Consumer<WireTapSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current IntegrationFlowDefinition.currentMessageChannel.
wireTap(MessageChannel, Consumer<WireTapSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current IntegrationFlowDefinition.currentMessageChannel.
wireTap(WireTapSpec) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
Populate the Wire Tap EI Pattern specific ChannelInterceptor implementation to the current IntegrationFlowDefinition.currentMessageChannel.
WireTapSpec - Class in org.springframework.integration.dsl.channel
The IntegrationComponentSpec implementation for the WireTap component.
WireTapSpec(MessageChannel) - Constructor for class org.springframework.integration.dsl.channel.WireTapSpec
 
WireTapSpec(String) - Constructor for class org.springframework.integration.dsl.channel.WireTapSpec
 

X

xmlSource() - Static method in class org.springframework.integration.dsl.support.Transformers
 
xmlSource(SourceFactory) - Static method in class org.springframework.integration.dsl.support.Transformers
 
xpath(String) - Static method in class org.springframework.integration.dsl.support.Transformers
 
xpath(String, XPathEvaluationType) - Static method in class org.springframework.integration.dsl.support.Transformers
 
xpath(String, NodeMapper<?>) - Static method in class org.springframework.integration.dsl.support.Transformers
 
xpath(String, XPathEvaluationType, NodeMapper<?>) - Static method in class org.springframework.integration.dsl.support.Transformers
 
xslt(Resource, Tuple2<String, Expression>...) - Static method in class org.springframework.integration.dsl.support.Transformers
 

_

_this() - Method in class org.springframework.integration.dsl.core.IntegrationComponentSpec
 
_this() - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
 
_this() - Method in class org.springframework.integration.dsl.support.MapBuilder
 
A B C D E F G H I J K L M N O P Q R S T U V W X _ 
Skip navigation links
Spring Integration Java DSL