Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
I
- id - Static variable in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
- id(String) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- id(String) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- id(String) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
- 
Specify anidfor theIntegrationFlowto register.
- id(String) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
- 
Specify anidfor theIntegrationFlowto register.
- id(String) - Method in class org.springframework.integration.dsl.EndpointSpec
- id(String) - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
- 
Configure the component identifier.
- id(String) - Method in class org.springframework.integration.dsl.MessageProducerSpec
- 
Configure the component identifier.
- id(String) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
- id(String) - Method in class org.springframework.integration.dsl.PublishSubscribeSpec
- id(String) - Method in class org.springframework.integration.dsl.QueueChannelSpec.MessageStoreSpec
- id(String) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
- id(String) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
- id(String) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
- id(String) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
- id(String) - Method in class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
- id(String) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
- id(String) - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
- id(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
- 
Return the MQTT message id.
- ID - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
- ID - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
- IDEMPOTENT_ENDPOINTS_MAPPING - Static variable in class org.springframework.integration.config.IdempotentReceiverAutoProxyCreatorInitializer
- IdempotentReceiver - Annotation Interface in org.springframework.integration.annotation
- 
Amethodthat has a MessagingAnnotation (@code @ServiceActivator, @Router etc.) that also has this annotation, has anIdempotentReceiverInterceptorapplied to the associatedMessageHandler.handleMessage(org.springframework.messaging.Message<?>)method.
- IdempotentReceiverAutoProxyCreatorInitializer - Class in org.springframework.integration.config
- 
TheIntegrationConfigurationInitializerthat populates theConfigurableListableBeanFactorywith anIdempotentReceiverAutoProxyCreatorwhenIdempotentReceiverInterceptorBeanDefinitions and theirmappingto Consumer Endpoints are present.
- IdempotentReceiverAutoProxyCreatorInitializer() - Constructor for class org.springframework.integration.config.IdempotentReceiverAutoProxyCreatorInitializer
- IdempotentReceiverInterceptor - Class in org.springframework.integration.handler.advice
- 
TheMethodInterceptorimplementation for the Idempotent Receiver E.I.
- IdempotentReceiverInterceptor(MessageSelector) - Constructor for class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
- IdempotentReceiverInterceptorParser - Class in org.springframework.integration.config.xml
- 
Parser for the <idempotent-receiver/> element.
- IdempotentReceiverInterceptorParser() - Constructor for class org.springframework.integration.config.xml.IdempotentReceiverInterceptorParser
- idExpression(String) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
- 
Specify a SpEL expression that will be evaluated to get theprimaryKeyforEntityManager.find(Class, Object).
- idExpression(Expression) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
- 
Specify a SpEL expression that will be evaluated to get theprimaryKeyforEntityManager.find(Class, Object).
- idForEntity(Object) - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
- IdGeneratorConfigurer - Class in org.springframework.integration.config
- IdGeneratorConfigurer() - Constructor for class org.springframework.integration.config.IdGeneratorConfigurer
- IdGenerators - Class in org.springframework.integration.support
- 
AlternativeIdGeneratorimplementations.
- IdGenerators() - Constructor for class org.springframework.integration.support.IdGenerators
- IdGenerators.JdkIdGenerator - Class in org.springframework.integration.support
- 
UUID.randomUUID().
- IdGenerators.SimpleIncrementingIdGenerator - Class in org.springframework.integration.support
- idleConsumerLimit(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
- 
The max for concurrent consumers number to use.
- idleConsumerLimit(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
- idleEventInterval(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- 
How often to emitListenerContainerIdleEvents in milliseconds.
- idleEventInterval(long) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
- 
Specify the idle interval before start sending idle events.
- idleEventInterval(Long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
- 
Set the idle event interval; when set, an event is emitted if a poll returns no records and this interval has elapsed since a record was returned.
- idleReplyContainerTimeout(long) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
- idleTaskExecutionLimit(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
- 
The limit for idle task.
- idleTaskExecutionLimit(int) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
- 
Only applies if theJmsMessageChannelSpec.containerType(Class)is aDefaultMessageListenerContainer.
- idleTaskExecutionLimit(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
- IGNORE - Enum constant in enum class org.springframework.integration.file.support.FileExistsMode
- 
If the file already exists, do nothing.
- ignoreEmptyResponses(boolean) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- 
Specify whether empty String response payloads should be ignored.
- ignoreExpressionFailures(boolean) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
- ignoreFailures(boolean) - Method in class org.springframework.integration.dsl.PublishSubscribeChannelSpec
- ignoreHidden(boolean) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
- 
Configure anIgnoreHiddenFileListFilterifignoreHidden == true.
- IgnoreHiddenFileListFilter - Class in org.springframework.integration.file.filters
- 
FileListFilterimplementation that ignores any hidden files.
- IgnoreHiddenFileListFilter() - Constructor for class org.springframework.integration.file.filters.IgnoreHiddenFileListFilter
- ignoreSendFailures() - Element in annotation interface org.springframework.integration.annotation.Router
- 
If set totrue, failures to send to a message channel will be ignored.
- ignoreSendFailures(boolean) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
- imapIdleAdapter() - Static method in class org.springframework.integration.mail.dsl.Mail
- 
AnImapIdleChannelAdapterSpecfactory using a defaultImapMailReceiver.
- imapIdleAdapter(String) - Static method in class org.springframework.integration.mail.dsl.Mail
- 
AImapIdleChannelAdapterSpecfactory based on the provided url.
- imapIdleAdapter(ImapMailReceiver) - Static method in class org.springframework.integration.mail.dsl.Mail
- 
AnImapIdleChannelAdapterSpecfactory based on the providedImapMailReceiver.
- ImapIdleChannelAdapter - Class in org.springframework.integration.mail
- 
An event-driven Channel Adapter that receives mail messages from a mail server that supports the IMAP "idle" command (see RFC 2177).
- ImapIdleChannelAdapter(ImapMailReceiver) - Constructor for class org.springframework.integration.mail.ImapIdleChannelAdapter
- ImapIdleChannelAdapter.ImapIdleExceptionEvent - Class in org.springframework.integration.mail
- ImapIdleChannelAdapterParser - Class in org.springframework.integration.mail.config
- 
Parser for the <imap-idle-channel-adapter> element in the 'mail' namespace.
- ImapIdleChannelAdapterParser() - Constructor for class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
- ImapIdleChannelAdapterSpec - Class in org.springframework.integration.mail.dsl
- ImapIdleChannelAdapterSpec(ImapMailReceiver) - Constructor for class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
- ImapIdleChannelAdapterSpec(ImapMailReceiver, boolean) - Constructor for class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
- imapInboundAdapter() - Static method in class org.springframework.integration.mail.dsl.Mail
- 
AnImapMailInboundChannelAdapterSpecfactory using a defaultImapMailReceiver.
- imapInboundAdapter(String) - Static method in class org.springframework.integration.mail.dsl.Mail
- 
AImapMailInboundChannelAdapterSpecfactory based on the provided url.
- imapInboundAdapter(ImapMailReceiver) - Static method in class org.springframework.integration.mail.dsl.Mail
- 
AnImapMailInboundChannelAdapterSpecfactory based on the providedImapMailReceiver.
- ImapMailInboundChannelAdapterSpec - Class in org.springframework.integration.mail.dsl
- 
AMailInboundChannelAdapterSpecfor IMAP.
- ImapMailInboundChannelAdapterSpec() - Constructor for class org.springframework.integration.mail.dsl.ImapMailInboundChannelAdapterSpec
- ImapMailInboundChannelAdapterSpec(String) - Constructor for class org.springframework.integration.mail.dsl.ImapMailInboundChannelAdapterSpec
- ImapMailInboundChannelAdapterSpec(ImapMailReceiver) - Constructor for class org.springframework.integration.mail.dsl.ImapMailInboundChannelAdapterSpec
- ImapMailReceiver - Class in org.springframework.integration.mail
- 
AMailReceiverimplementation for receiving mail messages from a mail server that supports the IMAP protocol.
- ImapMailReceiver() - Constructor for class org.springframework.integration.mail.ImapMailReceiver
- ImapMailReceiver(String) - Constructor for class org.springframework.integration.mail.ImapMailReceiver
- inbound_channel_adapter - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- inbound_gateway - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- inboundAdapter(int) - Static method in class org.springframework.integration.ip.dsl.Udp
- 
Create an inbound unicast channel adapter using the supplied port.
- inboundAdapter(Environment) - Static method in class org.springframework.integration.amqp.dsl.RabbitStream
- 
Create an initialRabbitStreamInboundChannelAdapterSpecwith the providedEnvironment.
- inboundAdapter(Environment, Codec) - Static method in class org.springframework.integration.amqp.dsl.RabbitStream
- 
Create an initialRabbitStreamInboundChannelAdapterSpecwith the providedEnvironment.
- inboundAdapter(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
- 
The factory to produce aJmsInboundChannelAdapterSpec.
- inboundAdapter(EntityManager) - Static method in class org.springframework.integration.jpa.dsl.Jpa
- 
Create aJpaInboundChannelAdapterSpecbuilder instance based on the providedEntityManager.
- inboundAdapter(EntityManagerFactory) - Static method in class org.springframework.integration.jpa.dsl.Jpa
- 
Create aJpaInboundChannelAdapterSpecbuilder instance based on the providedEntityManagerFactory.
- inboundAdapter(File) - Static method in class org.springframework.integration.file.dsl.Files
- 
Create aFileInboundChannelAdapterSpecbuilder for theFileReadingMessageSource.
- inboundAdapter(File, Comparator<File>) - Static method in class org.springframework.integration.file.dsl.Files
- 
Create aFileInboundChannelAdapterSpecbuilder for theFileReadingMessageSource.
- inboundAdapter(URL, String) - Static method in class org.springframework.integration.feed.dsl.Feed
- inboundAdapter(ConnectionFactory, String...) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initial AmqpInboundChannelAdapterSpec using aSimpleMessageListenerContainer.
- inboundAdapter(ConnectionFactory, Queue...) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initial AmqpInboundChannelAdapterSpec using aSimpleMessageListenerContainer.
- inboundAdapter(DirectMessageListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initialAmqpInboundGatewayDMLCSpecwith providedDirectMessageListenerContainer.
- inboundAdapter(SimpleMessageListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initialAmqpInboundGatewaySMLCSpecwith providedSimpleMessageListenerContainer.
- inboundAdapter(Resource, String) - Static method in class org.springframework.integration.feed.dsl.Feed
- inboundAdapter(SessionFactory<SmbFile>) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
ASmbInboundChannelAdapterSpecfactory for an inbound channel adapter spec.
- inboundAdapter(SessionFactory<SmbFile>, Comparator<File>) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
ASmbInboundChannelAdapterSpecfactory for an inbound channel adapter spec.
- inboundAdapter(SessionFactory<FTPFile>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
AFtpInboundChannelAdapterSpecfactory for an inbound channel adapter spec.
- inboundAdapter(SessionFactory<FTPFile>, Comparator<File>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
AFtpInboundChannelAdapterSpecfactory for an inbound channel adapter spec.
- inboundAdapter(SessionFactory<SftpClient.DirEntry>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
AnSftpInboundChannelAdapterSpecfactory for an inbound channel adapter spec.
- inboundAdapter(SessionFactory<SftpClient.DirEntry>, Comparator<File>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
AnSftpInboundChannelAdapterSpecfactory for an inbound channel adapter spec.
- inboundAdapter(AbstractConnectionFactorySpec<?, ?>) - Static method in class org.springframework.integration.ip.dsl.Tcp
- 
Create an inbound channel adapter using the supplied connection factory.
- inboundAdapter(AbstractConnectionFactory) - Static method in class org.springframework.integration.ip.dsl.Tcp
- 
Create an inbound channel adapter using the supplied connection factory.
- inboundAdapter(JpaOperations) - Static method in class org.springframework.integration.jpa.dsl.Jpa
- 
Create aJpaInboundChannelAdapterSpecbuilder instance based on the providedJpaOperations.
- inboundAdapter(JmsTemplate) - Static method in class org.springframework.integration.jms.dsl.Jms
- 
The factory to produce aJmsInboundChannelAdapterSpec.
- inboundAdapter(StreamListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.RabbitStream
- 
Create an initialRabbitStreamInboundChannelAdapterSpecwith the providedStreamListenerContainer.
- inboundChannelAdapter(DebeziumEngine.Builder<ChangeEvent<byte[], byte[]>>) - Static method in class org.springframework.integration.debezium.dsl.Debezium
- 
Create an instance ofDebeziumMessageProducerSpecfor the providedDebeziumEngine.Builder.
- inboundChannelAdapter(String...) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpRequestHandlerEndpointSpecbuilder for one-way adapter based on the providedpatharray for mapping.
- inboundChannelAdapter(String...) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxInboundEndpointSpecbuilder for one-way reactive adapter based on the providedpatharray for mapping.
- inboundChannelAdapter(Properties) - Static method in class org.springframework.integration.debezium.dsl.Debezium
- 
Create an instance ofDebeziumMessageProducerSpecfor the provided native debeziumPropertiesand JSON serialization formats.
- inboundChannelAdapter(Properties, Class<? extends SerializationFormat<byte[]>>, Class<? extends SerializationFormat<byte[]>>) - Static method in class org.springframework.integration.debezium.dsl.Debezium
- 
Create an instance ofDebeziumMessageProducerSpecfor the provided native debeziumPropertiesand serialization formats.
- inboundChannelAdapter(MongoOperations, String) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aMongoDbMessageSourceSpecbuilder instance based on the providedMongoOperations.
- inboundChannelAdapter(MongoDatabaseFactory, String) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aMongoDbMessageSourceSpecbuilder instance based on the providedMongoDatabaseFactory.
- inboundChannelAdapter(MongoDatabaseFactory, Query) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aMongoDbMessageSourceSpecbuilder instance based on the providedMongoDatabaseFactory.
- inboundChannelAdapter(R2dbcEntityOperations, String) - Static method in class org.springframework.integration.r2dbc.dsl.R2dbc
- 
Create an instance ofR2dbcMessageSourceSpecfor the providedR2dbcEntityOperationsand query string.
- inboundChannelAdapter(R2dbcEntityOperations, Function<R2dbcMessageSource.SelectCreator, StatementMapper.SelectSpec>) - Static method in class org.springframework.integration.r2dbc.dsl.R2dbc
- 
Create an instance ofR2dbcMessageSourceSpecfor the providedR2dbcEntityOperationsand function to create aStatementMapper.SelectSpecinstance.
- inboundChannelAdapter(R2dbcEntityOperations, Expression) - Static method in class org.springframework.integration.r2dbc.dsl.R2dbc
- 
Create an instance ofR2dbcMessageSourceSpecfor the providedR2dbcEntityOperationsand SpEL expression for query.
- inboundChannelAdapter(ConsumerFactory<K, V>, ConsumerProperties) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- 
Create an initialKafkaInboundChannelAdapterSpecwith the consumer factory and topics.
- inboundChannelAdapter(ConsumerFactory<K, V>, ConsumerProperties, boolean) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- 
Create an initialKafkaInboundChannelAdapterSpecwith the consumer factory and topics.
- inboundChannelAdapter(ConsumerFactory<K, V>, ConsumerProperties, KafkaMessageSource.KafkaAckCallbackFactory<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- 
Create an initialKafkaInboundChannelAdapterSpecwith the consumer factory and topics with a custom ack callback factory.
- inboundChannelAdapter(ConsumerFactory<K, V>, ConsumerProperties, KafkaMessageSource.KafkaAckCallbackFactory<K, V>, boolean) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- 
Create an initialKafkaInboundChannelAdapterSpecwith the consumer factory and topics with a custom ack callback factory.
- inboundChannelAdapter(ZContext) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
- 
Create an instance ofZeroMqMessageProducerSpecfor the providedZContext.
- inboundChannelAdapter(ZContext, SocketType) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
- InboundChannelAdapter - Annotation Interface in org.springframework.integration.annotation
- InboundChannelAdapterAnnotationPostProcessor - Class in org.springframework.integration.config
- 
Post-processor for Methods annotated with@InboundChannelAdapter.
- InboundChannelAdapterAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.InboundChannelAdapterAnnotationPostProcessor
- InboundChannelAdapters - Annotation Interface in org.springframework.integration.annotation
- 
The repeatable container forInboundChannelAdapterannotations.
- inboundControllerAdapter(String, String...) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpControllerEndpointSpecbuilder for one-way adapter based on the provided MVCviewNameandpatharray for mapping.
- inboundControllerAdapter(Expression, String...) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpControllerEndpointSpecbuilder for one-way adapter based on the provided SpEL expression andpatharray for mapping.
- inboundControllerGateway(String, String...) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpControllerEndpointSpecbuilder for request-reply gateway based on the provided MVCviewNameandpatharray for mapping.
- inboundControllerGateway(Expression, String...) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpControllerEndpointSpecbuilder for request-reply gateway based on the provided SpEL expression andpatharray for mapping.
- InboundFileSynchronizer - Interface in org.springframework.integration.file.remote.synchronizer
- 
Strategy for synchronizing from a remote File system to a local directory.
- inboundGateway(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
- 
The factory to produce aJmsInboundGatewaySpec.
- inboundGateway(ConnectionFactory, Class<C>) - Static method in class org.springframework.integration.jms.dsl.Jms
- 
The factory to produce aJmsInboundGatewaySpec.
- inboundGateway(String...) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpRequestHandlerEndpointSpecbuilder for request-reply gateway based on the providedpatharray for mapping.
- inboundGateway(String...) - Static method in class org.springframework.integration.rsocket.dsl.RSockets
- 
Create anRSocketInboundGatewaySpecbuilder for request-reply reactive gateway based on the providedpatharray for mapping.
- inboundGateway(String...) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxInboundEndpointSpecbuilder for request-reply reactive gateway based on the providedpatharray for mapping.
- inboundGateway(ConnectionFactory, String...) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initialAmqpInboundGatewaySpec.
- inboundGateway(ConnectionFactory, AmqpTemplate, String...) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initialAmqpInboundGatewaySpec.
- inboundGateway(ConnectionFactory, AmqpTemplate, Queue...) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initialAmqpInboundGatewaySpec.
- inboundGateway(ConnectionFactory, Queue...) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initialAmqpInboundGatewaySpec.
- inboundGateway(DirectMessageListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initialDirectMessageListenerContainerSpecwith providedDirectMessageListenerContainer.
- inboundGateway(DirectMessageListenerContainer, AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initialAmqpInboundGatewayDMLCSpecwith providedDirectMessageListenerContainer.
- inboundGateway(SimpleMessageListenerContainer) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initialAmqpInboundGatewaySMLCSpecwith providedSimpleMessageListenerContainer.
- inboundGateway(SimpleMessageListenerContainer, AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initialAmqpInboundGatewaySMLCSpecwith providedSimpleMessageListenerContainer.
- inboundGateway(AbstractConnectionFactorySpec<?, ?>) - Static method in class org.springframework.integration.ip.dsl.Tcp
- 
Create an inbound gateway using the supplied connection factory.
- inboundGateway(AbstractConnectionFactory) - Static method in class org.springframework.integration.ip.dsl.Tcp
- 
Create an inbound gateway using the supplied connection factory.
- inboundGateway(KafkaMessageListenerContainerSpec<K, V>, KafkaTemplateSpec<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- 
Create an initialKafkaInboundGatewaySpecwith the provided container and template specs.
- inboundGateway(AbstractMessageListenerContainer) - Static method in class org.springframework.integration.jms.dsl.Jms
- 
The factory to produce aJmsInboundGatewaySpec.
- inboundGateway(ConsumerFactory<K, V>, ContainerProperties, ProducerFactory<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- 
Create an initialKafkaInboundGatewaySpecwith the provided consumer factory, container properties and producer factory.
- inboundGateway(AbstractMessageListenerContainer<K, V>, KafkaTemplate<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- 
Create an initialKafkaInboundGatewaySpecwith the provided container and template.
- inboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- 
Configure the inbound header mapper to use whenAmqpPollableMessageChannelSpec.extractPayload(boolean)is true.
- inboundHeaderNames(String...) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
- inboundMapper() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- 
Construct a default inbound header mapper.
- inboundMapper() - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
- 
Factory method for creating a basic inbound mapper instance.
- InboundMessageMapper<T> - Interface in org.springframework.integration.mapping
- 
Strategy interface for mapping from an Object to aMessage.
- inboundMulticastAdapter(int, String) - Static method in class org.springframework.integration.ip.dsl.Udp
- 
Create an inbound multicast channel adapter using the supplied port and group.
- inboundPolledAdapter(ConnectionFactory, String) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initial AmqpInboundPolledChannelAdapterSpec.
- inboundPolledAdapter(ConnectionFactory, AmqpMessageSource.AmqpAckCallbackFactory, String) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initial AmqpInboundPolledChannelAdapterSpec.
- inboundReplyHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- inboundRequestHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- inboundStreamingAdapter(RemoteFileTemplate<SmbFile>) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
ASmbStreamingInboundChannelAdapterSpecfactory for an inbound channel adapter spec.
- inboundStreamingAdapter(RemoteFileTemplate<SmbFile>, Comparator<SmbFile>) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
ASmbStreamingInboundChannelAdapterSpecfactory for an inbound channel adapter spec.
- inboundStreamingAdapter(RemoteFileTemplate<FTPFile>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
AFtpStreamingInboundChannelAdapterSpecfactory for an inbound channel adapter spec.
- inboundStreamingAdapter(RemoteFileTemplate<FTPFile>, Comparator<FTPFile>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
AFtpStreamingInboundChannelAdapterSpecfactory for an inbound channel adapter spec.
- inboundStreamingAdapter(RemoteFileTemplate<SftpClient.DirEntry>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
AnSftpStreamingInboundChannelAdapterSpecfactory for an inbound channel adapter spec.
- inboundStreamingAdapter(RemoteFileTemplate<SftpClient.DirEntry>, Comparator<SftpClient.DirEntry>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
AnSftpStreamingInboundChannelAdapterSpecfactory for an inbound channel adapter spec.
- includeFilters() - Element in annotation interface org.springframework.integration.annotation.IntegrationComponentScan
- 
Specifies which types are eligible for component scanning.
- inclusive() - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
- 
Include the length of the header in addition to the payload.
- increment() - Method in interface org.springframework.integration.support.management.metrics.CounterFacade
- increment() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounter
- incrementAndGetConnectionSequence() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
- incrementAndGetConnectionSequence() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- incrementAndGetConnectionSequence() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
- incrementClientInstance() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
- indexOf(Object) - Method in class org.springframework.integration.history.MessageHistory
- info() - Static method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
- 
The factory to produce Log4j2LevelAdjuster instances forLevel.INFOlogging with theorg.springframework.integrationas default category.
- INFO - Enum constant in enum class org.springframework.integration.handler.LoggingHandler.Level
- INFO - Enum constant in enum class org.springframework.integration.syslog.RFC5424SyslogParser.Severity
- ingestQuery(String) - Method in class org.springframework.integration.cassandra.dsl.CassandraMessageHandlerSpec
- 
Set an ingest query.
- init() - Method in class org.springframework.integration.amqp.config.AmqpNamespaceHandler
- init() - Method in class org.springframework.integration.cassandra.config.xml.CassandraNamespaceHandler
- init() - Method in class org.springframework.integration.config.xml.IntegrationNamespaceHandler
- init() - Method in class org.springframework.integration.event.config.EventNamespaceHandler
- init() - Method in class org.springframework.integration.feed.config.FeedNamespaceHandler
- init() - Method in class org.springframework.integration.file.config.FileNamespaceHandler
- init() - Method in class org.springframework.integration.ftp.config.FtpNamespaceHandler
- init() - Method in class org.springframework.integration.groovy.config.GroovyNamespaceHandler
- init() - Method in class org.springframework.integration.hazelcast.config.xml.HazelcastIntegrationNamespaceHandler
- init() - Method in class org.springframework.integration.http.config.HttpNamespaceHandler
- init() - Method in class org.springframework.integration.ip.config.IpNamespaceHandler
- init() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
- 
Initializes the SSLEngine and sets up the encryption/decryption buffers.
- init() - Method in class org.springframework.integration.jdbc.config.JdbcNamespaceHandler
- init() - Method in class org.springframework.integration.jms.config.JmsNamespaceHandler
- init() - Method in class org.springframework.integration.jmx.config.JmxNamespaceHandler
- init() - Method in class org.springframework.integration.jpa.config.xml.JpaNamespaceHandler
- init() - Method in class org.springframework.integration.kafka.config.xml.KafkaNamespaceHandler
- init() - Method in class org.springframework.integration.mail.config.MailNamespaceHandler
- init() - Method in class org.springframework.integration.mongodb.config.MongoDbNamespaceHandler
- init() - Method in class org.springframework.integration.mqtt.config.xml.MqttNamespaceHandler
- init() - Method in class org.springframework.integration.redis.config.RedisNamespaceHandler
- init() - Method in class org.springframework.integration.rsocket.config.RSocketNamespaceHandler
- init() - Method in class org.springframework.integration.scripting.config.jsr223.ScriptNamespaceHandler
- init() - Method in class org.springframework.integration.sftp.config.SftpNamespaceHandler
- init() - Method in class org.springframework.integration.smb.config.SmbNamespaceHandler
- init() - Method in class org.springframework.integration.smb.session.SmbShare
- init() - Method in class org.springframework.integration.stomp.config.StompNamespaceHandler
- init() - Method in class org.springframework.integration.stream.config.StreamNamespaceHandler
- init() - Method in class org.springframework.integration.syslog.config.SyslogNamespaceHandler
- init() - Method in class org.springframework.integration.test.support.RequestResponseScenario
- init() - Method in class org.springframework.integration.webflux.config.WebFluxNamespaceHandler
- init() - Method in class org.springframework.integration.websocket.config.WebSocketNamespaceHandler
- init() - Method in class org.springframework.integration.ws.config.WsNamespaceHandler
- init() - Method in class org.springframework.integration.xml.config.IntegrationXmlNamespaceHandler
- init() - Method in class org.springframework.integration.xmpp.config.XmppNamespaceHandler
- init() - Method in class org.springframework.integration.zip.config.xml.ZipNamespaceHandler
- init() - Method in class org.springframework.integration.zookeeper.config.xml.ZookeeperNamespaceHandler
- initArgumentResolvers() - Method in class org.springframework.integration.handler.support.IntegrationMessageHandlerMethodFactory
- initArgumentResolvers() - Method in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
- initCorsConfiguration(Object, Method, RequestMappingInfo) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
- initCorsConfiguration(Object, Method, RequestMappingInfo) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
- initialize(String) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
- initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.GlobalChannelInterceptorInitializer
- initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.IdempotentReceiverAutoProxyCreatorInitializer
- initialize(ConfigurableListableBeanFactory) - Method in interface org.springframework.integration.config.IntegrationConfigurationInitializer
- initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.IntegrationConverterInitializer
- initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.dsl.context.DslIntegrationConfigurationInitializer
- initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.groovy.config.GroovyIntegrationConfigurationInitializer
- initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.hazelcast.config.HazelcastIntegrationConfigurationInitializer
- initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.http.config.HttpIntegrationConfigurationInitializer
- initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.jmx.config.JmxIntegrationConfigurationInitializer
- initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.webflux.config.WebFluxIntegrationConfigurationInitializer
- initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.websocket.config.WebSocketIntegrationConfigurationInitializer
- initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.ws.config.WsIntegrationConfigurationInitializer
- initializeConnection(TcpConnectionSupport, Socket) - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
- 
Transfer attributes such as (de)serializers, singleUse etc to a new connection.
- initializeConnection(TcpConnectionSupport, Socket) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
- 
Transfers attributes such as (de)serializer, mapper etc to a new connection.
- initialized(ServerSession, int) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
- initReturnValueHandlers() - Method in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
- injectConstructorWithAdapter(String, String, String, String, Element, BeanDefinitionBuilder, BeanMetadataElement, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- injectPropertyWithAdapter(String, String, String, String, String, Element, BeanDefinitionBuilder, BeanMetadataElement, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- InnerHandler(String, String) - Constructor for class org.springframework.integration.graph.CompositeMessageHandlerNode.InnerHandler
- input - Enum constant in enum class org.springframework.integration.graph.LinkNode.Type
- INPUT_CHANNEL - Static variable in class org.springframework.integration.transaction.IntegrationResourceHolder
- INPUT_CHANNEL_ATTRIBUTE - Static variable in interface org.springframework.integration.config.annotation.MethodAnnotationPostProcessor
- INPUT_MESSAGE_CONTEXT_KEY - Static variable in class org.springframework.integration.support.ErrorMessageUtils
- 
The context key for the message object.
- inputChannel() - Element in annotation interface org.springframework.integration.annotation.Aggregator
- inputChannel() - Element in annotation interface org.springframework.integration.annotation.Filter
- 
Specify the channel from which this filter will consume messages.
- inputChannel() - Element in annotation interface org.springframework.integration.annotation.Router
- 
Specify the channel from which this router will consume messages.
- inputChannel() - Element in annotation interface org.springframework.integration.annotation.ServiceActivator
- 
Specify the channel from which this service activator will consume messages.
- inputChannel() - Element in annotation interface org.springframework.integration.annotation.Splitter
- 
Specify the channel from which this splitter will consume messages.
- inputChannel() - Element in annotation interface org.springframework.integration.annotation.Transformer
- 
Specify the channel from which this transformer will consume messages.
- inputStream() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
- 
Subclasses can override this, for example to wrap the input stream.
- inputStream() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
- 
Subclasses can override this, for example to wrap the input stream.
- InputStreamCallback - Interface in org.springframework.integration.file.remote
- 
Callback for stream-based file retrieval using a RemoteFileOperations.
- INSERT - Enum constant in enum class org.springframework.integration.cassandra.outbound.CassandraMessageHandler.Type
- 
Set aCassandraMessageHandlerinto aninsertmode.
- INSERT - Enum constant in enum class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler.Type
- 
Set aR2dbcMessageHandlerinto aninsertmode.
- INSTANCE - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
- 
A single reusable instance.
- INSTANCE - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayLfSerializer
- 
A single reusable instance.
- INSTANCE - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
- 
A single reusable instance that does not treat timeouts as end of message.
- INSTANCE - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
- 
A single reusable instance.
- INSTANCE - Static variable in class org.springframework.integration.JavaUtils
- 
The singleton instance of this utility class.
- INSTANCE - Static variable in class org.springframework.integration.support.management.observation.DefaultMessageReceiverObservationConvention
- 
A shared singleton instance forDefaultMessageReceiverObservationConvention.
- INSTANCE - Static variable in class org.springframework.integration.support.management.observation.DefaultMessageRequestReplyReceiverObservationConvention
- 
A shared singleton instance forDefaultMessageRequestReplyReceiverObservationConvention.
- INSTANCE - Static variable in class org.springframework.integration.support.management.observation.DefaultMessageSenderObservationConvention
- 
A shared singleton instance forDefaultMessageSenderObservationConvention.
- INTEGER - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- INTEGRATION_CONFIGURATION_POST_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- INTEGRATION_CONVERSION_SERVICE_BEAN_NAME - Static variable in class org.springframework.integration.support.utils.IntegrationUtils
- INTEGRATION_DATATYPE_CHANNEL_MESSAGE_CONVERTER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- INTEGRATION_EVALUATION_CONTEXT_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- INTEGRATION_FIXED_SUBSCRIBER_CHANNEL_BPP_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- INTEGRATION_GLOBAL_PROPERTIES_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- INTEGRATION_GRAPH_SERVER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- INTEGRATION_HEADER_CHANNEL_REGISTRY_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- INTEGRATION_LIFECYCLE_ROLE_CONTROLLER - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- INTEGRATION_MESSAGE_BUILDER_FACTORY_BEAN_NAME - Static variable in class org.springframework.integration.support.utils.IntegrationUtils
- INTEGRATION_MESSAGE_HISTORY_CONFIGURER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- INTEGRATION_PROPERTIES_PREFIX - Static variable in class org.springframework.integration.context.IntegrationProperties
- INTEGRATION_SIMPLE_EVALUATION_CONTEXT_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- integrationComponents - Variable in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- IntegrationComponentScan - Annotation Interface in org.springframework.integration.annotation
- 
Configures component scanning directives for use withConfigurationclasses.
- IntegrationComponentScanRegistrar - Class in org.springframework.integration.config
- 
ImportBeanDefinitionRegistrarimplementation to scan and register Integration specific components.
- IntegrationComponentScanRegistrar() - Constructor for class org.springframework.integration.config.IntegrationComponentScanRegistrar
- IntegrationComponentSpec<S,T> - Class in org.springframework.integration.dsl
- 
The common Builder abstraction.
- IntegrationComponentSpec() - Constructor for class org.springframework.integration.dsl.IntegrationComponentSpec
- IntegrationConfigurationBeanFactoryPostProcessor - Class in org.springframework.integration.config
- 
BeanDefinitionRegistryPostProcessorto apply external Integration infrastructure configurations via loadingIntegrationConfigurationInitializerimplementations usingSpringFactoriesLoader.
- IntegrationConfigurationBeanFactoryPostProcessor() - Constructor for class org.springframework.integration.config.IntegrationConfigurationBeanFactoryPostProcessor
- IntegrationConfigurationInitializer - Interface in org.springframework.integration.config
- 
The strategy to initialize the external Integration infrastructure (@{code BeanFactoryPostProcessor}s, global beans etc.) in the providedbeanFactory.
- IntegrationConfigUtils - Class in org.springframework.integration.config
- 
Shared utility methods for Integration configuration.
- IntegrationConsumer - Interface in org.springframework.integration.endpoint
- 
Message consumers implement this interface, the message handler within a consumer may or may not emit output messages.
- IntegrationContextUtils - Class in org.springframework.integration.context
- 
Utility methods for accessing common integration components from the BeanFactory.
- IntegrationContextUtils() - Constructor for class org.springframework.integration.context.IntegrationContextUtils
- IntegrationConverter - Annotation Interface in org.springframework.integration.config
- 
A marker annotation (an analogue of<int:converter/>) to registerConverter,GenericConverterorConverterFactorybeans for theintegrationConversionService.
- IntegrationConverterInitializer - Class in org.springframework.integration.config
- 
TheIntegrationConfigurationInitializerto populateConverterRegistrar.IntegrationConverterRegistrationfor converter beans marked with anIntegrationConverterannotation.
- IntegrationConverterInitializer() - Constructor for class org.springframework.integration.config.IntegrationConverterInitializer
- IntegrationDsl - Annotation Interface in org.springframework.integration.dsl
- 
The KotlinDslMarkerannotation for classes used in scope of DSL, including all the Java DSL classes.
- IntegrationEvaluationContextFactoryBean - Class in org.springframework.integration.config
- IntegrationEvaluationContextFactoryBean() - Constructor for class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
- IntegrationEvent - Class in org.springframework.integration.events
- 
Base class for allApplicationEvents generated by the framework.
- IntegrationEvent(Object) - Constructor for class org.springframework.integration.events.IntegrationEvent
- IntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.events.IntegrationEvent
- IntegrationFlow - Interface in org.springframework.integration.dsl
- 
The main Integration DSL abstraction.
- IntegrationFlowAdapter - Class in org.springframework.integration.dsl
- 
The baseAdapterclass for theIntegrationFlowabstraction.
- IntegrationFlowAdapter() - Constructor for class org.springframework.integration.dsl.IntegrationFlowAdapter
- IntegrationFlowBeanPostProcessor - Class in org.springframework.integration.dsl.context
- 
ABeanPostProcessorto parseIntegrationFlowbeans and register their components as beans in the providedBeanFactory, if necessary.
- IntegrationFlowBeanPostProcessor() - Constructor for class org.springframework.integration.dsl.context.IntegrationFlowBeanPostProcessor
- IntegrationFlowBuilder - Class in org.springframework.integration.dsl
- IntegrationFlowContext - Interface in org.springframework.integration.dsl.context
- 
A public API for dynamic (manual) registration ofIntegrationFlows, not via standard bean registration phase.
- IntegrationFlowContext.IntegrationFlowRegistration - Interface in org.springframework.integration.dsl.context
- IntegrationFlowContext.IntegrationFlowRegistrationBuilder - Interface in org.springframework.integration.dsl.context
- 
A Builder pattern implementation for the options to registerIntegrationFlowin the application context.
- IntegrationFlowDefinition<B> - Class in org.springframework.integration.dsl
- 
TheBaseIntegrationFlowDefinitionextension for syntax sugar with generics for some type-based EIP-methods when an expected payload type is assumed from upstream.
- IntegrationFlowExtension<B> - Class in org.springframework.integration.dsl
- 
AnIntegrationFlowDefinitionextension for custom Java DSL operators and reusable solutions.
- IntegrationFlowExtension() - Constructor for class org.springframework.integration.dsl.IntegrationFlowExtension
- IntegrationGraphController - Class in org.springframework.integration.http.management
- 
The REST Controller to provide the management API overIntegrationGraphServer.
- IntegrationGraphController(IntegrationGraphServer) - Constructor for class org.springframework.integration.http.management.IntegrationGraphController
- IntegrationGraphControllerParser - Class in org.springframework.integration.http.config
- 
TheBeanDefinitionParserfor the<int-http:graph-controller>component.
- IntegrationGraphControllerParser() - Constructor for class org.springframework.integration.http.config.IntegrationGraphControllerParser
- IntegrationGraphControllerRegistrar - Class in org.springframework.integration.http.config
- 
Registers the necessary beans forEnableIntegrationGraphController.
- IntegrationGraphControllerRegistrar() - Constructor for class org.springframework.integration.http.config.IntegrationGraphControllerRegistrar
- IntegrationGraphServer - Class in org.springframework.integration.graph
- 
Builds the runtime object model graph.
- IntegrationGraphServer() - Constructor for class org.springframework.integration.graph.IntegrationGraphServer
- IntegrationHandlerResultHandler - Class in org.springframework.integration.webflux.inbound
- 
AHandlerResultHandlerimplementation to handle the result of theWebFluxInboundEndpointexecution.
- IntegrationHandlerResultHandler() - Constructor for class org.springframework.integration.webflux.inbound.IntegrationHandlerResultHandler
- IntegrationInboundManagement - Interface in org.springframework.integration.support.management
- 
Marker interface indicating that thisIntegrationManagementcomponent initiates message flow.
- IntegrationInvocableHandlerMethod - Class in org.springframework.integration.handler.support
- 
AnInvocableHandlerMethodextension for Spring Integration requirements.
- IntegrationInvocableHandlerMethod(Object, Method) - Constructor for class org.springframework.integration.handler.support.IntegrationInvocableHandlerMethod
- IntegrationJmxAttributeSource - Class in org.springframework.integration.monitor
- 
TheAnnotationJmxAttributeSourceextension to resolveManagedResources viaIntegrationManagedResourceon classes.
- IntegrationJmxAttributeSource() - Constructor for class org.springframework.integration.monitor.IntegrationJmxAttributeSource
- IntegrationManagedResource - Annotation Interface in org.springframework.integration.support.management
- 
Clone ofManagedResourcelimiting beans thus annotated so that they will only be exported by theIntegrationMBeanExporterand prevented from being exported by other MBeanExporters (if present).
- IntegrationManagement - Interface in org.springframework.integration.support.management
- 
Base interface for Integration managed components.
- IntegrationManagement.ManagementOverrides - Class in org.springframework.integration.support.management
- 
Toggles to inform the management configurer to not set these properties since the user has manually configured them in a bean definition.
- IntegrationManagementConfiguration - Class in org.springframework.integration.config
- 
@Configurationclass that registers aIntegrationManagementConfigurerbean.
- IntegrationManagementConfiguration(ControlBusCommandRegistry) - Constructor for class org.springframework.integration.config.IntegrationManagementConfiguration
- IntegrationManagementConfigurer - Class in org.springframework.integration.config
- 
Configures beans that implementIntegrationManagement.
- IntegrationManagementConfigurer() - Constructor for class org.springframework.integration.config.IntegrationManagementConfigurer
- IntegrationManagementParser - Class in org.springframework.integration.config.xml
- 
Parser for the <management/> element.
- IntegrationManagementParser() - Constructor for class org.springframework.integration.config.xml.IntegrationManagementParser
- IntegrationMBeanExportConfiguration - Class in org.springframework.integration.jmx.config
- 
@Configurationclass that registers aIntegrationMBeanExporterbean.
- IntegrationMBeanExportConfiguration() - Constructor for class org.springframework.integration.jmx.config.IntegrationMBeanExportConfiguration
- IntegrationMBeanExporter - Class in org.springframework.integration.monitor
- 
MBean exporter for Spring Integration components in an existing application.
- IntegrationMBeanExporter() - Constructor for class org.springframework.integration.monitor.IntegrationMBeanExporter
- IntegrationMessageHandlerMethodFactory - Class in org.springframework.integration.handler.support
- 
Extension of theDefaultMessageHandlerMethodFactoryfor Spring Integration requirements.
- IntegrationMessageHandlerMethodFactory() - Constructor for class org.springframework.integration.handler.support.IntegrationMessageHandlerMethodFactory
- IntegrationMessageHandlerMethodFactory(boolean) - Constructor for class org.springframework.integration.handler.support.IntegrationMessageHandlerMethodFactory
- IntegrationMessageHeaderAccessor - Class in org.springframework.integration
- 
Adds standard SI Headers.
- IntegrationMessageHeaderAccessor(Message<?>) - Constructor for class org.springframework.integration.IntegrationMessageHeaderAccessor
- IntegrationNamespaceHandler - Class in org.springframework.integration.config.xml
- 
Namespace handler for the integration namespace.
- IntegrationNamespaceHandler() - Constructor for class org.springframework.integration.config.xml.IntegrationNamespaceHandler
- IntegrationNamespaceUtils - Class in org.springframework.integration.config.xml
- 
Shared utility methods for integration namespace parsers.
- IntegrationNamespaceUtils() - Constructor for class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- IntegrationNode - Class in org.springframework.integration.graph
- 
Base class for all nodes.
- IntegrationNode(int, String, Object) - Constructor for class org.springframework.integration.graph.IntegrationNode
- IntegrationObjectSupport - Class in org.springframework.integration.context
- 
A base class that provides convenient access to the bean factory as well asTaskSchedulerandConversionServiceinstances.
- IntegrationObjectSupport() - Constructor for class org.springframework.integration.context.IntegrationObjectSupport
- IntegrationObservation - Enum Class in org.springframework.integration.support.management.observation
- 
TheObservationDocumentationimplementation for Spring Integration infrastructure.
- IntegrationObservation.GatewayTags - Enum Class in org.springframework.integration.support.management.observation
- 
Key names for message handler observations.
- IntegrationObservation.HandlerTags - Enum Class in org.springframework.integration.support.management.observation
- 
Key names for message handler observations.
- IntegrationObservation.ProducerTags - Enum Class in org.springframework.integration.support.management.observation
- 
Key names for message producer observations.
- IntegrationPattern - Interface in org.springframework.integration
- 
Indicates that a component implements some Enterprise Integration Pattern.
- IntegrationPatternType - Enum Class in org.springframework.integration
- 
The Enterprise Integration Pattern types.
- IntegrationPatternType.IntegrationPatternCategory - Enum Class in org.springframework.integration
- 
The Enterprise Integration Pattern categories.
- IntegrationProperties - Class in org.springframework.integration.context
- 
Utility class to encapsulate infrastructure Integration properties constants and their default values.
- IntegrationProperties() - Constructor for class org.springframework.integration.context.IntegrationProperties
- IntegrationReactiveUtils - Class in org.springframework.integration.util
- 
Utilities for adapting integration components to/from reactive types.
- IntegrationRegistrar - Class in org.springframework.integration.config
- 
ImportBeanDefinitionRegistrarimplementation that configures integration infrastructure.
- IntegrationRegistrar() - Constructor for class org.springframework.integration.config.IntegrationRegistrar
- IntegrationRequestMappingHandlerMapping - Class in org.springframework.integration.http.inbound
- 
TheHandlerMappingimplementation that detects and registersRequestMappingInfos forHttpRequestHandlingEndpointSupportfrom a Spring Integration HTTP configuration of<inbound-channel-adapter/>and<inbound-gateway/>elements.
- IntegrationRequestMappingHandlerMapping() - Constructor for class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
- IntegrationResourceHolder - Class in org.springframework.integration.transaction
- 
An implementation of theResourceHolderwhich holds an instance of the current Message and the synchronization resource.
- IntegrationResourceHolder() - Constructor for class org.springframework.integration.transaction.IntegrationResourceHolder
- IntegrationResourceHolderSynchronization - Class in org.springframework.integration.transaction
- 
The baseResourceHolderSynchronizationforIntegrationResourceHolder.
- IntegrationResourceHolderSynchronization(IntegrationResourceHolder, Object) - Constructor for class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
- IntegrationRSocketEndpoint - Interface in org.springframework.integration.rsocket
- 
A markerReactiveMessageHandlerextension interface for Spring Integration inbound endpoints.
- IntegrationSimpleEvaluationContextFactoryBean - Class in org.springframework.integration.config
- 
FactoryBeanto populateSimpleEvaluationContextinstances enhanced with: aTypeConverterbased on theConversionServicefrom the application context.
- IntegrationSimpleEvaluationContextFactoryBean() - Constructor for class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
- IntegrationStompHeaders - Class in org.springframework.integration.stomp.support
- 
The STOMP headers with Integration-friendlystomp_prefix.
- IntegrationStompHeaders() - Constructor for class org.springframework.integration.stomp.support.IntegrationStompHeaders
- IntegrationUtils - Class in org.springframework.integration.support.utils
- 
General utility methods.
- IntegrationWebExchangeBindException - Exception Class in org.springframework.integration.http.support
- 
AWebExchangeBindExceptionextension for validation error with a failed message context.
- IntegrationWebExchangeBindException(String, Object, BindingResult) - Constructor for exception class org.springframework.integration.http.support.IntegrationWebExchangeBindException
- IntegrationWebSocketContainer - Class in org.springframework.integration.websocket
- 
The high-level 'connection factory pattern' contract over low-level Web-Socket configuration.
- IntegrationWebSocketContainer() - Constructor for class org.springframework.integration.websocket.IntegrationWebSocketContainer
- IntegrationXmlNamespaceHandler - Class in org.springframework.integration.xml.config
- IntegrationXmlNamespaceHandler() - Constructor for class org.springframework.integration.xml.config.IntegrationXmlNamespaceHandler
- interactionModel(String) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
- 
Configure a SpEL expression to evaluate anRSocketInteractionModelfor the RSocket request type at runtime against a request message.
- interactionModel(Function<Message<P>, ?>) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
- 
Configure aFunctionto evaluate anRSocketInteractionModelfor the RSocket request type at runtime against a request message.
- interactionModel(Expression) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
- 
Configure a SpEL expression to evaluate anRSocketInteractionModelfor the RSocket request type at runtime against a request message.
- interactionModel(RSocketInteractionModel) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
- 
Configure anRSocketInteractionModelfor the RSocket request type.
- interactionModels(RSocketInteractionModel...) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
- 
Configure a set ofRSocketInteractionModelthe endpoint is going to be mapped onto.
- intercept(ChannelInterceptor...) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Add one or moreChannelInterceptorimplementations to the currentBaseIntegrationFlowDefinition.currentMessageChannel, in the given order, after any interceptors already registered.
- interceptor(ChannelInterceptor...) - Method in class org.springframework.integration.dsl.MessageChannelSpec
- INTERCEPTOR_FACTORY_CHAIN - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- interceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
- interceptors - Variable in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
- interceptors - Variable in class org.springframework.integration.channel.AbstractMessageChannel
- interceptors(ClientInterceptor...) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
- 
Specify theClientInterceptors to use.
- interceptors(ClientInterceptor...) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
- 
Specify theClientInterceptors to use.
- intExpression(String) - Static method in class org.springframework.integration.expression.ExpressionUtils
- 
Return aValueExpressionfor a simple literal, otherwise aSpelExpression.
- invoke(MethodInvocation) - Method in class org.springframework.integration.amqp.support.BoundRabbitChannelAdvice
- invoke(MethodInvocation) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
- invoke(MethodInvocation) - Method in interface org.springframework.integration.aop.ReceiveMessageAdvice
- invoke(MethodInvocation) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
- invoke(MethodInvocation) - Method in class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
- invoke(MethodInvocation) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
- invoke(MethodInvocation) - Method in class org.springframework.integration.handler.advice.HandleMessageAdviceAdapter
- invoke(MethodInvocation) - Method in class org.springframework.integration.handler.advice.ReactiveRequestHandlerAdvice
- invoke(MethodInvocation) - Method in class org.springframework.integration.scheduling.PollSkipAdvice
- invoke(RemoteFileOperations.OperationsCallback<F, T>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
- 
Invoke the callback and run all operations on the template argument in a dedicated thread-bound session and reliably close the it afterwards.
- invoke(RemoteFileOperations.OperationsCallback<F, T>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
- invoke(MessageContext) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
- invokeCommand(String, List<ControlBusController.CommandArgument>) - Method in class org.springframework.integration.http.management.ControlBusController
- IP_ADDRESS - Static variable in class org.springframework.integration.ip.IpHeaders
- 
The ip address from which a TCP message or UDP packet was received.
- IP_PREFIX - Static variable in class org.springframework.integration.ip.IpHeaders
- 
The "ip_" prefix for UDP and TCP headers.
- IpAdapterParserUtils - Class in org.springframework.integration.ip.config
- 
Utility methods and constants for IP adapter parsers.
- IpHeaders - Class in org.springframework.integration.ip
- 
Headers for Messages mapped from IP datagram packets.
- IpIntegrationEvent - Class in org.springframework.integration.ip.event
- IpIntegrationEvent(Object) - Constructor for class org.springframework.integration.ip.event.IpIntegrationEvent
- IpIntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.ip.event.IpIntegrationEvent
- IpNamespaceHandler - Class in org.springframework.integration.ip.config
- 
Namespace handler for Spring Integration's ip namespace.
- IpNamespaceHandler() - Constructor for class org.springframework.integration.ip.config.IpNamespaceHandler
- is(char) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
- IS_POSIX - Static variable in class org.springframework.integration.file.support.FileUtils
- isAbstract() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
- isAckDeferred() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
- isAckDeferred() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
- isAcknowledge() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- isAcknowledged() - Method in interface org.springframework.integration.acks.AcknowledgmentCallback
- 
Implementations must implement this to indicate when the ack has been processed by the user so that the framework can auto-ack if needed.
- isAcknowledged() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
- isAcknowledged() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
- isAcquired(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
- isAcquired(String) - Method in interface org.springframework.integration.jdbc.lock.LockRepository
- 
Check if a lock is held by this repository.
- isActive() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
- isActive() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- isActive() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
- isAnnotation() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
- isAppend() - Method in class org.springframework.integration.ftp.server.FileWrittenEvent
- isAsync() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
- isAsync() - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
- isAsync() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
- isAsync() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
- isAsyncExecutorExplicitlySet() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
- isAutoAck() - Method in interface org.springframework.integration.acks.AcknowledgmentCallback
- 
Return true if this acknowledgment supports auto ack when it has not been already ack'd by the application.
- isAutoAck() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
- isAutoAck() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
- isAutoReceiptEnabled() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
- isAutoReceiptEnabled() - Method in interface org.springframework.integration.stomp.StompSessionManager
- isAutoStartup() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- isAutoStartup() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
- isAutoStartup() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- isAutoStartup() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
- isAutoStartup() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
- isAutoStartup() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
- isAutoStartup() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- isAutoStartup() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
- isAutoStartup() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
- isAutoStartup() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
- isAutoStartup() - Method in class org.springframework.integration.hazelcast.leader.LeaderInitiator
- isAutoStartup() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
- isAutoStartup() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
- isAutoStartup() - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
- isAutoStartup() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
- isAutoStartup() - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- isAutoStartup() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
- isAutoStartup() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
- isAutoStartup() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
- isAutoStartup() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
- isAutoStartup() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
- isAutoStartup() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
- isAutoStartup() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
- isAutoStartup() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
- isAutoStartup() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
- isAutoStartup() - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
- isAutoStartup() - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
- isAutoStartup() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
- isAutoStartup() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
- isAutoStartup() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
- isAutoStartup() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
- isAutoStartup() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
- isAutoStartup() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
- isBroadcast() - Method in interface org.springframework.integration.channel.BroadcastCapableChannel
- 
Return a state of this channel in regards of broadcasting capabilities.
- isBroadcast() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
- isChannelsAutoCreate() - Method in class org.springframework.integration.context.IntegrationProperties
- 
Return the value ofIntegrationProperties.CHANNELS_AUTOCREATEoption.
- isChmodCapable() - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- isChmodCapable() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
- isChmodCapable() - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- isChmodCapable() - Method in class org.springframework.integration.ftp.outbound.FtpMessageHandler
- isChmodCapable() - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
- isChmodCapable() - Method in class org.springframework.integration.sftp.outbound.SftpMessageHandler
- isClientMode() - Method in interface org.springframework.integration.ip.tcp.connection.ClientModeCapable
- isClientMode() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- isClientMode() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
- isClientMode() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
- isClientModeConnected() - Method in interface org.springframework.integration.ip.tcp.connection.ClientModeCapable
- isClientModeConnected() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- isClientModeConnected() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
- isClientModeConnected() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
- isClientSet() - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
- isClientSet() - Method in class org.springframework.integration.http.dsl.HttpMessageHandlerSpec
- isClientSet() - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
- isClosed() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
- isComplete() - Method in class org.springframework.integration.mongodb.store.MessageDocument
- isComplete() - Method in interface org.springframework.integration.store.MessageGroup
- isComplete() - Method in class org.springframework.integration.store.MessageGroupMetadata
- isComplete() - Method in class org.springframework.integration.store.SimpleMessageGroup
- isConnected() - Method in class org.springframework.integration.ip.tcp.connection.ClientModeConnectionManager
- isConnected() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
- isConnected() - Method in interface org.springframework.integration.mqtt.core.ClientManager
- 
Return the managed clients isConnected.
- isConnected() - Method in class org.springframework.integration.mqtt.core.Mqttv3ClientManager
- isConnected() - Method in class org.springframework.integration.mqtt.core.Mqttv5ClientManager
- isConnected() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
- isConnected() - Method in interface org.springframework.integration.stomp.StompSessionManager
- isConnected() - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
- 
Returntrueif theClientWebSocketContainer.clientSessionis opened.
- isContextPropagationPresent - Static variable in class org.springframework.integration.util.IntegrationReactiveUtils
- 
The indicator thatio.micrometer:context-propagationlibrary is on classpath.
- isContinuation(Object) - Static method in class org.springframework.integration.util.CoroutinesUtils
- isContinuationType(Class<?>) - Static method in class org.springframework.integration.util.CoroutinesUtils
- isDefaultToParentFlow() - Method in class org.springframework.integration.dsl.AbstractRouterSpec
- isDigit() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
- isDirectory() - Method in interface org.springframework.integration.file.remote.FileInfo
- isDirectory() - Method in class org.springframework.integration.ftp.server.PathRemovedEvent
- isDirectory() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
- isDirectory() - Method in class org.springframework.integration.sftp.server.PathRemovedEvent
- isDirectory() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
- isDirectory() - Method in class org.springframework.integration.smb.session.SmbFileInfo
- isDirectory(F) - Method in class org.springframework.integration.file.filters.AbstractDirectoryAwareFileListFilter
- 
Subclasses must implement this method to indicate whether the file is a directory or not.
- isDirectory(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- isDirectory(F) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
- isDirectory(F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- isDirectory(File) - Method in class org.springframework.integration.file.filters.FileSystemPersistentAcceptOnceFileListFilter
- isDirectory(File) - Method in class org.springframework.integration.file.filters.RegexPatternFileListFilter
- isDirectory(File) - Method in class org.springframework.integration.file.filters.SimplePatternFileListFilter
- isDirectory(String) - Method in class org.springframework.integration.smb.session.SmbSession
- 
Check whether the remote resource is a directory.
- isDirectory(SmbFile) - Method in class org.springframework.integration.smb.filters.SmbRegexPatternFileListFilter
- isDirectory(SmbFile) - Method in class org.springframework.integration.smb.filters.SmbSimplePatternFileListFilter
- isDirectory(SmbFile) - Method in class org.springframework.integration.smb.inbound.SmbStreamingMessageSource
- isDirectory(SmbFile) - Method in class org.springframework.integration.smb.outbound.SmbOutboundGateway
- isDirectory(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpPersistentAcceptOnceFileListFilter
- isDirectory(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpRegexPatternFileListFilter
- isDirectory(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpSimplePatternFileListFilter
- isDirectory(FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- isDirectory(FTPFile) - Method in class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
- isDirectory(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.filters.SftpPersistentAcceptOnceFileListFilter
- isDirectory(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
- isDirectory(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.filters.SftpSimplePatternFileListFilter
- isDirectory(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
- isDirectory(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
- isDiscarded() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
- isEligibleAttribute(String) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
- isEligibleAttribute(String) - Method in class org.springframework.integration.ip.config.TcpInboundGatewayParser
- isEligibleAttribute(String) - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
- isEligibleAttribute(String) - Method in class org.springframework.integration.redis.config.RedisQueueInboundGatewayParser
- isEligibleAttribute(String) - Method in class org.springframework.integration.rsocket.config.RSocketInboundGatewayParser
- isEligibleAttribute(String) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
- isEmpty() - Method in class org.springframework.integration.expression.ExpressionEvalMap
- isEmpty() - Method in class org.springframework.integration.history.MessageHistory
- isEmpty() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
- isEmptyPayload(Object) - Method in class org.springframework.integration.support.NullAwarePayloadArgumentResolver
- isEqual(F, String) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- 
Override this method if you wish to use something other than the modified timestamp to determine equality.
- isErrorChannelIgnoreFailures() - Method in class org.springframework.integration.context.IntegrationProperties
- 
Return the value ofIntegrationProperties.ERROR_CHANNEL_IGNORE_FAILURESoption.
- isErrorChannelRequireSubscribers() - Method in class org.springframework.integration.context.IntegrationProperties
- 
Return the value ofIntegrationProperties.ERROR_CHANNEL_REQUIRE_SUBSCRIBERSoption.
- isExpectReply() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
- isExpectReply() - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
- isExpectSingleResult() - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
- isExpireGroupsUponCompletion() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- isExpireGroupsUponCompletion() - Method in class org.springframework.integration.aggregator.AggregatingMessageHandler
- isExtractPayload() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- isFair() - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
- isFile(F) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
- isFile(String) - Method in class org.springframework.integration.smb.session.SmbSession
- 
Check whether the remote resource is a file.
- isFile(SmbFile) - Method in class org.springframework.integration.smb.inbound.SmbInboundFileSynchronizer
- isFile(FTPFile) - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizer
- isFile(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
- isFinal() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
- isFixedRate() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
- 
Return whether this trigger is fixed rate.
- isForRecursion() - Method in class org.springframework.integration.file.filters.AbstractDirectoryAwareFileListFilter
- isForRecursion() - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
- isForRecursion() - Method in interface org.springframework.integration.file.filters.FileListFilter
- 
Return true if this filter is being used for recursion.
- isFrameContainingXBeforeFrameContainingY(String, String, StackTraceElement[]) - Static method in class org.springframework.integration.util.StackTraceUtils
- 
Traverses the stack trace element array looking for instances that contain the first or second Strings in the className property.
- isHandler(Class<?>) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
- isHandler(Class<?>) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
- isHeadersMappedLast() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- isImplicitChannel() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- isInclusive() - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
- 
Return true if the length header value includes its own length.
- isIndependent() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
- isInitialized() - Method in class org.springframework.integration.context.IntegrationObjectSupport
- 
Return the status of this component if it has been initialized already.
- isInitialized() - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
- isInitialized() - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
- isInitialized() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
- isInitialized() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
- isInputShutdown() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
- isInterface() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
- isJackson2Present() - Static method in class org.springframework.integration.support.json.JacksonPresent
- isKotlinFunction0(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
- 
Check if class iskotlin.jvm.functions.Function0.
- isKotlinFunction1(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
- 
Check if class iskotlin.jvm.functions.Function1.
- isKotlinUnit(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
- 
Check if class iskotlin.Unit.
- isLambda(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
- 
Check if class is Java or Kotlin lambda.
- isLambda(Object) - Static method in class org.springframework.integration.util.ClassUtils
- 
Check if object is Java, Kotlin or Groovy lambda.
- isLazyConnect() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- isLeader() - Method in class org.springframework.integration.hazelcast.leader.LeaderInitiator.HazelcastContext
- isLeader() - Method in interface org.springframework.integration.leader.Context
- 
Checks if theCandidatethis context was passed to is the leader.
- isLeader() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator.LeaderSelector
- isLeader() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator.CuratorContext
- isLink() - Method in interface org.springframework.integration.file.remote.FileInfo
- isLink() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
- isLink() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
- isLink() - Method in class org.springframework.integration.smb.session.SmbFileInfo
- 
Symbolic links are currently not supported in the JCIFS v2.x.x dependent library, so this method will always return false.
- isLink(F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- isLink(SmbFile) - Method in class org.springframework.integration.smb.outbound.SmbOutboundGateway
- 
Symbolic links are currently not supported in the JCIFS v2.x.x dependent library, so this method will always return false.
- isLink(FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- isLink(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
- isListening() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
- isListening() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
- isListening() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- isListening() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
- isListening() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
- isListening() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
- isLockable(File) - Method in interface org.springframework.integration.file.FileLocker
- 
Checks whether the file passed in can be locked by this locker.
- isLockable(File) - Method in class org.springframework.integration.file.locking.NioFileLocker
- isLockRegistrySet() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- isLoggingEnabled() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- isLoggingEnabled() - Method in class org.springframework.integration.channel.AbstractMessageChannel
- isLoggingEnabled() - Method in class org.springframework.integration.channel.NullChannel
- isLoggingEnabled() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
- isLoggingEnabled() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- isLoggingEnabled() - Method in class org.springframework.integration.handler.MessageHandlerSupport
- isLoggingEnabled() - Method in interface org.springframework.integration.support.management.IntegrationManagement
- 
Return whether logging is enabled.
- isLongLived() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
- isLongLived() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
- isLongLived() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
- isLongLived() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
- isLongLived() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
- isLookupHost() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- isLookupHost() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
- isLookupHost() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
- isLost() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
- isManualAcks() - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
- isManualAcks() - Method in interface org.springframework.integration.mqtt.core.ClientManager
- 
If manual acknowledge has to be used; false by default.
- isManualAcks() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
- isMapToPayload() - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
- isMessagingTemplateThrowExceptionOnLateReply() - Method in class org.springframework.integration.context.IntegrationProperties
- 
Return the value ofIntegrationProperties.THROW_EXCEPTION_ON_LATE_REPLYoption.
- isModified() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
- isNegated() - Method in interface org.springframework.integration.mapping.AbstractHeaderMapper.HeaderMatcher
- 
Return true if this match should be explicitly excluded from the mapping.
- isNegated() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
- isNoReadErrorOnClose() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
- isObserved() - Method in class org.springframework.integration.channel.AbstractMessageChannel
- isObserved() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
- isObserved() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- isObserved() - Method in class org.springframework.integration.graph.IntegrationNode
- 
Return true if this component is instrumented with an observation.
- isObserved() - Method in class org.springframework.integration.handler.MessageHandlerSupport
- isObserved() - Method in interface org.springframework.integration.support.management.IntegrationManagement
- 
True if this implementation is going to deal with a registry other than theObservationRegistry.NOOPinstance.
- isolation(Isolation) - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
- isOpen() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
- isOpen() - Method in interface org.springframework.integration.file.remote.session.Session
- isOpen() - Method in class org.springframework.integration.ftp.session.FtpSession
- isOpen() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
- isOpen() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- isOpen() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
- isOpen() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
- isOpen() - Method in class org.springframework.integration.sftp.session.SftpSession
- isOpen() - Method in class org.springframework.integration.smb.session.SmbSession
- 
Check whether this SMB session is open and ready for work by attempting to list remote files and checking for error conditions.
- isOutputChannelRequired() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- isOutputShutdown() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
- isOverwrite() - Method in class org.springframework.integration.transformer.support.AbstractHeaderValueMessageProcessor
- isOverwrite() - Method in interface org.springframework.integration.transformer.support.HeaderValueMessageProcessor
- isOverwrite() - Method in class org.springframework.integration.xml.transformer.support.XPathExpressionEvaluatingHeaderValueMessageProcessor
- isPaused() - Method in interface org.springframework.integration.core.Pausable
- 
Check if the endpoint is paused.
- isPaused() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
- isPaused() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
- isPaused() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
- isPayloadAsBytes() - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
- isPriorityEnabled() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
- isPriorityEnabled() - Method in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
- isPriorityEnabled() - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
- isPriorityEnabled() - Method in interface org.springframework.integration.store.PriorityCapableChannelMessageStore
- isPublishFailedEvents() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
- isPushbackCapable() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionSupport
- isRawMessageHeader() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
- isRawMessageHeader() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
- isReactive() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
- isReactive() - Method in class org.springframework.integration.endpoint.PollingConsumer
- isReactive() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
- isReadable(HttpMethod) - Static method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
- 
Checks if the request has a readable body (not a GET, HEAD, or OPTIONS request).
- isReadOnly(String) - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
- isReceiveOnlyAdvice(Advice) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
- 
Return true if this advice should be applied only to theAbstractPollingEndpoint.receiveMessage()operation rather than the whole poll.
- isReleaseLockBeforeSend() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- isReleasePartialSequences() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- isRetained() - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory.Will
- isRolledBack() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
- isRolledBack() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
- isRunning() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- isRunning() - Method in class org.springframework.integration.aggregator.DelegatingMessageGroupProcessor
- isRunning() - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
- isRunning() - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
- isRunning() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
- isRunning() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
- isRunning() - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
- isRunning() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- isRunning() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
- isRunning() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- isRunning() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- isRunning() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
- isRunning() - Method in class org.springframework.integration.channel.FluxMessageChannel
- isRunning() - Method in class org.springframework.integration.channel.interceptor.WireTap
- 
Check whether the wire tap is currently running.
- isRunning() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
- isRunning() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
- isRunning() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
- isRunning() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- isRunning() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
- isRunning() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
- isRunning() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
- isRunning() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
- isRunning() - Method in class org.springframework.integration.file.FileReadingMessageSource
- isRunning() - Method in class org.springframework.integration.file.FileWritingMessageHandler
- isRunning() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
- isRunning() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
- isRunning() - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
- isRunning() - Method in class org.springframework.integration.filter.MessageFilter
- isRunning() - Method in class org.springframework.integration.gateway.GatewayMessageHandler
- isRunning() - Method in class org.springframework.integration.handler.MessageHandlerChain
- isRunning() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
- isRunning() - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
- isRunning() - Method in class org.springframework.integration.handler.ReplyProducingMessageHandlerWrapper
- isRunning() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
- isRunning() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper
- isRunning() - Method in class org.springframework.integration.hazelcast.leader.LeaderInitiator
- 
trueif leadership election for thisLeaderInitiator.candidateis running.
- isRunning() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
- isRunning() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
- isRunning() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
- isRunning() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- isRunning() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
- isRunning() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
- 
Return true if all factories are running.
- isRunning() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
- isRunning() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
- isRunning() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
- isRunning() - Method in class org.springframework.integration.jdbc.channel.PostgresChannelMessageTableSubscriber
- isRunning() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
- isRunning() - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
- isRunning() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
- isRunning() - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- isRunning() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
- isRunning() - Method in class org.springframework.integration.jms.JmsOutboundGateway
- isRunning() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
- isRunning() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
- isRunning() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
- isRunning() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
- isRunning() - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
- isRunning() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
- isRunning() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
- isRunning() - Method in class org.springframework.integration.router.ExpressionEvaluatingRouter
- isRunning() - Method in class org.springframework.integration.router.MethodInvokingRouter
- isRunning() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
- isRunning() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
- isRunning() - Method in class org.springframework.integration.splitter.ExpressionEvaluatingSplitter
- isRunning() - Method in class org.springframework.integration.splitter.MethodInvokingSplitter
- isRunning() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
- isRunning() - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
- isRunning() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
- isRunning() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
- isRunning() - Method in interface org.springframework.integration.support.management.ManageableLifecycle
- isRunning() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
- isRunning() - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
- isRunning() - Method in class org.springframework.integration.transformer.ContentEnricher
- 
Lifecycle implementation.
- isRunning() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
- isRunning() - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
- isRunning() - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
- isRunning() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
- isRunning() - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
- isRunning() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
- isRunning() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
- isRunning() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
- isRunning() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
- isRunning() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
- isSendPartialResultOnExpiry() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- isSequenceAware() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- isServer() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
- isServer() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- isServer() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
- isSessionTransacted() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
- isSharedSession() - Method in interface org.springframework.integration.file.remote.session.SharedSessionCapable
- isSharedSession() - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
- isShouldMarkMessagesAsRead() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
- isShouldMarkMessagesAsRead() - Method in class org.springframework.integration.mail.ImapMailReceiver
- 
Check if messages should be marked as read.
- isShuttingDown() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
- isSingleStatementForPoll() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
- 
Indicate if the queries for polling are using a single statement (e.g.
- isSingleStatementForPoll() - Method in class org.springframework.integration.jdbc.store.channel.PostgresChannelMessageStoreQueryProvider
- isSingleton() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
- isSingleton() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
- isSingleton() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
- isSingleton() - Method in class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
- isSingleton() - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
- isSingleton() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
- isSingleton() - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
- isSingleton() - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- isSingleUse() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- isSingleUse() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
- isSoKeepAlive() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- isSoKeepAlive() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
- isSoKeepAlive() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
- isSoTcpNoDelay() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- isSoTcpNoDelay() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
- isSoTcpNoDelay() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
- isStale(T) - Method in interface org.springframework.integration.util.SimplePool.PoolItemCallback
- 
Called by the pool when an idle item is retrieved from the pool.
- isStatusDirty(int) - Method in class org.springframework.integration.sftp.session.SftpRemoteFileTemplate
- 
Check ifSftpException.getStatus()is treated as fatal.
- isStatusDirty(int) - Method in class org.springframework.integration.smb.session.SmbRemoteFileTemplate
- 
Check ifSmbException.getNtStatus()is treated as fatal.
- isStatusDirty(String) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
- 
Check ifThrowable.getMessage()is treated as fatal.
- isSyncExecutor() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
- isSyncExecutor() - Method in class org.springframework.integration.util.ErrorHandlingTaskExecutor
- isTimeoutOnIdle() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
- isTransacted() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
- isTransacted() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
- isUseIdAsPrefix(String) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
- 
Return true to prefix flow bean names with the flow id and a period.
- isUseIdAsPrefix(String) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
- isUseTemporaryFileName() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
- isUseTemporaryFileName() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
- isUseWatchService() - Method in class org.springframework.integration.file.FileReadingMessageSource
- isUsingDirectBuffers() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
- isUsingDirectBuffers() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
- isUsingDirectBuffers() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
- isUsingReplyProducer() - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
- 
Override this to signal that this channel adapter is actually using a AbstractReplyProducingMessageHandler while it is not possible for this parser to determine that because, say, a FactoryBean is being used.
- isUsingReplyProducer() - Method in class org.springframework.integration.file.config.FileOutboundChannelAdapterParser
- isUsingReplyProducer() - Method in class org.springframework.integration.jpa.config.xml.JpaOutboundChannelAdapterParser
- isVoid() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
- isWritable(Object) - Method in class org.springframework.integration.expression.DynamicExpression
- isWritable(Object) - Method in class org.springframework.integration.expression.FunctionExpression
- isWritable(Object) - Method in class org.springframework.integration.expression.SupplierExpression
- isWritable(Object) - Method in class org.springframework.integration.expression.ValueExpression
- isWritable(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
- isWritable(EvaluationContext) - Method in class org.springframework.integration.expression.FunctionExpression
- isWritable(EvaluationContext) - Method in class org.springframework.integration.expression.SupplierExpression
- isWritable(EvaluationContext) - Method in class org.springframework.integration.expression.ValueExpression
- isWritable(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
- isWritable(EvaluationContext, Object) - Method in class org.springframework.integration.expression.FunctionExpression
- isWritable(EvaluationContext, Object) - Method in class org.springframework.integration.expression.SupplierExpression
- isWritable(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
- iterator() - Method in class org.springframework.integration.history.MessageHistory
- iterator() - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- iterator() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- iterator() - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- iterator() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
- iterator() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- iterator() - Method in class org.springframework.integration.store.MessageGroupQueue
- iterator() - Method in interface org.springframework.integration.store.MessageGroupStore
- iterator() - Method in class org.springframework.integration.store.SimpleMessageStore
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form