- cacheLevel(Integer) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
-
- cacheLevel(Integer) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
-
- 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
-
- 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
-
- 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
-
- channel(String, ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
-
- channelMapping(String, 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.
- clientId(String) - Method in class org.springframework.integration.dsl.jms.JmsListenerContainerSpec
-
- clientId(String) - Method in class org.springframework.integration.dsl.jms.JmsPublishSubscribeMessageChannelSpec
-
- 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.
- concurrency(int) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
-
Specify a concurrency maximum number for the KafkaMessageListenerContainer
.
- 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.JmsMessageChannelSpec
-
- 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<C>>) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec
-
- configureListenerContainer(Consumer<JmsListenerContainerSpec<C>>) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
-
- configureListenerContainer(Consumer<KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec>) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
-
- confirmAckChannel(MessageChannel) - Method in class org.springframework.integration.dsl.amqp.AmqpOutboundEndpointSpec
-
- confirmCorrelationExpression(String) - Method in class org.springframework.integration.dsl.amqp.AmqpOutboundEndpointSpec
-
- confirmNackChannel(MessageChannel) - Method in class org.springframework.integration.dsl.amqp.AmqpOutboundEndpointSpec
-
- 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
-
- ConsumerEndpointSpec(H) - Constructor for class org.springframework.integration.dsl.core.ConsumerEndpointSpec
-
- consumerProperties(Properties) - Method in class org.springframework.integration.dsl.kafka.KafkaHighLevelConsumerMessageSourceSpec
-
- consumerProperties(Consumer<PropertiesBuilder>) - Method in class org.springframework.integration.dsl.kafka.KafkaHighLevelConsumerMessageSourceSpec
-
- consumerTimeout(int) - Method in class org.springframework.integration.dsl.kafka.KafkaHighLevelConsumerMessageSourceSpec.ConsumerMetadataSpec
-
Specify the Kafka High Level Consumer consumer.timeout.ms
property.
- 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
-
- container(ConnectionFactory, String) - Static method in class org.springframework.integration.dsl.jms.Jms
-
- containerType(Class<? extends AbstractMessageListenerContainer>) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
-
Configure the type of the container; must be an
AbstractMessageListenerContainer
.
- 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
-
- 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(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
-
- datatype(Class<?>...) - Method in class org.springframework.integration.dsl.channel.MessageChannelSpec
-
- defaultDelay(long) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
-
- defaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.dsl.amqp.AmqpOutboundEndpointSpec
-
- defaultEncoding(String) - Method in class org.springframework.integration.dsl.mail.MailSendingMessageHandlerSpec
-
- defaultFileTypeMap(FileTypeMap) - Method in class org.springframework.integration.dsl.mail.MailSendingMessageHandlerSpec
-
- 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
-
- 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
-
- 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
-
- deleteRemoteFiles(boolean) - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
-
- deleteSourceFiles(boolean) - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
-
- 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
-
- 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
-
- 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.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
-
- discardChannel(String) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
-
- discardFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
-
- discardWithinAdvice(boolean) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
-
- doGet() - Method in class org.springframework.integration.dsl.AbstractRouterSpec
-
- doGet() - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
-
- doGet() - Method in class org.springframework.integration.dsl.amqp.AmqpOutboundEndpointSpec
-
- doGet() - Method in class org.springframework.integration.dsl.amqp.AmqpPollableMessageChannelSpec
-
- 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.core.EndpointSpec
-
- doGet() - Method in class org.springframework.integration.dsl.core.IntegrationComponentSpec
-
- doGet() - Method in class org.springframework.integration.dsl.core.MessageProducerSpec
-
- doGet() - Method in class org.springframework.integration.dsl.core.MessagingGatewaySpec
-
- doGet() - Method in class org.springframework.integration.dsl.core.PollerSpec
-
- doGet() - Method in class org.springframework.integration.dsl.EnricherSpec
-
- doGet() - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
-
- doGet() - Method in class org.springframework.integration.dsl.file.FileSplitterSpec
-
- doGet() - Method in class org.springframework.integration.dsl.file.FileTransferringMessageHandlerSpec
-
- doGet() - Method in class org.springframework.integration.dsl.file.FileWritingMessageHandlerSpec
-
- doGet() - Method in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
-
- doGet() - Method in class org.springframework.integration.dsl.file.RemoteFileOutboundGatewaySpec
-
- doGet() - Method in class org.springframework.integration.dsl.file.TailAdapterSpec
-
- doGet() - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
- doGet() - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
-
- doGet() - Method in class org.springframework.integration.dsl.jms.JmsDestinationAccessorSpec
-
- doGet() - Method in class org.springframework.integration.dsl.jms.JmsInboundChannelAdapterSpec
-
- doGet() - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
-
- doGet() - Method in class org.springframework.integration.dsl.jms.JmsOutboundChannelAdapterSpec
-
- doGet() - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
-
- doGet() - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
-
- doGet() - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
-
- doGet() - Method in class org.springframework.integration.dsl.kafka.KafkaHighLevelConsumerMessageSourceSpec
-
- doGet() - Method in class org.springframework.integration.dsl.kafka.KafkaProducerMessageHandlerSpec
-
- doGet() - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
-
- doGet() - Method in class org.springframework.integration.dsl.mail.MailSendingMessageHandlerSpec
-
- doGet() - Method in class org.springframework.integration.dsl.scripting.ScriptMessageSourceSpec
-
- doGet() - Method in class org.springframework.integration.dsl.scripting.ScriptSpec
-
- doGet() - Method in class org.springframework.integration.dsl.WireTapSpec
-
- 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
-
- failover - Variable in class org.springframework.integration.dsl.channel.LoadBalancingChannelSpec
-
- failover(Boolean) - Method in class org.springframework.integration.dsl.channel.LoadBalancingChannelSpec
-
- fetchTaskExecutor(Executor) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
-
Specify an Executor
for fetch tasks for the KafkaMessageListenerContainer
.
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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) - Static method in class org.springframework.integration.dsl.IntegrationFlowAdapter
-
- from(Object, String, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlowAdapter
-
- from(String) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(String, boolean) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(IntegrationFlows.ChannelsFunction) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(MessageChannelSpec<?, ?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(MessageChannel) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(IntegrationFlows.MessageSourcesFunction) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(IntegrationFlows.MessageSourcesFunction, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(MessageSourceSpec<?, ? extends MessageSource<?>>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(MessageSourceSpec<?, ? extends MessageSource<?>>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- 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
-
- from(MessageSource<?>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(IntegrationFlows.MessageProducersFunction) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(MessageProducerSpec<?, ?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(MessageProducerSupport) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(IntegrationFlows.MessagingGatewaysFunction) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(MessagingGatewaySpec<?, ?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- from(MessagingGatewaySupport) - Static method in class org.springframework.integration.dsl.IntegrationFlows
-
- 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
-
- Ftp() - Constructor for class org.springframework.integration.dsl.ftp.Ftp
-
- 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
-
- 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
-
- 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
-
- FunctionExpression(Function<S, ?>) - Constructor for class org.springframework.integration.dsl.support.FunctionExpression
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- headerFilter(String, boolean) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
-
- 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.
- headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseInboundChannelAdapterSpec
-
Configure the adapter's AmqpHeaderMapper
;
defaults to DefaultAmqpHeaderMapper
.
- headerMapper - Variable in class org.springframework.integration.dsl.amqp.AmqpBaseInboundGatewaySpec
-
- headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.dsl.amqp.AmqpBaseInboundGatewaySpec
-
Configure the gateway's AmqpHeaderMapper
; defaults to
DefaultAmqpHeaderMapper
.
- headerMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.dsl.amqp.AmqpOutboundEndpointSpec
-
- 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.JmsOutboundChannelAdapterSpec
-
- headerMapper(JmsHeaderMapper) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec
-
- 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() - Constructor for class org.springframework.integration.dsl.http.Http
-
- 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
-
- 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
-
- 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
-
- mail(String) - Method in class org.springframework.integration.dsl.Adapters
-
- Mail - Class in org.springframework.integration.dsl.mail
-
- Mail() - Constructor for class org.springframework.integration.dsl.mail.Mail
-
- MailHeadersBuilder - Class in org.springframework.integration.dsl.mail
-
- MailInboundChannelAdapterSpec<S extends MailInboundChannelAdapterSpec<S,R>,R extends org.springframework.integration.mail.AbstractMailReceiver> - Class in org.springframework.integration.dsl.mail
-
- MailInboundChannelAdapterSpec() - 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.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.AmqpOutboundEndpointSpec
-
- 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
-
- 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(Integer) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
-
- maxFetch(int) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
-
Specify a max fetch for the KafkaMessageListenerContainer
.
- maxFetchSize(int) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
-
- maxFetchSize(int) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
-
- maxMessages(int) - Method in class org.springframework.integration.dsl.kafka.KafkaHighLevelConsumerMessageSourceSpec.ConsumerMetadataSpec
-
- maxMessagesPerPoll(long) - Method in class org.springframework.integration.dsl.core.PollerSpec
-
- maxMessagesPerTask(int) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
-
- maxMessagesPerTask(Integer) - Method in class org.springframework.integration.dsl.jms.JmsOutboundGatewaySpec.ReplyContainerSpec
-
- 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
-
- messageConverters(HttpMessageConverter<?>...) - Method in class org.springframework.integration.dsl.http.BaseHttpInboundEndpointSpec
-
- messageConverters(HttpMessageConverter<?>...) - Method in class org.springframework.integration.dsl.http.HttpMessageHandlerSpec
-
- 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
-
- messageDriverChannelAdapter(KafkaMessageListenerContainer) - Static method in class org.springframework.integration.dsl.kafka.Kafka
-
- messageDriverChannelAdapter(ConnectionFactory, Partition...) - Static method in class org.springframework.integration.dsl.kafka.Kafka
-
- messageDriverChannelAdapter(ConnectionFactory, String...) - Static method in class org.springframework.integration.dsl.kafka.Kafka
-
- MessageHandlerSpec<S extends MessageHandlerSpec<S,H>,H extends org.springframework.messaging.MessageHandler> - Class in org.springframework.integration.dsl.core
-
- MessageHandlerSpec() - Constructor for class org.springframework.integration.dsl.core.MessageHandlerSpec
-
- messageIdEnabled(boolean) - Method in class org.springframework.integration.dsl.jms.JmsPollableMessageChannelSpec
-
- 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 s SpEL 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
-
- MessageProcessorMessageSource(MessageProcessor<?>) - Constructor for class org.springframework.integration.dsl.support.MessageProcessorMessageSource
-
- MessageProcessorSpec<S extends MessageProcessorSpec<S>> - Class in org.springframework.integration.dsl.core
-
- 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
-
- 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 MessageSourceSpec
s from Namespace Factories.
- MessageSourceSpec<S extends MessageSourceSpec<S,H>,H extends org.springframework.integration.core.MessageSource<?>> - Class in org.springframework.integration.dsl.core
-
- 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
-
- MessagingGatewaySpec(G) - Constructor for class org.springframework.integration.dsl.core.MessagingGatewaySpec
-
- 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
-
- 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
-
- 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.
- offsetManager(OffsetManager) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
-
Specify an OffsetManager
for the KafkaMessageListenerContainer
.
- 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.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.core - package org.springframework.integration.dsl.core
-
Provides core classes of the 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.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.
- 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(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
-
- outboundAdapter(ConnectionFactory) - Static method in class org.springframework.integration.dsl.jms.Jms
-
- 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() - Static method in class org.springframework.integration.dsl.kafka.Kafka
-
- outboundChannelAdapter(Consumer<PropertiesBuilder>) - Static method in class org.springframework.integration.dsl.kafka.Kafka
-
- outboundChannelAdapter(Properties) - Static method in class org.springframework.integration.dsl.kafka.Kafka
-
- 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(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
-
- 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
-
- 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
-
- outputChannel(MessageChannel) - Method in class org.springframework.integration.dsl.core.MessageProducerSpec
-
Specify 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.
- 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.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, 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) - 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, 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'.
- 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(String, 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
-
- 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.JmsMessageChannelSpec
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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.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
-
- 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
-
- returnChannel(MessageChannel) - Method in class org.springframework.integration.dsl.amqp.AmqpOutboundEndpointSpec
-
- 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<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<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<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<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<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<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<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>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
-
Populate the
MethodInvokingRouter
for provided
Function
and payload type with default options.
- route(Class<P>, Function<P, T>, Consumer<RouterSpec<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<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<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<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<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<R>>, Consumer<GenericEndpointSpec<R>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
-
- 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<R extends org.springframework.integration.router.AbstractMappingMessageRouter> - Class in org.springframework.integration.dsl
-
- routeToRecipients(Consumer<RecipientListRouterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
-
- routeToRecipients(Consumer<RecipientListRouterSpec>, Consumer<GenericEndpointSpec<RecipientListRouter>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
-
- routingKey(String) - Method in class org.springframework.integration.dsl.amqp.AmqpOutboundEndpointSpec
-
- routingKeyExpression(String) - Method in class org.springframework.integration.dsl.amqp.AmqpOutboundEndpointSpec
-
- scanEachPoll(boolean) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
-
- scanner(DirectoryScanner) - Method in class org.springframework.integration.dsl.file.FileInboundChannelAdapterSpec
-
- script(Resource) - Method in class org.springframework.integration.dsl.MessageSources
-
- script(String) - Method in class org.springframework.integration.dsl.MessageSources
-
- 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
-
- 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
-
- searchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
-
- searchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.dsl.mail.ImapMailInboundChannelAdapterSpec
-
- 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.
- selector(String) - Method in class org.springframework.integration.dsl.WireTapSpec
-
- selector(MessageSelector) - Method in class org.springframework.integration.dsl.WireTapSpec
-
- selectorExpression(String) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
-
Configure a SpEL expression to select messages.
- selectorExpression(String) - 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.core.ConsumerEndpointSpec
-
- sendTimeout(long) - Method in class org.springframework.integration.dsl.core.PollerSpec
-
- 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
-
- session(Session) - Method in class org.springframework.integration.dsl.mail.MailInboundChannelAdapterSpec
-
- sessionAcknowledgeMode(int) - Method in class org.springframework.integration.dsl.jms.JmsDestinationAccessorSpec
-
- 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
-
- sessionTransacted(boolean) - Method in class org.springframework.integration.dsl.jms.JmsDestinationAccessorSpec
-
- 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.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
-
- setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.dsl.jms.JmsInboundGatewaySpec
-
- setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.dsl.jms.JmsMessageDrivenChannelAdapterSpec
-
- setOutputChannel(MessageChannel) - 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>, 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
-
- 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
-
- shouldMarkMessagesAsRead(boolean) - Method in class org.springframework.integration.dsl.mail.ImapIdleChannelAdapterSpec
-
- shouldMarkMessagesAsRead(boolean) - Method in class org.springframework.integration.dsl.mail.ImapMailInboundChannelAdapterSpec
-
- 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
-
- 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
-
- splitter(boolean) - Static method in class org.springframework.integration.dsl.file.Files
-
- 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
-
- StandardIntegrationFlow - Class in org.springframework.integration.dsl
-
- 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
-
- stopConsumerMinInterval(long) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundChannelAdapterSpec
-
- stopConsumerMinInterval(long) - Method in class org.springframework.integration.dsl.amqp.AmqpInboundGatewaySpec
-
- stopTimeout(int) - Method in class org.springframework.integration.dsl.kafka.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
-
Specify a stop
timeout for the KafkaMessageListenerContainer
.
- 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(String, IntegrationFlow) - Method in class org.springframework.integration.dsl.RouterSpec
-
- 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
-
- suffix(String) - Method in class org.springframework.integration.dsl.RouterSpec
-
- synchronizer - Variable in class org.springframework.integration.dsl.file.RemoteFileInboundChannelAdapterSpec
-
- syslogToMap() - Static method in class org.springframework.integration.dsl.support.Transformers
-
- 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
-
- 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.JmsMessageChannelSpec
-
- 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.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
-
- timeout(long) - Method in class org.springframework.integration.dsl.WireTapSpec
-
- 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.
- 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
-
- toMap() - Static method in class org.springframework.integration.dsl.support.Transformers
-
- toMap(boolean) - Static method in class org.springframework.integration.dsl.support.Transformers
-
- 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 s SpEL expression to determine the Kafka topic at runtime against
request Message as a root object of evaluation context.
- topicFilter(String, int, boolean) - Method in class org.springframework.integration.dsl.kafka.KafkaHighLevelConsumerMessageSourceSpec.ConsumerMetadataSpec
-
- topicStreamMap(Map<String, Integer>) - Method in class org.springframework.integration.dsl.kafka.KafkaHighLevelConsumerMessageSourceSpec.ConsumerMetadataSpec
-
- topicStreamMap(Consumer<MapBuilder<?, String, Integer>>) - Method in class org.springframework.integration.dsl.kafka.KafkaHighLevelConsumerMessageSourceSpec.ConsumerMetadataSpec
-
- 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
-
- transactional(PlatformTransactionManager) - Method in class org.springframework.integration.dsl.core.PollerSpec
-
Specify a TransactionInterceptor
Advice
with the
provided PlatformTransactionManager
for the pollingTask
.
- transactionAttribute(TransactionAttribute) - Method in class org.springframework.integration.dsl.amqp.AmqpMessageChannelSpec
-
- 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.JmsMessageChannelSpec
-
- transactionName(String) - Method in class org.springframework.integration.dsl.jms.JmsMessageChannelSpec
-
- 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.JmsMessageChannelSpec
-
- 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
Transformer
s.
- 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
-
- 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(Collection<Object>) - Constructor for class org.springframework.integration.dsl.support.tuple.Tuple
-
Creates a new Tuple
that holds the given values
.
- Tuple(Object...) - 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
-
- 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
-