Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
T
- tableName(String) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
-
Specify a table in the target database to execute the query.
- tableNameExpression(String) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
-
Set a SpEL expression to evaluate a table name at runtime against request message.
- tableNameExpression(Expression) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
-
Set a SpEL expression to evaluate a table name at runtime against request message.
- tableNameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
-
Set a
Function
to evaluate a table name at runtime against request message. - tag(String, String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.CounterBuilder
-
Add a tag.
- tag(String, String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.GaugeBuilder
-
Add a tag.
- tag(String, String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.TimerBuilder
-
Add a tag.
- tag(String, String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounterBuilder
- tag(String, String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGaugeBuilder
- tag(String, String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimerBuilder
- TAG - Static variable in class org.springframework.integration.syslog.SyslogHeaders
- TAG - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
- tailAdapter(File) - Static method in class org.springframework.integration.file.dsl.Files
-
Create a
TailAdapterSpec
builder for theFileTailingMessageProducerSupport
. - TailAdapterSpec - Class in org.springframework.integration.file.dsl
-
A
MessageProducerSpec
for file tailing adapters. - TailAdapterSpec() - Constructor for class org.springframework.integration.file.dsl.TailAdapterSpec
- take() - Method in class org.springframework.integration.store.MessageGroupQueue
- takeLeadership(CuratorFramework) - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator.LeaderListener
- target - Variable in class org.springframework.integration.dsl.IntegrationComponentSpec
- TASK_SCHEDULER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- TASK_SCHEDULER_POOL_SIZE - Static variable in class org.springframework.integration.context.IntegrationProperties
-
Specifies the value of
ThreadPoolTaskScheduler.poolSize
for thetaskScheduler
bean initialized by the Integration infrastructure. - taskExecutor() - Element in annotation interface org.springframework.integration.annotation.Poller
- taskExecutor(Executor) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Configure an
Executor
used to invoke the message listener. - taskExecutor(Executor) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
Configure an
Executor
used to invoke the message listener. - taskExecutor(Executor) - Method in class org.springframework.integration.dsl.PollerSpec
-
Specify an
Executor
to perform thepollingTask
. - taskExecutor(Executor) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
- taskExecutor(Executor) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
- taskExecutor(Executor) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
Specify an
Executor
. - taskExecutor(Executor) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
-
Only applies if the
JmsMessageChannelSpec.containerType(Class)
is aDefaultMessageListenerContainer
or aSimpleMessageListenerContainer
. - taskExecutor(Executor) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
- taskExecutor(TaskExecutor) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
-
Configure a task executor.
- taskScheduler(TaskScheduler) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
-
Configure a
TaskScheduler
for scheduling tasks, for example in the Polling Consumer. - taskScheduler(TaskScheduler) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- taskScheduler(TaskScheduler) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
-
Specify a
TaskScheduler
for flush task when theFileExistsMode.APPEND_NO_FLUSH
is in use. - taskScheduler(TaskScheduler) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
-
Set a task scheduler - defaults to the integration 'taskScheduler'.
- taskScheduler(TaskScheduler) - Method in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
- taskScheduler(TaskScheduler) - Method in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
- taskScheduler(TaskScheduler) - Method in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
- taskScheduler(TaskScheduler) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
- taskScheduler(TaskScheduler) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec
- tcp - Enum constant in enum class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean.Protocol
- Tcp - Class in org.springframework.integration.ip.dsl
-
Factory methods for TCP.
- TcpClientConnectionFactorySpec<S extends TcpClientConnectionFactorySpec<S,
C>, C extends AbstractClientConnectionFactory> - Class in org.springframework.integration.ip.dsl - TcpClientConnectionFactorySpec(C) - Constructor for class org.springframework.integration.ip.dsl.TcpClientConnectionFactorySpec
-
Create an instance.
- TcpClientConnectionFactorySpec(String, int) - Constructor for class org.springframework.integration.ip.dsl.TcpClientConnectionFactorySpec
-
Deprecated.since 6.0.3; use a subclass.
- TcpClientConnectionFactorySpec(String, int, boolean) - Constructor for class org.springframework.integration.ip.dsl.TcpClientConnectionFactorySpec
-
Deprecated.since 6.0.3; use a subclass.
- TcpCodecs - Class in org.springframework.integration.ip.tcp.serializer
-
Factory class to create TCP Serializer/Deserializers used to encode/decode messages to/from a TCP stream.
- TcpConnection - Interface in org.springframework.integration.ip.tcp.connection
-
An abstraction over
Socket
andSocketChannel
that sendsMessage
objects by serializing the payload and streaming it to the destination. - TcpConnectionCloseEvent - Class in org.springframework.integration.ip.tcp.connection
- TcpConnectionCloseEvent(TcpConnection, String) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionCloseEvent
- TcpConnectionEvent - Class in org.springframework.integration.ip.tcp.connection
-
ApplicationEvent representing normal operations on a
TcpConnection
. - TcpConnectionEvent(TcpConnection, String) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionEvent
- TcpConnectionEvent(TcpConnection, String, Throwable) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionEvent
- TcpConnectionExceptionEvent - Class in org.springframework.integration.ip.tcp.connection
-
ApplicationEvent representing exceptions on a
TcpConnection
. - TcpConnectionExceptionEvent(TcpConnection, String, Throwable) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionExceptionEvent
- TcpConnectionFactoryFactoryBean - Class in org.springframework.integration.ip.config
-
Instantiates a TcpN(et|io)(Server|Client)ConnectionFactory, depending on type and using-nio attributes.
- TcpConnectionFactoryFactoryBean() - Constructor for class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
- TcpConnectionFactoryFactoryBean(String) - Constructor for class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
- TcpConnectionFactoryParser - Class in org.springframework.integration.ip.config
- TcpConnectionFactoryParser() - Constructor for class org.springframework.integration.ip.config.TcpConnectionFactoryParser
- TcpConnectionFailedCorrelationEvent - Class in org.springframework.integration.ip.tcp.connection
-
An event emitted when an endpoint cannot correlate a connection id to a connection; the cause is a messaging exception with the failed message.
- TcpConnectionFailedCorrelationEvent(Object, String, MessagingException) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionFailedCorrelationEvent
- TcpConnectionFailedEvent - Class in org.springframework.integration.ip.tcp.connection
-
An event emitted when a connection could not be established for some reason.
- TcpConnectionFailedEvent(Object, Throwable) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionFailedEvent
- TcpConnectionInterceptor - Interface in org.springframework.integration.ip.tcp.connection
- TcpConnectionInterceptorFactory - Interface in org.springframework.integration.ip.tcp.connection
-
Interface for TCP connection interceptor factories.
- TcpConnectionInterceptorFactoryChain - Class in org.springframework.integration.ip.tcp.connection
- TcpConnectionInterceptorFactoryChain() - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactoryChain
- TcpConnectionInterceptorSupport - Class in org.springframework.integration.ip.tcp.connection
-
Base class for
TcpConnectionInterceptor
s; passes all method calls through to the underlyingTcpConnection
. - TcpConnectionInterceptorSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- TcpConnectionInterceptorSupport(ApplicationEventPublisher) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- TcpConnectionOpenEvent - Class in org.springframework.integration.ip.tcp.connection
- TcpConnectionOpenEvent(TcpConnection, String) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionOpenEvent
- TcpConnectionServerExceptionEvent - Class in org.springframework.integration.ip.tcp.connection
-
IpIntegrationEvent
representing exceptions on a TCP server socket/channel. - TcpConnectionServerExceptionEvent(Object, Throwable) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionServerExceptionEvent
- TcpConnectionServerListeningEvent - Class in org.springframework.integration.ip.tcp.connection
-
IpIntegrationEvent
emitted when a server begins listening. - TcpConnectionServerListeningEvent(TcpServerConnectionFactory, int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionServerListeningEvent
- TcpConnectionSupport - Class in org.springframework.integration.ip.tcp.connection
-
Base class for TcpConnections.
- TcpConnectionSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
- TcpConnectionSupport(Socket, boolean, boolean, ApplicationEventPublisher, String) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
Create a
TcpConnectionSupport
object and publishes aTcpConnectionOpenEvent
, if an event publisher is provided. - TcpConnectionSupport(ApplicationEventPublisher) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
- TcpDeserializationExceptionEvent - Class in org.springframework.integration.ip.tcp.serializer
-
Event representing an exception while decoding an incoming stream.
- TcpDeserializationExceptionEvent(Object, Throwable, byte[], int) - Constructor for class org.springframework.integration.ip.tcp.serializer.TcpDeserializationExceptionEvent
- TcpInboundChannelAdapterParser - Class in org.springframework.integration.ip.config
-
Channel Adapter that receives TCP stream frames and maps them to Messages.
- TcpInboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.TcpInboundChannelAdapterParser
- TcpInboundChannelAdapterSpec - Class in org.springframework.integration.ip.dsl
- TcpInboundChannelAdapterSpec(AbstractConnectionFactorySpec<?, ?>) - Constructor for class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
-
Construct an instance using the provided connection factory spec.
- TcpInboundChannelAdapterSpec(AbstractConnectionFactory) - Constructor for class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
-
Construct an instance using an existing spring-managed connection factory.
- TcpInboundGateway - Class in org.springframework.integration.ip.tcp
-
Inbound Gateway using a server connection factory - threading is controlled by the factory.
- TcpInboundGateway() - Constructor for class org.springframework.integration.ip.tcp.TcpInboundGateway
- TcpInboundGatewayParser - Class in org.springframework.integration.ip.config
- TcpInboundGatewayParser() - Constructor for class org.springframework.integration.ip.config.TcpInboundGatewayParser
- TcpInboundGatewaySpec - Class in org.springframework.integration.ip.dsl
- TcpInboundGatewaySpec(AbstractConnectionFactorySpec<?, ?>) - Constructor for class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
-
Construct an instance using a connection factory spec.
- TcpInboundGatewaySpec(AbstractConnectionFactory) - Constructor for class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
-
Construct an instance using an existing spring-managed connection factory.
- TcpListener - Interface in org.springframework.integration.ip.tcp.connection
-
Classes that implement this interface may register with a connection factory to receive messages retrieved from a
TcpConnection
. - TcpMessageMapper - Class in org.springframework.integration.ip.tcp.connection
-
Maps incoming data from a
TcpConnection
to aMessage
. - TcpMessageMapper() - Constructor for class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
- TcpNetClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
-
A client connection factory that creates
TcpNetConnection
s. - TcpNetClientConnectionFactory(String, int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
-
Creates a TcpNetClientConnectionFactory for connections to the host and port.
- TcpNetClientConnectionFactorySpec - Class in org.springframework.integration.ip.dsl
- TcpNetClientConnectionFactorySpec(String, int) - Constructor for class org.springframework.integration.ip.dsl.TcpNetClientConnectionFactorySpec
- TcpNetConnection - Class in org.springframework.integration.ip.tcp.connection
-
A TcpConnection that uses and underlying
Socket
. - TcpNetConnection(Socket, boolean, boolean, ApplicationEventPublisher, String) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNetConnection
-
Construct a TcpNetConnection for the socket.
- TcpNetConnectionSupport - Interface in org.springframework.integration.ip.tcp.connection
-
Used by NET connection factories to instantiate a
TcpNetConnection
object. - TcpNetServerConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
-
Implements a server connection factory that produces
TcpNetConnection
s using aServerSocket
. - TcpNetServerConnectionFactory(int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
Listens for incoming connections on the port.
- TcpNetServerConnectionFactorySpec - Class in org.springframework.integration.ip.dsl
- TcpNetServerConnectionFactorySpec(int) - Constructor for class org.springframework.integration.ip.dsl.TcpNetServerConnectionFactorySpec
- TcpNioClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
-
A client connection factory that creates
TcpNioConnection
s. - TcpNioClientConnectionFactory(String, int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
Creates a TcpNioClientConnectionFactory for connections to the host and port.
- TcpNioClientConnectionFactorySpec - Class in org.springframework.integration.ip.dsl
- TcpNioClientConnectionFactorySpec(String, int) - Constructor for class org.springframework.integration.ip.dsl.TcpNioClientConnectionFactorySpec
- TcpNioConnection - Class in org.springframework.integration.ip.tcp.connection
-
A TcpConnection that uses and underlying
SocketChannel
. - TcpNioConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
Construct a TcpNetConnection for the SocketChannel.
- TcpNioConnectionSupport - Interface in org.springframework.integration.ip.tcp.connection
-
Used by NIO connection factories to instantiate a
TcpNioConnection
object. - TcpNioServerConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
-
/** Implements a server connection factory that produces
TcpNioConnection
s using aServerSocketChannel
. - TcpNioServerConnectionFactory(int) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
Listens for incoming connections on the port.
- TcpNioServerConnectionFactorySpec - Class in org.springframework.integration.ip.dsl
- TcpNioServerConnectionFactorySpec(int) - Constructor for class org.springframework.integration.ip.dsl.TcpNioServerConnectionFactorySpec
- TcpNioSSLConnection - Class in org.springframework.integration.ip.tcp.connection
-
Implementation of
TcpConnection
supporting SSL/TLS over NIO. - TcpNioSSLConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String, SSLEngine) - Constructor for class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
- TcpOutboundChannelAdapterParser - Class in org.springframework.integration.ip.config
- TcpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.TcpOutboundChannelAdapterParser
- TcpOutboundChannelAdapterSpec - Class in org.springframework.integration.ip.dsl
- TcpOutboundChannelAdapterSpec(AbstractConnectionFactorySpec<?, ?>) - Constructor for class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
-
Construct an instance using the provided connection factory spec.
- TcpOutboundChannelAdapterSpec(AbstractConnectionFactory) - Constructor for class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
-
Construct an instance using an existing spring-managed connection factory.
- TcpOutboundGateway - Class in org.springframework.integration.ip.tcp
-
TCP outbound gateway that uses a client connection factory.
- TcpOutboundGateway() - Constructor for class org.springframework.integration.ip.tcp.TcpOutboundGateway
- TcpOutboundGatewayParser - Class in org.springframework.integration.ip.config
-
Parser for the <outbound-gateway> element of the integration 'jms' namespace.
- TcpOutboundGatewayParser() - Constructor for class org.springframework.integration.ip.config.TcpOutboundGatewayParser
- TcpOutboundGatewaySpec - Class in org.springframework.integration.ip.dsl
-
A
MessageHandlerSpec
forTcpOutboundGateway
s. - TcpOutboundGatewaySpec(TcpClientConnectionFactorySpec<?, ?>) - Constructor for class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
-
Construct an instance using the supplied connection factory spec.
- TcpOutboundGatewaySpec(AbstractClientConnectionFactory) - Constructor for class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
-
Construct an instance using an existing spring-managed connection factory.
- TcpReceivingChannelAdapter - Class in org.springframework.integration.ip.tcp
-
Tcp inbound channel adapter using a TcpConnection to receive data - if the connection factory is a server factory, this Listener owns the connections.
- TcpReceivingChannelAdapter() - Constructor for class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
- TcpSender - Interface in org.springframework.integration.ip.tcp.connection
-
An interface representing a sending client of a connection factory.
- TcpSendingMessageHandler - Class in org.springframework.integration.ip.tcp
-
Tcp outbound channel adapter using a TcpConnection to send data - if the connection factory is a server factory, the TcpListener owns the connections.
- TcpSendingMessageHandler() - Constructor for class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
- TcpServerConnectionFactory - Interface in org.springframework.integration.ip.tcp.connection
-
Connection factories that act as TCP servers, listening for incoming connections.
- TcpServerConnectionFactorySpec<S extends TcpServerConnectionFactorySpec<S,
C>, C extends AbstractServerConnectionFactory> - Class in org.springframework.integration.ip.dsl - TcpServerConnectionFactorySpec(int) - Constructor for class org.springframework.integration.ip.dsl.TcpServerConnectionFactorySpec
-
Deprecated.since 6.0.3; use a subclass.
- TcpServerConnectionFactorySpec(int, boolean) - Constructor for class org.springframework.integration.ip.dsl.TcpServerConnectionFactorySpec
-
Deprecated.since 6.0.3; use a subclass.
- TcpServerConnectionFactorySpec(C) - Constructor for class org.springframework.integration.ip.dsl.TcpServerConnectionFactorySpec
-
Create an instance.
- TcpSocketFactorySupport - Interface in org.springframework.integration.ip.tcp.connection
-
Strategy interface for supplying Socket Factories.
- tcpSocketSupport(TcpSocketSupport) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
-
Deprecated.
- TcpSocketSupport - Interface in org.springframework.integration.ip.tcp.connection
-
Strategy interface for modifying sockets.
- TcpSSLContextSupport - Interface in org.springframework.integration.ip.tcp.connection
-
Strategy interface for the creation of an
SSLContext
object for use with SSL/TLS sockets. - TcpSyslogReceivingChannelAdapter - Class in org.springframework.integration.syslog.inbound
-
TCP implementation of a syslog inbound channel adapter.
- TcpSyslogReceivingChannelAdapter() - Constructor for class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
- template - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- templateChannelTransacted(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
Configure
channelTransacted
on theRabbitTemplate
used when sending messages to the channel. - temporaryFileSuffix(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
-
Set the temporary suffix to use when transferring files to the remote system.
- temporaryFileSuffix(String) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
-
By default, every file that is in the process of being transferred will appear in the file system with an additional suffix, which by default is
.writing
. - temporaryFileSuffix(String) - Method in class org.springframework.integration.file.dsl.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.file.dsl.RemoteFileOutboundGatewaySpec
-
Set the temporary suffix to use when transferring files to the remote system.
- temporaryRemoteDirectory(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
-
Specify a remote directory path.
- temporaryRemoteDirectory(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
-
Specify a remote temporary directory path
Function
. - temporaryRemoteDirectoryExpression(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
-
Specify a remote directory path SpEL expression.
- temporaryRemoteDirectoryExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Set a temporary remote directory expression; used when transferring files to the remote system.
- temporaryRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Set a temporary remote directory expression; used when transferring files to the remote system.
- temporaryRemoteDirectoryFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
-
Set a temporary remote directory function; used when transferring files to the remote system.
- test() - Method in interface org.springframework.integration.file.remote.session.Session
-
Test the session is still alive, e.g.
- test() - Method in class org.springframework.integration.ftp.session.FtpSession
- test() - Method in class org.springframework.integration.sftp.session.SftpSession
- test(Message<?>) - Method in class org.springframework.integration.test.predicate.MessagePredicate
- TestingUtilities - Class in org.springframework.integration.ip.util
-
Convenience class providing methods for testing IP components.
- testRequestResponseScenarios() - Method in class org.springframework.integration.test.support.AbstractRequestResponseScenarioTests
-
Execute each scenario.
- TestUtils - Class in org.springframework.integration.test.util
- TestUtils() - Constructor for class org.springframework.integration.test.util.TestUtils
- TestUtils.LevelsContainer - Record Class in org.springframework.integration.test.util
- TestUtils.TestApplicationContext - Class in org.springframework.integration.test.util
-
A
GenericApplicationContext
extension with some support methods to register Spring Integration beans in the application context at runtime. - THREAD - Static variable in class org.springframework.integration.xmpp.XmppHeaders
- ThreadAffinityClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
-
A client connection factory that binds a connection to a thread.
- ThreadAffinityClientConnectionFactory(AbstractClientConnectionFactory) - Constructor for class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
- ThreadStatePropagationChannelInterceptor<S> - Class in org.springframework.integration.channel.interceptor
-
The
ExecutorChannelInterceptor
implementation responsible for theThread
(any?) state propagation from one message flow's thread to another through theMessageChannel
s involved in the flow. - ThreadStatePropagationChannelInterceptor() - Constructor for class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
- THROW_EXCEPTION_ON_LATE_REPLY - Static variable in class org.springframework.integration.context.IntegrationProperties
-
Specifies the value of
GenericMessagingTemplate.throwExceptionOnLateReply
. - throwExceptionOnRejection() - Element in annotation interface org.springframework.integration.annotation.Filter
-
Throw an exception if the filter rejects the message.
- throwExceptionOnRejection(boolean) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
-
The default value is
false
meaning that rejected Messages will be quietly dropped or sent to the discard channel if available. - TIME - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- timeout(int) - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
- timeout(long) - Method in class org.springframework.integration.dsl.WireTapSpec
- TimeoutCountSequenceSizeReleaseStrategy - Class in org.springframework.integration.aggregator
-
A
ReleaseStrategy
that releases all messages if any of the following is true: The sequence is complete (if there is one). There are more messages than a threshold set by the user. The time elapsed since the earliest message, according to their timestamps, if present, exceeds a timeout set by the user. - TimeoutCountSequenceSizeReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
- TimeoutCountSequenceSizeReleaseStrategy(int, long) - Constructor for class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
- timerBuilder(String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor
-
Create a timer builder for a timer with the provided name.
- timerBuilder(String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
- TimerFacade - Interface in org.springframework.integration.support.management.metrics
- TimerStats - Class in org.springframework.integration.graph
-
Statistics captured from a timer meter.
- TimerStats(long, double, double) - Constructor for class org.springframework.integration.graph.TimerStats
- timestamp(Function<Message<P>, Long>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Configure a
Function
that will be invoked at runtime to determine the Kafka record timestamp will be stored in the topic. - TIMESTAMP - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- TIMESTAMP - Static variable in class org.springframework.integration.syslog.SyslogHeaders
- TIMESTAMP - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
- TIMESTAMP_PROPERTY - Static variable in class org.springframework.integration.history.MessageHistory
- timestampExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Configure a SpEL expression to determine the timestamp at runtime against a request Message as a root object of evaluation context.
- timestampExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Configure an
Expression
to determine the timestamp at runtime against a request Message as a root object of evaluation context. - timeToLive(int) - Method in class org.springframework.integration.ip.dsl.UdpMulticastOutboundChannelAdapterSpec
- timeToLive(long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- timeToLive(long) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
- timeToLive(long) - Method in class org.springframework.integration.jms.dsl.JmsTemplateSpec
- timeToLiveExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
-
Specify a SpEL expression to evaluate a
timeToLive
for JMS message to send. - timeToLiveFunction(Function<Message<P>, ?>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
-
Specify a
Function
to resolve atimeToLive
for JMS message to send. - TINYINT - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- to(String...) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the To: addresses.
- to(IntegrationFlow) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Finish this flow with delegation to other
IntegrationFlow
instance. - TO - Static variable in class org.springframework.integration.mail.MailHeaders
- TO - Static variable in class org.springframework.integration.xmpp.XmppHeaders
- toArray() - Method in class org.springframework.integration.history.MessageHistory
- toArray(T[]) - Method in class org.springframework.integration.history.MessageHistory
- toByteArrayTransformer() - Static method in class org.springframework.integration.file.dsl.Files
-
Create a
FileToByteArrayTransformer
instance. - toByteArrayTransformer(boolean) - Static method in class org.springframework.integration.file.dsl.Files
-
Create a
FileToByteArrayTransformer
instance. - toCommand(String) - Static method in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
- toExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the expression that will be evaluated to determine the To: addresses.
- toFunction(Function<Message<P>, String[]>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set a function that will be invoked to determine the To: addresses based on the message.
- toHeaders(Message) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
- toHeaders(MimeMessage) - Method in class org.springframework.integration.mail.support.DefaultMailHeaderMapper
- toHeaders(Message) - Method in class org.springframework.integration.camel.support.CamelHeaderMapper
- toHeaders(MqttProperties) - Method in class org.springframework.integration.mqtt.support.MqttHeaderMapper
- toHeaders(HttpHeaders) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Map from an HttpHeaders instance to integration MessageHeaders.
- toHeaders(StompHeaders) - Method in class org.springframework.integration.stomp.support.StompHeaderMapper
- toHeaders(T) - Method in interface org.springframework.integration.mapping.HeaderMapper
- toHeadersFromReply(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
- toHeadersFromReply(T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
-
Map from the given reply object to abstracted
MessageHeaders
. - toHeadersFromRequest(MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- toHeadersFromRequest(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
- toHeadersFromRequest(T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
-
Map from the given request object to abstracted
MessageHeaders
. - toJson() - Static method in class org.springframework.integration.dsl.Transformers
- toJson() - Method in class org.springframework.integration.file.remote.AbstractFileInfo
- toJson(Object) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
- toJson(Object) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
- toJson(Object, Writer) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
- toJson(Object, Writer) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
- toJson(Object, String...) - Static method in class org.springframework.integration.json.SimpleJsonSerializer
-
Convert the bean to JSON with the provided properties.
- toJson(String) - Static method in class org.springframework.integration.dsl.Transformers
- toJson(ObjectToJsonTransformer.ResultType) - Static method in class org.springframework.integration.dsl.Transformers
-
Factory for the
ObjectToJsonTransformer
based on the providedObjectToJsonTransformer.ResultType
. - toJson(ObjectToJsonTransformer.ResultType, String) - Static method in class org.springframework.integration.dsl.Transformers
- toJson(JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.Transformers
- toJson(JsonObjectMapper<?, ?>, String) - Static method in class org.springframework.integration.dsl.Transformers
- toJson(JsonObjectMapper<?, ?>, ObjectToJsonTransformer.ResultType) - Static method in class org.springframework.integration.dsl.Transformers
- toJson(JsonObjectMapper<?, ?>, ObjectToJsonTransformer.ResultType, String) - Static method in class org.springframework.integration.dsl.Transformers
- toJsonNode(Object) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
- toJsonNode(Object) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
- toMap() - Static method in class org.springframework.integration.dsl.Transformers
- toMap() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
- toMap(boolean) - Static method in class org.springframework.integration.dsl.Transformers
- toMap(JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.Transformers
- toMap(JsonObjectMapper<?, ?>, boolean) - Static method in class org.springframework.integration.dsl.Transformers
- toMessage(byte[]) - Method in interface org.springframework.integration.mapping.BytesMessageMapper
- toMessage(byte[], Map<String, Object>) - Method in interface org.springframework.integration.mapping.BytesMessageMapper
- toMessage(byte[], Map<String, Object>) - Method in class org.springframework.integration.mapping.ConvertingBytesMessageMapper
- toMessage(byte[], Map<String, Object>) - Method in class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
- toMessage(AbstractIMapEvent) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer.HazelcastEntryListener
- toMessage(E) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer.AbstractHazelcastEventListener
- toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.codec.CodecMessageConverter
- toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
- toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
- toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.support.converter.MapMessageConverter
- toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.support.converter.PassThruMessageConverter
- toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
- toMessage(String, Map<String, Object>) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
- toMessage(String, MqttMessage) - Method in interface org.springframework.integration.mqtt.support.MqttMessageConverter
-
Convert to a Message.
- toMessage(DatagramPacket) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
- toMessage(DatagramPacket, Map<String, Object>) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
- toMessage(TcpConnection, Map<String, Object>) - Method in class org.springframework.integration.ip.tcp.connection.MessageConvertingTcpMessageMapper
- toMessage(TcpConnection, Map<String, Object>) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
- toMessage(T) - Method in interface org.springframework.integration.mapping.InboundMessageMapper
-
Convert a provided object to the
Message
. - toMessage(T, Map<String, Object>) - Method in interface org.springframework.integration.mapping.InboundMessageMapper
-
Convert a provided object to the
Message
and supply with headers if necessary and provided. - toMessageBuilder(String, MqttMessage) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
- toMessageBuilder(String, MqttMessage) - Method in interface org.springframework.integration.mqtt.support.MqttMessageConverter
-
Convert to a message builder.
- toOption(String) - Static method in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
- toPasswordProtectedString(URLName) - Static method in class org.springframework.integration.mail.MailTransportUtils
-
Returns a string representation of the given
URLName
, where the password has been protected. - topic - Variable in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
- topic(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Configure the Kafka topic to send messages.
- topic(String) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
-
Specify a topic the
SocketType.PUB
socket is going to use for distributing messages into the subscriptions. - topic(Function<Message<P>, String>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Configure a
Function
that will be invoked at runtime to determine the topic to which a message will be sent. - TOPIC - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
- TOPIC - Static variable in class org.springframework.integration.zeromq.ZeroMqHeaders
-
A ZeroMq pub/sub message topic header.
- TOPIC_ALIAS - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
- topicExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Configure a SpEL expression to determine the Kafka topic at runtime against request Message as a root object of evaluation context.
- topicExpression(String) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
-
Specify a SpEL expression to evaluate a topic a
SocketType.PUB
is going to use for distributing messages into the subscriptions.It is ignored for all otherSocketType
s supported. - topicExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
-
Configure an
Expression
to determine the Kafka topic at runtime against request Message as a root object of evaluation context. - topicExpression(Expression) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
-
Specify a SpEL expression to evaluate a topic a
SocketType.PUB
is going to use for distributing messages into the subscriptions.It is ignored for all otherSocketType
s supported. - topicFunction(Function<Message<?>, String>) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageHandlerSpec
-
Specify a
Function
to evaluate a topic aSocketType.PUB
is going to use for distributing messages into the subscriptions.It is ignored for all otherSocketType
s supported. - topicLock - Variable in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
- topics(String...) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
-
Specify topics the
SocketType.SUB
socket is going to use for subscription. - toProperties() - Method in class org.springframework.integration.context.IntegrationProperties
-
Represent the current instance as a
Properties
. - toReactivePublisher() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Represent an Integration Flow as a Reactive Streams
Publisher
bean. - toReactivePublisher() - Method in class org.springframework.integration.dsl.IntegrationFlowBuilder
- toReactivePublisher(boolean) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Represent an Integration Flow as a Reactive Streams
Publisher
bean. - toReactivePublisher(boolean) - Method in class org.springframework.integration.dsl.IntegrationFlowBuilder
- toSoapHeaders(WebServiceMessage, Message<?>) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
- toString() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
- toString() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
- toString() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
- toString() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
- toString() - Method in exception org.springframework.integration.amqp.support.NackedAmqpMessageException
- toString() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
- toString() - Method in record class org.springframework.integration.channel.DefaultHeaderChannelRegistry.MessageChannelWrapper
-
Returns a string representation of this record class.
- toString() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
- toString() - Method in class org.springframework.integration.channel.NullChannel
- toString() - Method in record class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor.BeanDefinitionPropertiesMapper
-
Returns a string representation of this record class.
- toString() - Method in record class org.springframework.integration.config.MessagingAnnotationPostProcessor.MessagingMetaAnnotation
-
Returns a string representation of this record class.
- toString() - Method in class org.springframework.integration.context.IntegrationObjectSupport
- toString() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
- toString() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
- toString() - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
- toString() - Method in class org.springframework.integration.events.IntegrationEvent
- toString() - Method in class org.springframework.integration.expression.ExpressionEvalMap
- toString() - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
- toString() - Method in class org.springframework.integration.expression.ValueExpression
- toString() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
- toString() - Method in class org.springframework.integration.file.remote.AbstractFileInfo
- toString() - Method in class org.springframework.integration.file.remote.aop.RotationPolicy.KeyDirectory
- toString() - Method in class org.springframework.integration.file.splitter.FileSplitter.FileMarker
- toString() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingEvent
- toString() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingIdleEvent
- toString() - Method in class org.springframework.integration.filter.ExpressionEvaluatingSelector
- toString() - Method in class org.springframework.integration.ftp.server.ApacheMinaFtpEvent
- toString() - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
- toString() - Method in class org.springframework.integration.ftp.server.FileWrittenEvent
- toString() - Method in class org.springframework.integration.ftp.server.FtpRequestEvent
- toString() - Method in class org.springframework.integration.ftp.server.PathRemovedEvent
- toString() - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
- toString() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
- toString() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
- toString() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
- toString() - Method in class org.springframework.integration.hazelcast.leader.LeaderInitiator.HazelcastContext
- toString() - Method in class org.springframework.integration.hazelcast.message.EntryEventMessagePayload
- toString() - Method in class org.springframework.integration.history.MessageHistory
- toString() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- toString() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
- toString() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionCloseEvent
- toString() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionEvent
- toString() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionFailedCorrelationEvent
- toString() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionOpenEvent
- toString() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
- toString() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
- toString() - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
- toString() - Method in class org.springframework.integration.jpa.support.JpaParameter
- toString() - Method in record class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
- toString() - Method in exception org.springframework.integration.kafka.support.KafkaSendFailureException
- toString() - Method in class org.springframework.integration.leader.DefaultCandidate
- toString() - Method in class org.springframework.integration.leader.event.AbstractLeaderEvent
- toString() - Method in class org.springframework.integration.mail.AbstractMailReceiver
- toString() - Method in class org.springframework.integration.message.AdviceMessage
- toString() - Method in class org.springframework.integration.mqtt.event.MqttMessageDeliveredEvent
- toString() - Method in class org.springframework.integration.mqtt.event.MqttMessageSentEvent
- toString() - Method in class org.springframework.integration.mqtt.event.MqttSubscribedEvent
- toString() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
- toString() - Method in class org.springframework.integration.rsocket.RSocketConnectedEvent
- toString() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
- toString() - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
- toString() - Method in class org.springframework.integration.sftp.server.DirectoryCreatedEvent
- toString() - Method in class org.springframework.integration.sftp.server.FileWrittenEvent
- toString() - Method in class org.springframework.integration.sftp.server.PathMovedEvent
- toString() - Method in class org.springframework.integration.sftp.server.PathRemovedEvent
- toString() - Method in class org.springframework.integration.sftp.server.SessionClosedEvent
- toString() - Method in class org.springframework.integration.sftp.server.SessionOpenedEvent
- toString() - Method in class org.springframework.integration.smb.session.SmbConfig
- toString() - Method in class org.springframework.integration.smb.session.SmbFileInfo
- toString() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
- toString() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
- toString() - Method in class org.springframework.integration.store.SimpleMessageGroup
- toString() - Method in class org.springframework.integration.support.MutableMessage
- toString() - Method in exception org.springframework.integration.support.PartialSuccessException
- toString() - Method in record class org.springframework.integration.test.util.TestUtils.LevelsContainer
-
Returns a string representation of this record class.
- toString() - Method in class org.springframework.integration.util.UpperBound
- toString() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator.CuratorContext
- toStringTransformer() - Static method in class org.springframework.integration.file.dsl.Files
-
Create a
FileToStringTransformer
instance with defaultcharset
and no delete files afterwards. - toStringTransformer() - Static method in class org.springframework.integration.mail.dsl.Mail
-
A
MailToStringTransformer
factory. - toStringTransformer(boolean) - Static method in class org.springframework.integration.file.dsl.Files
-
Create a
FileToStringTransformer
instance with defaultcharset
and with delete files flag. - toStringTransformer(String) - Static method in class org.springframework.integration.file.dsl.Files
-
Create a
FileToStringTransformer
instance with providedcharset
and no delete files afterwards. - toStringTransformer(String) - Static method in class org.springframework.integration.mail.dsl.Mail
-
A
MailToStringTransformer
factory. - toStringTransformer(String, boolean) - Static method in class org.springframework.integration.file.dsl.Files
-
Create a
FileToStringTransformer
instance with providedcharset
and delete files flag. - trace() - Static method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
-
The factory to produce Log4j2LevelAdjuster instances for
Level.TRACE
logging with theorg.springframework.integration
as default category. - TRACE - Enum constant in enum class org.springframework.integration.handler.LoggingHandler.Level
- TrackableComponent - Interface in org.springframework.integration.support.management
- transacted(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundPolledChannelAdapterSpec
- transactional() - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
-
Specify a
TransactionInterceptor
Advice
with defaultPlatformTransactionManager
andDefaultTransactionAttribute
for theMessageHandler
. - transactional() - Method in class org.springframework.integration.dsl.PollerSpec
-
Specify a
TransactionInterceptor
Advice
with defaultPlatformTransactionManager
andDefaultTransactionAttribute
for thepollingTask
. - transactional() - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
Specify a
TransactionInterceptor
Advice
with defaultPlatformTransactionManager
andDefaultTransactionAttribute
for the downstream flow. - transactional(boolean) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
-
Specify a
TransactionInterceptor
Advice
with defaultPlatformTransactionManager
andDefaultTransactionAttribute
for theMessageHandler
. - transactional(TransactionInterceptor) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
- transactional(TransactionInterceptor) - Method in class org.springframework.integration.dsl.PollerSpec
- transactional(TransactionInterceptor) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
Specify a
TransactionInterceptor
Advice
for the downstream flow. - transactional(TransactionManager) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
-
Specify a
TransactionInterceptor
Advice
with the providedPlatformTransactionManager
and defaultDefaultTransactionAttribute
for theMessageHandler
. - transactional(TransactionManager) - Method in class org.springframework.integration.dsl.PollerSpec
-
Specify a
TransactionInterceptor
Advice
with the providedPlatformTransactionManager
and defaultDefaultTransactionAttribute
for thepollingTask
. - transactional(TransactionManager) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
Specify a
TransactionInterceptor
Advice
with the providedTransactionManager
and defaultDefaultTransactionAttribute
for the downstream flow. - transactional(TransactionManager, boolean) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
-
Specify a
TransactionInterceptor
Advice
with the providedPlatformTransactionManager
and defaultDefaultTransactionAttribute
for theMessageHandler
. - transactionalRelease() - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
-
Specify a
TransactionInterceptor
Advice
with defaultTransactionManager
andDefaultTransactionAttribute
for theMessageHandler
. - transactionalRelease(TransactionInterceptor) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
- transactionalRelease(TransactionManager) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
-
Specify a
TransactionInterceptor
Advice
with the providedTransactionManager
and defaultDefaultTransactionAttribute
for theMessageHandler
. - transactionAttribute(TransactionAttribute) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Set the transaction attribute to use when using an external transaction manager.
- transactionAttribute(TransactionAttribute) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
Configure a
TransactionAttribute
to be used with theAmqpMessageChannelSpec.transactionManager(PlatformTransactionManager)
. - transactionAttribute(TransactionAttribute) - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
- TransactionHandleMessageAdvice - Class in org.springframework.integration.transaction
-
A
TransactionInterceptor
extension withHandleMessageAdvice
marker. - TransactionHandleMessageAdvice() - Constructor for class org.springframework.integration.transaction.TransactionHandleMessageAdvice
- TransactionHandleMessageAdvice(TransactionManager, Properties) - Constructor for class org.springframework.integration.transaction.TransactionHandleMessageAdvice
- TransactionHandleMessageAdvice(TransactionManager, TransactionAttributeSource) - Constructor for class org.springframework.integration.transaction.TransactionHandleMessageAdvice
- TransactionInterceptorBuilder - Class in org.springframework.integration.transaction
-
Provides a fluent API to build a transaction interceptor.
- TransactionInterceptorBuilder() - Constructor for class org.springframework.integration.transaction.TransactionInterceptorBuilder
- TransactionInterceptorBuilder(boolean) - Constructor for class org.springframework.integration.transaction.TransactionInterceptorBuilder
- transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Configure a
PlatformTransactionManager
; used to synchronize the rabbit transaction with some other transaction(s). - transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
Configure a
PlatformTransactionManager
; used to synchronize the rabbit transaction with some other transaction(s). - transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
A
PlatformTransactionManager
reference. - transactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
-
Only applies if the
JmsMessageChannelSpec.containerType(Class)
is aDefaultMessageListenerContainer
. - transactionManager(TransactionManager) - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
-
Provide a
TransactionManager
instance to use. - transactionName(String) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
A name for transaction.
- transactionName(String) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
-
Only applies if the
JmsMessageChannelSpec.containerType(Class)
is aDefaultMessageListenerContainer
. - transactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.dsl.PollerSpec
-
Specify the
TransactionSynchronizationFactory
to attach aTransactionSynchronization
to the transaction aroundpoll
operation. - transactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
-
Configure a
TransactionSynchronizationFactory
. - TransactionSynchronizationFactory - Interface in org.springframework.integration.transaction
-
Strategy for implementing factories that create
TransactionSynchronization
. - TransactionSynchronizationFactoryBean - Class in org.springframework.integration.transaction
-
The
FactoryBean
implementation (withBuilder
style) to be used from JavaConfig to populateDefaultTransactionSynchronizationFactory
bean. - TransactionSynchronizationFactoryBean() - Constructor for class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- TransactionSynchronizationFactoryParser - Class in org.springframework.integration.config.xml
-
Parser for transaction-synchronization-factory element.
- TransactionSynchronizationFactoryParser() - Constructor for class org.springframework.integration.config.xml.TransactionSynchronizationFactoryParser
- TransactionSynchronizationProcessor - Interface in org.springframework.integration.transaction
-
Strategy for implementing transaction synchronization processors.
- transactionTimeout(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
A transaction timeout.
- transactionTimeout(int) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
-
Only applies if the
JmsMessageChannelSpec.containerType(Class)
is aDefaultMessageListenerContainer
. - transferCookies(boolean) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
-
Set to
true
if you wishSet-Cookie
header in response to be transferred asCookie
header in subsequent interaction for a message. - transferTo(File) - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
- transform(Class<P>, GenericTransformer<P, T>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MessageTransformingHandler
instance for the providedGenericTransformer
for the specificexpectedType
to convert at runtime. - transform(Class<P>, GenericTransformer<P, T>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MessageTransformingHandler
instance for the providedGenericTransformer
for the specificexpectedType
to convert at runtime. - transform(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MessageTransformingHandler
for theMethodInvokingTransformer
to invoke the discovered service method at runtime. - transform(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MessageTransformingHandler
for theMethodInvokingTransformer
to invoke the service method at runtime. - transform(Object, String, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MessageTransformingHandler
for theMethodInvokingTransformer
to invoke the service method at runtime. - transform(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- transform(String, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- transform(GenericTransformer<S, T>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
-
Populate the
MessageTransformingHandler
instance for the providedGenericTransformer
. - transform(GenericTransformer<S, T>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
-
Populate the
MessageTransformingHandler
instance for the providedGenericTransformer
. - transform(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MessageTransformingHandler
instance for theMessageProcessor
from providedMessageProcessorSpec
. - transform(MessageProcessorSpec<?>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate the
MessageTransformingHandler
instance for theMessageProcessor
from providedMessageProcessorSpec
. - transform(Message<?>) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
- transform(Message<?>) - Method in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
- transform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
- transform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractTransformer
- transform(Message<?>) - Method in class org.springframework.integration.transformer.HeaderEnricher
- transform(Message<?>) - Method in class org.springframework.integration.transformer.HeaderFilter
- transform(Message<?>) - Method in interface org.springframework.integration.transformer.Transformer
- transform(S) - Method in interface org.springframework.integration.core.GenericTransformer
- transformer - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- Transformer - Interface in org.springframework.integration.transformer
-
Strategy interface for transforming a
Message
. - Transformer - Annotation Interface in org.springframework.integration.annotation
-
Indicates that a method is capable of transforming a message, message header, or message payload.
- TRANSFORMER_TRANSFORM_METHOD - Static variable in class org.springframework.integration.util.ClassUtils
-
The
org.springframework.integration.core.GenericTransformer#transform(Object)
method object. - TransformerAnnotationPostProcessor - Class in org.springframework.integration.config
-
Post-processor for Methods annotated with a
@Transformer
. - TransformerAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.TransformerAnnotationPostProcessor
- TransformerFactoryBean - Class in org.springframework.integration.config
-
Factory bean for creating a Message Transformer.
- TransformerFactoryBean() - Constructor for class org.springframework.integration.config.TransformerFactoryBean
- transformerHelper - Variable in class org.springframework.integration.ws.DefaultSoapHeaderMapper
- TransformerParser - Class in org.springframework.integration.config.xml
-
Parser for the <transformer/> element.
- TransformerParser() - Constructor for class org.springframework.integration.config.xml.TransformerParser
- Transformers - Class in org.springframework.integration.dsl
-
An utility class to provide methods for out-of-the-box
Transformer
s. - Transformers - Annotation Interface in org.springframework.integration.annotation
-
The repeatable container for
Transformer
annotations. - Transformers() - Constructor for class org.springframework.integration.dsl.Transformers
- transformFile(File) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
-
Subclasses must implement this method to transform the File contents.
- transformFile(File) - Method in class org.springframework.integration.file.transformer.FileToByteArrayTransformer
- transformFile(File) - Method in class org.springframework.integration.file.transformer.FileToStringTransformer
- transformPayload(Object) - Method in class org.springframework.integration.transformer.ObjectToMapTransformer
- transformPayload(Object) - Method in class org.springframework.integration.transformer.ObjectToStringTransformer
- transformPayload(Object) - Method in class org.springframework.integration.transformer.SyslogToMapTransformer
- transformPayload(Object) - Method in class org.springframework.integration.xml.transformer.SourceCreatingTransformer
- transformPayload(Object) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
- transformPayload(Map<?, ?>) - Method in class org.springframework.integration.transformer.MapToObjectTransformer
- transformPayload(T) - Method in class org.springframework.integration.transformer.AbstractPayloadTransformer
- transformPayload(T) - Method in class org.springframework.integration.transformer.EncodingPayloadTransformer
- transformPayload(T) - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
- transformResult(Result) - Method in class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
- transformResult(Result) - Method in class org.springframework.integration.xml.transformer.ResultToStringTransformer
- transformResult(Result) - Method in interface org.springframework.integration.xml.transformer.ResultTransformer
- trigger() - Element in annotation interface org.springframework.integration.annotation.Poller
- trigger(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
ServiceActivatingHandler
instance to performMessageTriggerAction
. - trigger(String, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
ServiceActivatingHandler
instance to performMessageTriggerAction
and endpoint options fromGenericEndpointSpec
. - trigger(MessageTriggerAction) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
ServiceActivatingHandler
instance to performMessageTriggerAction
. - trigger(MessageTriggerAction, Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
ServiceActivatingHandler
instance to performMessageTriggerAction
and endpoint options fromGenericEndpointSpec
. - trigger(Message<?>) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
- trigger(Message<?>) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
When using
FileExistsMode.APPEND_NO_FLUSH
, you can send a message to this method to flush any file(s) that needs it. - trigger(Message<?>) - Method in interface org.springframework.integration.handler.MessageTriggerAction
-
Take some action based on the message.
- trigger(Trigger) - Method in class org.springframework.integration.dsl.PollerFactory
- trigger(Trigger) - Static method in class org.springframework.integration.dsl.Pollers
- tryAcquire(long) - Method in class org.springframework.integration.util.UpperBound
-
Acquires a permit from the underlying semaphore if this UpperBound is bounded and returns true if it succeeds within the given timeout.
- tryClaim(File) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
-
This class takes the minimal implementation and merely delegates to the locker if set.
- tryClaim(File) - Method in interface org.springframework.integration.file.DirectoryScanner
-
Claim the file to process.
- tryOptimizedDispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
- TYPE - Static variable in class org.springframework.integration.transformer.support.AvroHeaders
-
The
SpecificRecord
type. - TYPE - Static variable in class org.springframework.integration.xmpp.XmppHeaders
- TYPE_ID - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
- TYPE_PROPERTY - Static variable in class org.springframework.integration.history.MessageHistory
- typeExpression(String) - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
-
Set the expression to evaluate against the message to determine the type id.
- typeExpression(String) - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
-
Set the expression to evaluate against the message to determine the value for the
AvroHeaders.TYPE
header. - typeExpression(Expression) - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
-
Set the expression to evaluate against the message to determine the type.
- typeExpression(Expression) - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
-
Set the expression to evaluate against the message to determine the value for the
AvroHeaders.TYPE
header.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form