Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
C
- CACHE_NAME - Static variable in class org.springframework.integration.hazelcast.HazelcastHeaders
- 
The cache name header name.
- CacheEventType - Enum Class in org.springframework.integration.hazelcast
- 
Enumeration of Cache Event Types.
- cacheLevel(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
- 
Specify the level of caching that this listener container is allowed to apply.
- cacheLevel(Integer) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
- 
Only applies if theJmsMessageChannelSpec.containerType(Class)is aDefaultMessageListenerContainer.
- cacheLevel(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
- cacheLevelName(String) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
- 
Specify the level of caching that this listener container is allowed to apply, in the form of the name of the corresponding constant: e.g.
- CacheListeningPolicyType - Enum Class in org.springframework.integration.hazelcast
- 
Enumeration of Cache Listening Policy Type.
- CacheRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
- 
TheAbstractRequestHandlerAdviceimplementation for cachingAbstractReplyProducingMessageHandler.RequestHandler#handleRequestMessage(Message)results.
- CacheRequestHandlerAdvice(String...) - Constructor for class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
- 
Create aCacheRequestHandlerAdviceinstance based on the provided name of caches andCacheableOperationas default one.
- CachingClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
- 
Connection factory that caches connections from the underlying target factory.
- CachingClientConnectionFactory(AbstractClientConnectionFactory, int) - Constructor for class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
- 
Construct a caching connection factory that delegates to the provided factory, with the provided pool size.
- CachingSessionFactory<F> - Class in org.springframework.integration.file.remote.session
- 
ASessionFactoryimplementation that caches Sessions for reuse without requiring reconnection each time the Session is retrieved from the factory.
- CachingSessionFactory(SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.session.CachingSessionFactory
- 
Create a CachingSessionFactory with an unlimited number of sessions.
- CachingSessionFactory(SessionFactory<F>, int) - Constructor for class org.springframework.integration.file.remote.session.CachingSessionFactory
- 
Create a CachingSessionFactory with the specified session limit.
- CachingSessionFactory.CachedSession - Class in org.springframework.integration.file.remote.session
- call() - Method in class org.springframework.integration.hazelcast.leader.LeaderInitiator.LeaderSelector
- call() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator.LeaderSelector
- CallerBlocksPolicy - Class in org.springframework.integration.util
- 
ARejectedExecutionHandlerthat blocks the caller until the executor has room in its queue, or a timeout occurs (in which case aRejectedExecutionExceptionis thrown.
- CallerBlocksPolicy(long) - Constructor for class org.springframework.integration.util.CallerBlocksPolicy
- 
Construct instance based on the provided maximum wait time.
- Camel - Class in org.springframework.integration.camel.dsl
- 
Factory class for Apache Camel components DSL.
- CamelHeaderMapper - Class in org.springframework.integration.camel.support
- 
AHeaderMapperfor mapping headers from Spring Integration message to Apache Camel message and back.
- CamelHeaderMapper() - Constructor for class org.springframework.integration.camel.support.CamelHeaderMapper
- CamelMessageHandler - Class in org.springframework.integration.camel.outbound
- 
AMessageHandlerfor calling Apache Camel route and produce (optionally) a reply.
- CamelMessageHandler() - Constructor for class org.springframework.integration.camel.outbound.CamelMessageHandler
- CamelMessageHandler(ProducerTemplate) - Constructor for class org.springframework.integration.camel.outbound.CamelMessageHandler
- CamelMessageHandlerSpec - Class in org.springframework.integration.camel.dsl
- 
TheMessageHandlerSpecforCamelMessageHandler.
- CamelMessageHandlerSpec(ProducerTemplate) - Constructor for class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
- canAdd(Message<?>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler.SequenceAwareMessageGroup
- 
This method determines whether messages have been added to this group that supersede the given message based on its sequence id.
- canAdd(Message<?>) - Method in interface org.springframework.integration.store.MessageGroup
- 
Query if the message can be added.
- canAdd(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.FilterFactoryBean
- 
MessageFilter is an ARPMH.
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.RouterFactoryBean
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
- 
Always returns true - anyAbstractMessageProducingHandlercan be used directly.
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.SplitterFactoryBean
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.TransformerFactoryBean
- 
Always returns true - anyAbstractMessageProducingHandlercan be used directly.
- cancelIdleInterval(long) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
- 
How often to recycle the idle task (in case of a silently dropped connection).
- cancelPing() - Method in class org.springframework.integration.mail.ImapMailReceiver
- 
The hook to be called when we need to cancel the current ping task and close the mail folder.
- canConvert(Class<?>, Class<?>) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
- canConvert(TypeDescriptor, TypeDescriptor) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
- Candidate - Interface in org.springframework.integration.leader
- 
Interface that defines the contract for candidates to participate in a leader election.
- canRead(Class<?>, MediaType) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
- canRead(EvaluationContext, Object, String) - Method in class org.springframework.integration.json.JsonPropertyAccessor
- canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingReleaseStrategy
- 
Evaluate the expression provided on theMessageGroupand return the result (must be boolean).
- canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.MessageCountReleaseStrategy
- 
Release the group if it has more messages than the threshold and has not previously been released.
- canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
- canRelease(MessageGroup) - Method in interface org.springframework.integration.aggregator.ReleaseStrategy
- canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
- canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.SimpleSequenceSizeReleaseStrategy
- canRelease(MessageGroup) - Method in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
- canRelease(MessageGroup) - Method in class org.springframework.integration.file.aggregator.FileAggregator
- canRelease(MessageGroup) - Method in class org.springframework.integration.file.aggregator.FileMarkerReleaseStrategy
- canWrite(Class<?>, MediaType) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
- canWrite(Class<?>, MediaType) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
- canWrite(EvaluationContext, Object, String) - Method in class org.springframework.integration.json.JsonPropertyAccessor
- capacity - Variable in class org.springframework.integration.dsl.QueueChannelSpec
- capacity(int) - Method in class org.springframework.integration.dsl.PriorityChannelSpec
- capacity(Integer) - Method in class org.springframework.integration.dsl.QueueChannelSpec.MessageStoreSpec
- Cassandra - Class in org.springframework.integration.cassandra.dsl
- 
Factory class for Apache Cassandra components DSL.
- CassandraMessageHandler - Class in org.springframework.integration.cassandra.outbound
- 
AnAbstractReplyProducingMessageHandlerimplementation for Cassandra outbound operations.
- CassandraMessageHandler(ReactiveCassandraOperations) - Constructor for class org.springframework.integration.cassandra.outbound.CassandraMessageHandler
- CassandraMessageHandler(ReactiveCassandraOperations, CassandraMessageHandler.Type) - Constructor for class org.springframework.integration.cassandra.outbound.CassandraMessageHandler
- CassandraMessageHandler.Type - Enum Class in org.springframework.integration.cassandra.outbound
- 
The mode for theCassandraMessageHandler.
- CassandraMessageHandlerSpec - Class in org.springframework.integration.cassandra.dsl
- CassandraMessageHandlerSpec(ReactiveCassandraOperations) - Constructor for class org.springframework.integration.cassandra.dsl.CassandraMessageHandlerSpec
- CassandraMessageHandlerSpec(ReactiveCassandraOperations, CassandraMessageHandler.Type) - Constructor for class org.springframework.integration.cassandra.dsl.CassandraMessageHandlerSpec
- CassandraNamespaceHandler - Class in org.springframework.integration.cassandra.config.xml
- 
The namespace handler for "int-cassandra" namespace.
- CassandraNamespaceHandler() - Constructor for class org.springframework.integration.cassandra.config.xml.CassandraNamespaceHandler
- CassandraOutboundChannelAdapterParser - Class in org.springframework.integration.cassandra.config.xml
- 
The parser for the<int-cassandra:outbound-channel-adapter>.
- CassandraOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.cassandra.config.xml.CassandraOutboundChannelAdapterParser
- CassandraOutboundGatewayParser - Class in org.springframework.integration.cassandra.config.xml
- 
The parser for the<int-cassandra:outbound-gateway>.
- CassandraOutboundGatewayParser() - Constructor for class org.springframework.integration.cassandra.config.xml.CassandraOutboundGatewayParser
- CassandraParserUtils - Class in org.springframework.integration.cassandra.config.xml
- 
Theint-cassandranamespace XML parser helper.
- categories() - Element in annotation interface org.springframework.integration.test.condition.LogLevels
- 
Category names representing Log4j categories to change.
- categories(boolean, String...) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
- 
Specify the categories for logging level adjusting configured before.
- categories(String...) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
- 
Specify the categories for logging level adjusting configured before.
- categoryLevels() - Method in record class org.springframework.integration.test.util.TestUtils.LevelsContainer
- 
Returns the value of thecategoryLevelsrecord component.
- cause - Variable in class org.springframework.integration.events.IntegrationEvent
- cc(String...) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set the cc: addresses.
- CC - Static variable in class org.springframework.integration.mail.MailHeaders
- ccExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set the expression that will be evaluated to determine the cc: addresses.
- ccFunction(Function<Message<P>, String[]>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set a function that will be invoked to determine the cc: addresses based on the message.
- chain - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- ChainFileListFilter<F> - Class in org.springframework.integration.file.filters
- 
TheCompositeFileListFilterextension which chains the result of the previous filter to the next one.
- ChainFileListFilter() - Constructor for class org.springframework.integration.file.filters.ChainFileListFilter
- ChainFileListFilter(Collection<? extends FileListFilter<F>>) - Constructor for class org.springframework.integration.file.filters.ChainFileListFilter
- ChainParser - Class in org.springframework.integration.config.xml
- 
Parser for the <chain> element.
- ChainParser() - Constructor for class org.springframework.integration.config.xml.ChainParser
- CHANGE_STREAM_OPERATION_TYPE - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
- 
The header for change stream event type.
- CHANGE_STREAM_RESUME_TOKEN - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
- 
The header for change stream event resume token.
- CHANGE_STREAM_TIMESTAMP - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
- 
The header for change stream event timestamp.
- changeStreamInboundChannelAdapter(ReactiveMongoOperations) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aMongoDbChangeStreamMessageProducerSpecbuilder instance based on the providedReactiveMongoOperations.
- channel - Variable in class org.springframework.integration.dsl.MessageChannelSpec
- channel() - Element in annotation interface org.springframework.integration.annotation.InboundChannelAdapter
- channel() - Element in annotation interface org.springframework.integration.annotation.Publisher
- channel() - Method in record class org.springframework.integration.channel.DefaultHeaderChannelRegistry.MessageChannelWrapper
- 
Returns the value of thechannelrecord component.
- channel(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
- 
The factory to produce aJmsMessageChannelSpec.
- channel(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate aMessageChannelReferenceinstance at the currentIntegrationFlowchain position.
- channel(String, ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
- 
The factory to produce aJmsMessageChannelSpec.
- channel(String, ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initial AmqpMessageChannelSpec.
- channel(Function<Channels, MessageChannelSpec<?, ?>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate aMessageChannelinstance at the currentIntegrationFlowchain position using theChannelsfactory fluent API.
- channel(ConnectionFactory) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initial AmqpMessageChannelSpec.
- channel(MessageChannelSpec<?, ?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate aMessageChannelinstance at the currentIntegrationFlowchain position using theMessageChannelSpecfluent API.
- channel(KafkaTemplate<?, ?>, KafkaListenerContainerFactory<?>, String) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- 
Create a spec for a subscribable channel with the provided parameters.
- channel(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate the providedMessageChannelinstance at the currentIntegrationFlowchain position.
- CHANNEL_INITIALIZER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- CHANNEL_RESOLVER_BEAN_NAME - Static variable in class org.springframework.integration.support.channel.ChannelResolverUtils
- ChannelInitializer - Class in org.springframework.integration.config
- 
AInitializingBeanimplementation that is responsible for creating channels that are not explicitly defined but identified via the 'input-channel' attribute of the corresponding endpoints.
- ChannelInitializer.AutoCreateCandidatesCollector - Class in org.springframework.integration.config
- ChannelInterceptorList(LogAccessor) - Constructor for class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
- ChannelInterceptorParser - Class in org.springframework.integration.config.xml
- 
A helper class for parsing the sub-elements of a channel's interceptors element.
- ChannelInterceptorParser() - Constructor for class org.springframework.integration.config.xml.ChannelInterceptorParser
- channelKeyFallback(boolean) - Method in class org.springframework.integration.dsl.RouterSpec
- 
When true (default), if a resolved channel key does not exist in the channel map, the key itself is used as the channel name, which we will attempt to resolve to a channel.
- channelMapping(K, String) - Method in class org.springframework.integration.dsl.RouterSpec
- channelMapping(K, MessageChannel) - Method in class org.springframework.integration.dsl.RouterSpec
- 
The router mapping configuration based on the provided generic key andMessageChannelbean.
- channelMappings() - Element in annotation interface org.springframework.integration.annotation.Router
- 
The 'key=value' pairs to represent channelMapping entries.
- ChannelMessageStore - Interface in org.springframework.integration.store
- 
A marker interface that indicates this message store has optimizations for use in aQueueChannel.
- ChannelMessageStorePreparedStatementSetter - Class in org.springframework.integration.jdbc.store.channel
- 
Callback to be used with theJdbcChannelMessageStore.
- ChannelMessageStorePreparedStatementSetter() - Constructor for class org.springframework.integration.jdbc.store.channel.ChannelMessageStorePreparedStatementSetter
- 
The default constructor for inheritors who are not interested in the message serialization tobyte[].
- ChannelMessageStorePreparedStatementSetter(SerializingConverter, LobHandler) - Constructor for class org.springframework.integration.jdbc.store.channel.ChannelMessageStorePreparedStatementSetter
- 
Instantiate aChannelMessageStorePreparedStatementSetterwith the provided serializer and lobHandler, which both must not be null.
- ChannelMessageStoreQueryProvider - Interface in org.springframework.integration.jdbc.store.channel
- 
Common interface used in order to configure theJdbcChannelMessageStoreto provide database-specific queries.
- channelNameToChannel(String) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
- channelNameToChannel(String) - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
- 
Converts the channel name back to aMessageChannel(if it is registered).
- ChannelPublishingJmsMessageListener - Class in org.springframework.integration.jms
- 
JMS MessageListener that converts a JMS Message into a Spring Integration Message and sends that Message to a channel.
- ChannelPublishingJmsMessageListener() - Constructor for class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
- ChannelPurger - Class in org.springframework.integration.channel
- 
A utility class for purgingMessagesfrom one or moreQueueChannels.
- ChannelPurger(QueueChannel...) - Constructor for class org.springframework.integration.channel.ChannelPurger
- ChannelPurger(MessageSelector, QueueChannel...) - Constructor for class org.springframework.integration.channel.ChannelPurger
- channelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- 
Specify theDestinationResolverstrategy to use.
- ChannelResolverUtils - Class in org.springframework.integration.support.channel
- 
Channel resolution utilities.
- channels - Variable in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
- Channels - Class in org.springframework.integration.dsl
- CHANNELS_AUTOCREATE - Static variable in class org.springframework.integration.context.IntegrationProperties
- 
Specifies whether to allow create automaticallyDirectChannelbeans for non-declared channels or not.
- CHANNELS_MAX_BROADCAST_SUBSCRIBERS - Static variable in class org.springframework.integration.context.IntegrationProperties
- 
Specifies the value forAbstractDispatcher.maxSubscribersin case of point-to-point channels (e.g.
- CHANNELS_MAX_UNICAST_SUBSCRIBERS - Static variable in class org.springframework.integration.context.IntegrationProperties
- 
Specifies the value forAbstractDispatcher.maxSubscribersin case of point-to-point channels (e.g.
- channelToChannelName(Object) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
- channelToChannelName(Object) - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
- 
Converts the channel to a name (String).
- channelToChannelName(Object, long) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
- channelToChannelName(Object, long) - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
- 
Converts the channel to a name (String).
- channelTransacted(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- channelTransacted(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- 
ConfigurechannelTransactedon both theRabbitTemplate(for sends) andSimpleMessageListenerContainer(for receives) when using Spring Integration 4.0.
- ChannelUtils - Class in org.springframework.integration.channel
- 
Channel utilities.
- CHAR - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- CharacterStreamReadingMessageSource - Class in org.springframework.integration.stream
- 
A pollable source forReaders.
- CharacterStreamReadingMessageSource(Reader) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
- 
Construct an instance with the provider reader.
- CharacterStreamReadingMessageSource(Reader, int) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
- 
Construct an instance with the provider reader and buffer size.
- CharacterStreamReadingMessageSource(Reader, int, boolean) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
- 
Construct an instance with the provided reader and buffer size.
- CharacterStreamWritingMessageHandler - Class in org.springframework.integration.stream
- 
AMessageHandlerthat writes characters to aWriter.
- CharacterStreamWritingMessageHandler(Writer) - Constructor for class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
- CharacterStreamWritingMessageHandler(Writer, int) - Constructor for class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
- charset - Variable in class org.springframework.integration.zip.transformer.AbstractZipTransformer
- charset(String) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
- 
Set the charset to be used when reading the file, when something other than the default charset is required.
- charset(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- 
Set the charset to use when converting String payloads to bytes as the content of the remote file.
- charset(String) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- 
Set the charset to use when converting String payloads to bytes as the content of the file.
- charset(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Set the charset to use when converting String payloads to bytes as the content of the remote file.
- charset(String) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
- 
Specify the charset name to use for converting String-typed payloads to bytes.
- charset(Charset) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
- 
Set the charset to be used when reading the file, when something other than the default charset is required.
- charset(Charset) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- 
Set the charset to use when converting String payloads to bytes as the content of the remote file.
- CHAT - Static variable in class org.springframework.integration.xmpp.XmppHeaders
- ChatMessageInboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
- 
Parser for the XMPP 'inbound-channel-adapter' element.
- ChatMessageInboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.ChatMessageInboundChannelAdapterParser
- ChatMessageListeningEndpoint - Class in org.springframework.integration.xmpp.inbound
- 
This component logs in as a user and forwards any messages to that user on to downstream components.
- ChatMessageListeningEndpoint() - Constructor for class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
- ChatMessageListeningEndpoint(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
- ChatMessageOutboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
- 
Parser for the XMPP 'outbound-channel-adapter' element
- ChatMessageOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.ChatMessageOutboundChannelAdapterParser
- ChatMessageSendingMessageHandler - Class in org.springframework.integration.xmpp.outbound
- 
MessageHandler that sends an XMPP Chat Message.
- ChatMessageSendingMessageHandler() - Constructor for class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
- ChatMessageSendingMessageHandler(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
- checkActive() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- checkActive() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
- checkAllowList(Class<?>) - Method in class org.springframework.integration.support.converter.AllowListDeserializingConverter
- checkAndConfigureFixedSubscriberChannel(Element, ParserContext, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- checkClosure(int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
- checkDeliveryMode(Message<?>, MessageProperties, MessageDeliveryMode) - Static method in class org.springframework.integration.amqp.support.MappingUtils
- 
Check the delivery mode and update with the default if not already present.
- CheckedFunction<T,R> - Interface in org.springframework.integration.util 
- 
A Function-like interface which allows throwing Error.
- checkForIllegalTarget(Object, String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
- checkForIllegalTarget(Object, String) - Method in class org.springframework.integration.config.FilterFactoryBean
- checkMessageHandlerAttributes(String, List<Annotation>) - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- checkReuse(MessageProducer) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- checkTaskExecutor(String) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
- 
Creates a default task executor if none was supplied.
- chmod(int) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- 
Set the file permissions after uploading, e.g.
- chmod(int) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- 
Set the file permissions after uploading, e.g.
- chmod(int) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Set the file permissions after uploading, e.g.
- CircuitBreakerOpenException(Message<?>, String) - Constructor for exception org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice.CircuitBreakerOpenException
- claim_check_in - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- claim_check_out - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- claimCheckIn(MessageStore) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- claimCheckIn(MessageStore, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- ClaimCheckInParser - Class in org.springframework.integration.config.xml
- 
Parser for the <claim-check-in/> element.
- ClaimCheckInParser() - Constructor for class org.springframework.integration.config.xml.ClaimCheckInParser
- ClaimCheckInTransformer - Class in org.springframework.integration.transformer
- 
Transformer that stores a Message and returns a new Message whose payload is the id of the stored Message.
- ClaimCheckInTransformer(MessageStore) - Constructor for class org.springframework.integration.transformer.ClaimCheckInTransformer
- 
Create a claim check-in transformer that will delegate to the provided MessageStore.
- claimCheckOut(MessageStore) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMessageTransformingHandlerfor theClaimCheckOutTransformerwith providedMessageStore.
- claimCheckOut(MessageStore, boolean) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMessageTransformingHandlerfor theClaimCheckOutTransformerwith providedMessageStoreandremoveMessageflag.
- claimCheckOut(MessageStore, boolean, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMessageTransformingHandlerfor theClaimCheckOutTransformerwith providedMessageStoreandremoveMessageflag.
- ClaimCheckOutParser - Class in org.springframework.integration.config.xml
- 
Parser for the <claim-check-out/> element.
- ClaimCheckOutParser() - Constructor for class org.springframework.integration.config.xml.ClaimCheckOutParser
- ClaimCheckOutTransformer - Class in org.springframework.integration.transformer
- 
Transformer that accepts a Message whose payload is a UUID and retrieves the Message associated with that id from a MessageStore if available.
- ClaimCheckOutTransformer(MessageStore) - Constructor for class org.springframework.integration.transformer.ClaimCheckOutTransformer
- 
Create a claim check-out transformer that will delegate to the provided MessageStore.
- classes() - Element in annotation interface org.springframework.integration.test.condition.LogLevels
- 
Classes representing Log4j categories to change.
- classes(boolean, Class<?>...) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
- 
Specify the classes for logging level adjusting configured before.
- classes(Class<?>...) - Method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
- 
Specify the classes for logging level adjusting configured before.
- classLevels() - Method in record class org.springframework.integration.test.util.TestUtils.LevelsContainer
- 
Returns the value of theclassLevelsrecord component.
- ClassUtils - Class in org.springframework.integration.util
- ClassUtils() - Constructor for class org.springframework.integration.util.ClassUtils
- clear() - Method in class org.springframework.integration.channel.QueueChannel
- clear() - Method in interface org.springframework.integration.channel.QueueChannelOperations
- 
Remove allMessagesfrom this channel.
- clear() - Method in class org.springframework.integration.expression.ExpressionEvalMap
- clear() - Method in class org.springframework.integration.history.MessageHistory
- clear() - Method in interface org.springframework.integration.store.MessageGroup
- clear() - Method in class org.springframework.integration.store.SimpleMessageGroup
- clear() - Method in class org.springframework.integration.support.MutableMessageHeaders
- CLEAR_ALL - Enum constant in enum class org.springframework.integration.hazelcast.CacheEventType
- 
The Hazelcast CLEAR_ALL event.
- clearCache() - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
- 
Clear the resource bundle cache.
- clearMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
- clearOnFlush(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaUpdatingOutboundEndpointSpec
- 
If set totruetheEntityManager.clear()will be called, and only if theEntityManager.flush()was called after performing persistence operations.
- clearQueue() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
- 
Clear the Redis Queue specified byRedisQueueInboundGateway.boundListOperations.
- clearQueue() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
- 
Clear the Redis Queue specified byRedisQueueMessageDrivenEndpoint.boundListOperations.
- clearThreadKey() - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
- 
Clear the key for this thread.
- clearThreadKey(Message<?>) - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
- 
Messaging-friendly version ofDelegatingSessionFactory.clearThreadKey()that can be invoked from a service activator.
- CLIENT - Enum constant in enum class org.springframework.integration.hazelcast.ClusterMonitorType
- 
The client listener mode.
- CLIENT_ACKNOWLEDGE - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
- CLIENT_ACKNOWLEDGE_STRING - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
- CLIENT_MODE - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- ClientCallback<C,T> - Interface in org.springframework.integration.file.remote 
- 
RemoteFileTemplatecallback with the underlying client instance providing access to lower level methods.
- ClientCallbackWithoutResult<C> - Interface in org.springframework.integration.file.remote
- 
RemoteFileTemplatecallback with the underlying client instance providing access to lower level methods where no result is returned.
- ClientHttpResponseBodyExtractor - Class in org.springframework.integration.webflux.support
- 
TheBodyExtractoridentity function implementation which just returns the providedClientHttpResponse.
- ClientHttpResponseBodyExtractor() - Constructor for class org.springframework.integration.webflux.support.ClientHttpResponseBodyExtractor
- clientId(String) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
- clientId(String) - Method in class org.springframework.integration.jms.dsl.JmsPublishSubscribeMessageChannelSpec
- ClientManager<T,C> - Interface in org.springframework.integration.mqtt.core 
- 
A utility abstraction over MQTT client which can be used in any MQTT-related component without need to handle generic client callbacks, reconnects etc.
- ClientManager.ConnectCallback - Interface in org.springframework.integration.mqtt.core
- 
A contract for a custom callback onconnectCompleteevent from the client.
- clientMode(boolean) - Method in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
- clientMode(boolean) - Method in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
- clientMode(boolean) - Method in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
- ClientModeCapable - Interface in org.springframework.integration.ip.tcp.connection
- 
Edpoints implementing this interface are capable of running in client-mode.
- ClientModeConnectionManager - Class in org.springframework.integration.ip.tcp.connection
- 
Intended to be run on a schedule, simply gets the connection from a client connection factory each time it is run.
- ClientModeConnectionManager(AbstractConnectionFactory) - Constructor for class org.springframework.integration.ip.tcp.connection.ClientModeConnectionManager
- clientRSocketConnector(ClientRSocketConnector) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
- 
Configure aClientRSocketConnectorfor client side requests based on the connection provided by theClientRSocketConnector.getRequester().
- ClientRSocketConnector - Class in org.springframework.integration.rsocket
- 
A clientAbstractRSocketConnectorextension to the RSocket connection.
- ClientRSocketConnector(ClientTransport) - Constructor for class org.springframework.integration.rsocket.ClientRSocketConnector
- 
Instantiate a connector based on the providedClientTransport.
- ClientRSocketConnector(String, int) - Constructor for class org.springframework.integration.rsocket.ClientRSocketConnector
- 
Instantiate a connector based on theTcpClientTransport.
- ClientRSocketConnector(URI) - Constructor for class org.springframework.integration.rsocket.ClientRSocketConnector
- 
Instantiate a connector based on theWebsocketClientTransport.
- ClientStompEncoder - Class in org.springframework.integration.websocket.support
- 
AStompEncoderextension to prepare a message for sending/receiving before/after encoding/decoding when used from WebSockets client side.
- ClientStompEncoder() - Constructor for class org.springframework.integration.websocket.support.ClientStompEncoder
- ClientWebSocketContainer - Class in org.springframework.integration.websocket
- 
TheIntegrationWebSocketContainerimplementation for theclientWeb-Socket connection.
- ClientWebSocketContainer(WebSocketClient, String, Object...) - Constructor for class org.springframework.integration.websocket.ClientWebSocketContainer
- ClientWebSocketContainer(WebSocketClient, URI) - Constructor for class org.springframework.integration.websocket.ClientWebSocketContainer
- 
Constructor with a preparedURI.
- ClientWebSocketContainerParser - Class in org.springframework.integration.websocket.config
- 
TheAbstractSingleBeanDefinitionParserimplementation for the<websocket:client-container/>element.
- ClientWebSocketContainerParser() - Constructor for class org.springframework.integration.websocket.config.ClientWebSocketContainerParser
- CLOB - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- cloneAndExecute() - Method in interface org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice.ExecutionCallback
- 
Call this when it is necessary to clone the invocation before calling proceed() - such as when the invocation might be called multiple times - for example in a retry advice.
- cloneConnectOptions(MqttConnectOptions) - Static method in class org.springframework.integration.mqtt.support.MqttUtils
- 
Clone theMqttConnectOptions, except the serverUris.
- close() - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- close() - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
- close() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
- close() - Method in interface org.springframework.integration.file.remote.session.Session
- close() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
- close() - Method in class org.springframework.integration.ftp.session.FtpSession
- close() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
- 
Closes the connection.
- close() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- close() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
- 
Close this connection.
- close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
- 
Closes this connection.
- close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
- close() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
- close() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
- close() - Method in interface org.springframework.integration.jdbc.lock.LockRepository
- close() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
- close() - Method in class org.springframework.integration.sftp.session.SftpSession
- close() - Method in class org.springframework.integration.smb.session.SmbSession
- close() - Method in class org.springframework.integration.smb.session.SmbShare
- close() - Method in interface org.springframework.integration.util.CloseableIterator
- close() - Method in class org.springframework.integration.util.FunctionIterator
- close() - Method in interface org.springframework.integration.util.Pool
- 
Close the pool; returned items will be destroyed.
- close() - Method in class org.springframework.integration.util.SimplePool
- CLOSEABLE_RESOURCE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
- CloseableIterator<E> - Interface in org.springframework.integration.util
- 
ACloseableIteratoris intended to be used when it may hold resources (such as file or socket handles).
- closeConnection(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
- 
If we have been intercepted, propagate the close from the outermost interceptor; otherwise, just call close().
- closeConnection(String) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- 
Close a connection with the specified connection id.
- closeConnection(String) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
- closeFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
- closeFolder(Folder, boolean) - Static method in class org.springframework.integration.mail.MailTransportUtils
- 
Close the given JavaMail Folder and ignore any thrown exception.
- closeService(Service) - Static method in class org.springframework.integration.mail.MailTransportUtils
- 
Close the given JavaMail Service and ignore any thrown exception.
- closeSession(WebSocketSession, CloseStatus) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
- closeStreamAfterSend(boolean) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
- 
Set to true to close the connection output stream after sending without closing the connection.
- ClusterMonitorType - Enum Class in org.springframework.integration.hazelcast
- 
Enumeration of Hazelcast Cluster Monitor Types.
- Codec - Interface in org.springframework.integration.codec
- 
Interface for classes that perform both encode (serialize) and decode (deserialize) on multiple classes.
- codecConfigurer(ServerCodecConfigurer) - Method in class org.springframework.integration.webflux.dsl.WebFluxInboundEndpointSpec
- CodecMessageConverter - Class in org.springframework.integration.codec
- 
AMessageConverterthat delegates to aCodecto convert.
- CodecMessageConverter(Codec) - Constructor for class org.springframework.integration.codec.CodecMessageConverter
- collection(String) - Method in class org.springframework.integration.mongodb.dsl.MongoDbChangeStreamMessageProducerSpec
- 
Configure a collection to subscribe for change events.
- COLLECTION_NAME - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
- 
The header for MongoDb collection name.
- CollectionArgumentResolver - Class in org.springframework.integration.handler.support
- CollectionArgumentResolver(boolean) - Constructor for class org.springframework.integration.handler.support.CollectionArgumentResolver
- collectionCallback(MessageCollectionCallback<P>) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
- 
Reference to an instance ofMessageCollectionCallbackwhich specifies the database operation to execute in the request message context.
- CollectionFilter<T> - Interface in org.springframework.integration.util
- 
Base strategy for filtering out a subset of a Collection of elements.
- collectionName - Variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- collectionName(String) - Method in class org.springframework.integration.mongodb.dsl.AbstractMongoDbMessageSourceSpec
- 
Configure a collection name to query against.
- collectionName(String) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
- 
Identify the name of the MongoDb collection to use.
- collectionName(String) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
- 
Configure a collection name to store data.
- collectionNameExpression(String) - Method in class org.springframework.integration.mongodb.dsl.AbstractMongoDbMessageSourceSpec
- 
Configure a SpEL expression to evaluation a collection name on eachreceive()call.
- collectionNameExpression(String) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
- 
A SpEL expression which should resolve to aStringvalue identifying the name of the MongoDb collection to use.
- collectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.dsl.AbstractMongoDbMessageSourceSpec
- 
Configure a SpEL expression to evaluation a collection name on eachreceive()call.
- collectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
- 
Configure a SpEL expression to evaluate a collection name against a request message.
- collectionNameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
- collectionNameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mongodb.dsl.ReactiveMongoDbMessageHandlerSpec
- 
Configure aFunctionfor evaluation a collection against request message.
- collectionNameSupplier(Supplier<String>) - Method in class org.springframework.integration.mongodb.dsl.AbstractMongoDbMessageSourceSpec
- 
Configure aSupplierto obtain a collection name on eachreceive()call.
- COMMAND - Static variable in class org.springframework.integration.redis.support.RedisHeaders
- commitCallback(OffsetCommitCallback) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
- 
Set the commit callback; by default a simple logging callback is used to log success at DEBUG level and failures at ERROR level.
- commonOutboundProperties(Element, ParserContext, BeanDefinitionBuilder) - Static method in class org.springframework.integration.kafka.config.xml.KafkaParsingUtils
- CommonSocketOptions - Interface in org.springframework.integration.ip
- comparator(Comparator<Message<?>>) - Method in class org.springframework.integration.dsl.PriorityChannelSpec
- compare(Message<?>, Message<?>) - Method in class org.springframework.integration.aggregator.MessageSequenceComparator
- compareTo(FileInfo<F>) - Method in class org.springframework.integration.file.remote.AbstractFileInfo
- compareTo(KafkaMessageSource.KafkaAckInfo<K, V>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
- compareValues(BiPredicate<String, String>) - Method in class org.springframework.integration.selector.MetadataStoreSelector
- 
Fluent version ofMetadataStoreSelector.setCompareValues(BiPredicate).
- compilerMode() - Element in annotation interface org.springframework.integration.annotation.UseSpelInvoker
- 
Specify that the annotated method (or methods in the annotated class) will be invoked using SpEL instead of anInvocableHandlerMethodwith the specified compilerMode.
- complete() - Method in interface org.springframework.integration.store.MessageGroup
- 
Complete the group.
- complete() - Method in class org.springframework.integration.store.MessageGroupMetadata
- complete() - Method in class org.springframework.integration.store.SimpleMessageGroup
- COMPLETE - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
- completeGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
- completeGroup(Object) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
- completeGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- completeGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
- completeGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- completeGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
- 
Completes this MessageGroup.
- completeGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
- completeGroup(Object, MessageGroup, Lock) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- completeGroup(Message<?>, Object, MessageGroup, Lock) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- COMPONENT_NAME - Enum constant in enum class org.springframework.integration.support.management.observation.IntegrationObservation.GatewayTags
- 
Name of the message gateway component.
- COMPONENT_NAME - Enum constant in enum class org.springframework.integration.support.management.observation.IntegrationObservation.HandlerTags
- 
Name of the message handler component.
- COMPONENT_NAME - Enum constant in enum class org.springframework.integration.support.management.observation.IntegrationObservation.ProducerTags
- 
Name of the message handler component.
- COMPONENT_TYPE - Enum constant in enum class org.springframework.integration.support.management.observation.IntegrationObservation.GatewayTags
- 
Type of the component - 'gateway'.
- COMPONENT_TYPE - Enum constant in enum class org.springframework.integration.support.management.observation.IntegrationObservation.HandlerTags
- 
Type of the component - 'handler'.
- COMPONENT_TYPE - Enum constant in enum class org.springframework.integration.support.management.observation.IntegrationObservation.ProducerTags
- 
Type of the component - 'producer'.
- ComponentsEvaluationCallback(EvaluationContext, Object, boolean, Class<?>) - Constructor for class org.springframework.integration.expression.ExpressionEvalMap.ComponentsEvaluationCallback
- ComponentsRegistration - Interface in org.springframework.integration.dsl
- 
The marker interface for theIntegrationComponentSpecimplementation, when there is need to register as beans not only the target spec's components, but some additional components, e.g.
- componentsToRegister - Variable in class org.springframework.integration.dsl.EndpointSpec
- componentsToRegister - Variable in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
- CompositeCodec - Class in org.springframework.integration.codec
- 
A Codec that can delegate to one out of many Codecs, each mapped to a class.
- CompositeCodec(Map<Class<?>, Codec>, Codec) - Constructor for class org.springframework.integration.codec.CompositeCodec
- CompositeCodec(Codec) - Constructor for class org.springframework.integration.codec.CompositeCodec
- CompositeExecutor - Class in org.springframework.integration.util
- 
AnExecutorthat encapsulates two underlying executors.
- CompositeExecutor(Executor, Executor) - Constructor for class org.springframework.integration.util.CompositeExecutor
- CompositeFileListFilter<F> - Class in org.springframework.integration.file.filters
- 
SimpleFileListFilterthat predicates its matches against all of the configuredFileListFilter.
- CompositeFileListFilter() - Constructor for class org.springframework.integration.file.filters.CompositeFileListFilter
- CompositeFileListFilter(Collection<? extends FileListFilter<F>>) - Constructor for class org.springframework.integration.file.filters.CompositeFileListFilter
- CompositeKryoRegistrar - Class in org.springframework.integration.codec.kryo
- 
AKryoRegistrarthat delegates and validates registrations across all components.
- CompositeKryoRegistrar(List<KryoRegistrar>) - Constructor for class org.springframework.integration.codec.kryo.CompositeKryoRegistrar
- CompositeMessageHandler - Interface in org.springframework.integration.handler
- 
Classes implementing this interface delegate to a list of handlers.
- CompositeMessageHandlerNode - Class in org.springframework.integration.graph
- 
Represents a composite message handler.
- CompositeMessageHandlerNode(int, String, MessageHandler, String, String, List<CompositeMessageHandlerNode.InnerHandler>) - Constructor for class org.springframework.integration.graph.CompositeMessageHandlerNode
- CompositeMessageHandlerNode.InnerHandler - Class in org.springframework.integration.graph
- CompoundTrigger - Class in org.springframework.integration.util
- 
ATriggerthat delegates theTrigger.nextExecutionTime(TriggerContext)to one of two Triggers.
- CompoundTrigger(Trigger) - Constructor for class org.springframework.integration.util.CompoundTrigger
- 
Construct a compound trigger with the supplied primary trigger.
- CompoundTriggerAdvice - Class in org.springframework.integration.aop
- 
AMessageSourceMutatorthat uses aCompoundTriggerto adjust the poller - when a message is present, the compound trigger's primary trigger is used to determine the next poll.
- CompoundTriggerAdvice(CompoundTrigger, Trigger) - Constructor for class org.springframework.integration.aop.CompoundTriggerAdvice
- concurrency(int) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
- 
Specify a concurrency maximum number for theAbstractMessageListenerContainer.
- concurrency(String) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
- 
The concurrency to use.
- concurrentConsumers(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- concurrentConsumers(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- concurrentConsumers(int) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
- 
The concurrent consumers number to use.
- concurrentConsumers(int) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
- 
Only applies if theJmsMessageChannelSpec.containerType(Class)is aDefaultMessageListenerContaineror aSimpleMessageListenerContainer.
- concurrentConsumers(Integer) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec.ReplyContainerSpec
- ConcurrentMetadataStore - Interface in org.springframework.integration.metadata
- 
Supports atomic updates to values in the store.
- ConfigurableCompositeMessageConverter - Class in org.springframework.integration.support.converter
- 
ACompositeMessageConverterextension with some defaultMessageConverters which can be overridden with the given converters or added in the end of targetconverterscollection.
- ConfigurableCompositeMessageConverter() - Constructor for class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
- 
Create an instance with the default converters.
- ConfigurableCompositeMessageConverter(Collection<MessageConverter>) - Constructor for class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
- 
Create an instance with the given converters and without defaults.
- ConfigurableCompositeMessageConverter(Collection<MessageConverter>, boolean) - Constructor for class org.springframework.integration.support.converter.ConfigurableCompositeMessageConverter
- 
Create an instance with the given converters and with defaults in the end.
- ConfigurableMongoDbMessageStore - Class in org.springframework.integration.mongodb.store
- 
An alternate MongoDBMessageStoreandMessageGroupStorewhich allows the user to configure the instance ofMongoTemplate.
- ConfigurableMongoDbMessageStore(MongoTemplate) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- ConfigurableMongoDbMessageStore(MongoTemplate, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- ConfigurableMongoDbMessageStore(MongoDatabaseFactory) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- ConfigurableMongoDbMessageStore(MongoDatabaseFactory, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- ConfigurableMongoDbMessageStore(MongoDatabaseFactory, MappingMongoConverter) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- ConfigurableMongoDbMessageStore(MongoDatabaseFactory, MappingMongoConverter, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- configure(DatagramSocket) - Method in interface org.springframework.integration.ip.udp.SocketCustomizer
- 
Configure the socket ({code setTrafficClass()}, etc).
- configure(Consumer<StreamListenerContainer>) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageListenerContainerSpec
- 
Perform additional configuration of the container.
- configure(IntegrationFlowDefinition<?>) - Method in interface org.springframework.integration.dsl.IntegrationFlow
- 
The callback-based function to declare the chain of EIP-methods to configure an integration flow with the providedIntegrationFlowDefinition.
- configure(IntegrationFlowDefinition<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- configure(IntegrationFlowDefinition<?>) - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
- configureAdviceChain(Element, Element, boolean, BeanDefinition, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- configureAdviceChain(Element, Element, BeanDefinition, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- configureAndSetAdviceChainIfPresent(Element, Element, boolean, BeanDefinition, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- configureAndSetAdviceChainIfPresent(Element, Element, boolean, BeanDefinition, ParserContext, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- configureAndSetAdviceChainIfPresent(Element, Element, BeanDefinition, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- configureAndSetAdviceChainIfPresent(Element, Element, BeanDefinition, ParserContext, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- configureChannels(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
- configureChannels(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.amqp.config.AmqpInboundGatewayParser
- configureContainer(Consumer<DirectMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterDMLCSpec
- configureContainer(Consumer<DirectMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundGatewayDMLCSpec
- configureContainer(Consumer<RabbitStreamMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamInboundChannelAdapterSpec
- configureContainer(Consumer<SimpleMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSMLCSpec
- configureContainer(Consumer<SimpleMessageListenerContainerSpec>) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySMLCSpec
- configureFilter(BeanDefinitionBuilder, Element, ParserContext, String, String, String) - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
- configureHandler(ServiceActivatingHandler) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
- configureHeaderMapper(Element, BeanDefinitionBuilder, ParserContext, Class<?>, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- 
Utility method to configure a HeaderMapper for Inbound and Outbound channel adapters/gateway.
- configureHeaderMapper(Element, BeanDefinitionBuilder, ParserContext, BeanDefinitionBuilder, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- 
Utility method to configure a HeaderMapper for Inbound and Outbound channel adapters/gateway.
- configureJmsTemplate(Consumer<JmsTemplateSpec>) - Method in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec.JmsInboundChannelSpecTemplateAware
- 
Configure the channel adapter to use the template specification created by invoking theConsumercallback, passing in aJmsTemplateSpec.
- configureJmsTemplate(Consumer<JmsTemplateSpec>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec.JmsOutboundChannelSpecTemplateAware
- configureKafkaTemplate(Consumer<KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec<K, V, R>>) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.KafkaGatewayMessageHandlerTemplateSpec
- 
Configure a Kafka Template by invoking theConsumercallback, with aKafkaTemplateSpecargument.
- configureKafkaTemplate(Consumer<KafkaTemplateSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
- 
Configure a Kafka Template by invoking theConsumercallback, with aKafkaTemplateSpecargument.
- configureKryoInstance(Kryo) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
- 
Subclasses implement this to configure the kryo instance.
- configureKryoInstance(Kryo) - Method in class org.springframework.integration.codec.kryo.PojoCodec
- configureListenerContainer(Consumer<KafkaMessageListenerContainerSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
- 
Configure a listener container by invoking theConsumercallback, with aKafkaMessageListenerContainerSpecargument.
- configureListenerContainer(Consumer<KafkaMessageListenerContainerSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
- 
Configure a listener container by invoking theConsumercallback, with aKafkaMessageListenerContainerSpecargument.
- configureListenerContainer(Consumer<S>) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec.JmsInboundGatewayListenerContainerSpec
- 
Specify aConsumerto accept aJmsListenerContainerSpecfor further configuration.
- configureListenerContainer(Consumer<S>) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
- 
Configure a listener container by invoking theConsumercallback, with aJmsListenerContainerSpecargument.
- configureMappingRouter(AbstractMappingMessageRouter) - Method in class org.springframework.integration.config.RouterFactoryBean
- configurePollerMetadata(Element, BeanDefinitionBuilder, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- 
Parse a "poller" element to provide a reference for the target BeanDefinitionBuilder.
- configurePollingEndpoint(AbstractPollingEndpoint, Poller) - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- configureRouter(AbstractMessageRouter) - Method in class org.springframework.integration.config.RouterFactoryBean
- configureSocket(SocketCustomizer) - Method in class org.springframework.integration.ip.dsl.AbstractUdpOutboundChannelAdapterSpec
- 
Configure the socket.
- configureSocket(SocketCustomizer) - Method in class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
- 
Configure the socket.
- configureSource(MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
- configureSplitter(AbstractMessageSplitter) - Method in class org.springframework.integration.config.SplitterFactoryBean
- configureTemplate(Consumer<KafkaTemplateSpec<K, R>>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
- 
Configure a template by invoking theConsumercallback, with aKafkaTemplateSpecargument.
- configureTransactionAttributes(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- 
Parse a "transactional" element and configure aTransactionInterceptorwith "transactionManager" and other "transactionDefinition" properties.
- configureTransactionAttributes(Element, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- 
Parse a "transactional" element and configure aTransactionInterceptororTransactionHandleMessageAdvicewith "transactionManager" and other "transactionDefinition" properties.
- configureTransactionDefinition(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- 
Parse attributes of "transactional" element and configure aDefaultTransactionAttributewith provided "transactionDefinition" properties.
- confirm(CorrelationData, boolean, String) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- confirmAckChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- 
Set the channel to which acks are send (publisher confirms).
- confirmCorrelationExpression(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- 
Set a SpEL expression to evaluate confirm correlation at runtime.
- confirmCorrelationExpression(Expression) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- 
Set a SpEL expression to evaluate confirm correlation at runtime.
- confirmCorrelationFunction(Function<Message<?>, Object>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- 
Set aFunctionto evaluate confirm correlation at runtime.
- confirmNackChannel(MessageChannel) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- 
Set the channel to which nacks are send (publisher confirms).
- confirmTimeout(long) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
- 
Set a timeout after which a nack will be synthesized if no publisher confirm has been received within that time.
- confirmTimeout(long) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageHandlerSpec
- 
Set a timeout for the confirm result.
- connect() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
- 
Perform subscription into the RSocket server for incoming requests.
- connect(StompSessionHandler) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
- connect(StompSessionHandler) - Method in interface org.springframework.integration.stomp.StompSessionManager
- CONNECT_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- connectComplete(boolean) - Method in interface org.springframework.integration.mqtt.core.ClientManager.ConnectCallback
- 
Called when the connection to the server is completed successfully.
- connectComplete(boolean) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
- connectComplete(boolean) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- connectComplete(boolean, String) - Method in class org.springframework.integration.mqtt.core.Mqttv3ClientManager
- connectComplete(boolean, String) - Method in class org.springframework.integration.mqtt.core.Mqttv5ClientManager
- connectComplete(boolean, String) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
- connectComplete(boolean, String) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- connectComplete(boolean, String) - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- CONNECTION_ID - Static variable in class org.springframework.integration.ip.IpHeaders
- 
A unique identifier for a TCP connection; set by the framework for inbound messages; when sending to a server-side inbound channel adapter, or replying to an inbound gateway, this header is required so the endpoint can determine which connection to send the message to.
- connectionFactory - Variable in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
- connectionFactory - Variable in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
- connectionFactory - Variable in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
- connectionFactory - Variable in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
- connectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
- ConnectionFactory - Interface in org.springframework.integration.ip.tcp.connection
- 
A factory used to create TcpConnection objects.
- connectionLost(Throwable) - Method in class org.springframework.integration.mqtt.core.Mqttv3ClientManager
- connectionLost(Throwable) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
- connectionLost(Throwable) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
- connectionSupport(TcpNetConnectionSupport) - Method in class org.springframework.integration.ip.dsl.TcpNetClientConnectionFactorySpec
- 
TheTcpNetConnectionSupportto use to create connection objects.
- connectionSupport(TcpNetConnectionSupport) - Method in class org.springframework.integration.ip.dsl.TcpNetServerConnectionFactorySpec
- 
TheTcpNetConnectionSupportto use to create connection objects.
- connectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.dsl.TcpNioClientConnectionFactorySpec
- 
TheTcpNioConnectionSupportto use.
- connectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.dsl.TcpNioServerConnectionFactorySpec
- 
TheTcpNioConnectionSupportto use.
- connectTimeout(int) - Method in class org.springframework.integration.ip.dsl.TcpClientConnectionFactorySpec
- 
Set the connection timeout in seconds.
- connectUrl(String) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
- 
Configure a connection to the ZeroMQ proxy with the pair of ports over colon for proxy frontend and backend sockets.
- connectUrl(String) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
- 
Configure an URL forZMQ.Socket.connect(String).
- consecutiveActiveTrigger(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- consecutiveIdleTrigger(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- ConsoleInboundChannelAdapterParser - Class in org.springframework.integration.stream.config
- 
Parser for the <stdin-channel-adapter> element.
- ConsoleInboundChannelAdapterParser() - Constructor for class org.springframework.integration.stream.config.ConsoleInboundChannelAdapterParser
- ConsoleOutboundChannelAdapterParser - Class in org.springframework.integration.stream.config
- 
Parser for the "stdout-" and "stderr-channel-adapter" elements.
- ConsoleOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.stream.config.ConsoleOutboundChannelAdapterParser
- CONSOLIDATED_HEADERS - Static variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- 
Header containingList<Map<String, Object>headers when batch mode isAmqpInboundChannelAdapter.BatchMode.EXTRACT_PAYLOADS_WITH_HEADERS.
- constructType(Type) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
- constructType(Type) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
- consumeDelay(Duration) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqChannelSpec
- 
Specify aDurationto delay consumption when no data received.
- consumeDelay(Duration) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
- 
Specify aDurationto delay consumption when no data received.
- CONSUMER - Static variable in class org.springframework.integration.redis.support.RedisHeaders
- CONSUMER_GROUP - Static variable in class org.springframework.integration.redis.support.RedisHeaders
- consumerArguments(Map<String, Object>) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- 
Set consumer arguments.
- consumerBatchEnabled(boolean) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
- 
Set to true to enable batching of consumed messages.
- consumerCustomizer(ConsumerCustomizer) - Method in class org.springframework.integration.amqp.dsl.RabbitStreamMessageListenerContainerSpec
- 
Set a consumer customizer.
- ConsumerEndpointFactoryBean - Class in org.springframework.integration.config
- 
TheFactoryBeanimplementation forAbstractEndpointpopulation.
- ConsumerEndpointFactoryBean() - Constructor for class org.springframework.integration.config.ConsumerEndpointFactoryBean
- ConsumerEndpointSpec<S extends ConsumerEndpointSpec<S,H>, H extends MessageHandler> - Class in org.springframework.integration.dsl 
- 
AEndpointSpecfor consumer endpoints.
- ConsumerEndpointSpec(H) - Constructor for class org.springframework.integration.dsl.ConsumerEndpointSpec
- consumerProperties() - Method in record class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
- 
Returns the value of theconsumerPropertiesrecord component.
- consumerRebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
- 
Set the user definedConsumerRebalanceListenerimplementation.
- consumersPerQueue(int) - Method in class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
- consumerTagStrategy(ConsumerTagStrategy) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- 
Set the implementation ofConsumerTagStrategyto generate consumer tags.
- consumes(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.RequestMappingSpec
- 
The consumable media types of the mapped request, narrowing the primary mapping.
- container(ConnectionFactory, Destination) - Static method in class org.springframework.integration.jms.dsl.Jms
- 
The factory to produce aJmsListenerContainerSpec.
- container(ConnectionFactory, String) - Static method in class org.springframework.integration.jms.dsl.Jms
- 
The factory to produce aJmsListenerContainerSpec.
- containerType(Class<? extends AbstractMessageListenerContainer>) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
- 
Configure the type of the container.
- contains(Object) - Method in class org.springframework.integration.history.MessageHistory
- containsAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
- containsElementIgnoreCase(String[], String) - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
- containsKey(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
- containsSequence(Integer) - Method in class org.springframework.integration.store.SimpleMessageGroup
- 
Return true if a message with this sequence number header exists in the group.
- containsValue(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
- content_enricher - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- CONTENT_MD5 - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
- CONTENT_TYPE - Static variable in class org.springframework.integration.mail.MailHeaders
- CONTENT_TYPE_ID - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
- CONTENT_TYPE_PROPERTY - Static variable in class org.springframework.integration.jms.JmsHeaderMapper
- ContentBasedHeaderMatcher(boolean, Collection<String>) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.ContentBasedHeaderMatcher
- ContentEnricher - Class in org.springframework.integration.transformer
- 
Content Enricher is a Message Transformer that can augment a message's payload with either static values or by optionally invoking a downstream message flow via its request channel and then applying values from the reply Message to the original payload.
- ContentEnricher() - Constructor for class org.springframework.integration.transformer.ContentEnricher
- contentType(String) - Method in class org.springframework.integration.debezium.dsl.DebeziumMessageProducerSpec
- 
Set the outbound message content type.
- contentType(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set the content type.
- contentTypeExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set an expression that will be evaluated to determine the content type.
- contentTypeFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set a function that will be invoked to determine the content type.
- context - Variable in class org.springframework.integration.hazelcast.leader.LeaderInitiator.LeaderSelector
- Context - Interface in org.springframework.integration.leader
- 
Interface that defines the context for candidate leadership.
- CONTEXT_ACKNOWLEDGMENT - Static variable in interface org.springframework.integration.kafka.inbound.KafkaInboundEndpoint
- 
RetryContextattribute key for an acknowledgment if the listener is capable of acknowledging.
- CONTEXT_CONSUMER - Static variable in interface org.springframework.integration.kafka.inbound.KafkaInboundEndpoint
- 
RetryContextattribute key for the consumer if the listener is consumer-aware.
- CONTEXT_RECORD - Static variable in interface org.springframework.integration.kafka.inbound.KafkaInboundEndpoint
- 
RetryContextattribute key for the record.
- contextClearHook - Variable in class org.springframework.integration.handler.advice.ContextHolderRequestHandlerAdvice
- ContextHolderRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
- 
AnAbstractRequestHandlerAdviceimplementation to store and reset a value into/from some context (e.g.
- ContextHolderRequestHandlerAdvice(Function<Message<?>, Object>, Consumer<Object>, Runnable) - Constructor for class org.springframework.integration.handler.advice.ContextHolderRequestHandlerAdvice
- 
Construct an instance based on the provided hooks.
- contextSetHook - Variable in class org.springframework.integration.handler.advice.ContextHolderRequestHandlerAdvice
- ContinuationHandlerMethodArgumentResolver - Class in org.springframework.integration.handler.support
- 
No-op resolver for method arguments of typeContinuation.
- ContinuationHandlerMethodArgumentResolver() - Constructor for class org.springframework.integration.handler.support.ContinuationHandlerMethodArgumentResolver
- control_bus - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- controlBus() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theControl BusEI Pattern specificMessageHandlerimplementation at the currentIntegrationFlowchain position.
- controlBus(Consumer<GenericEndpointSpec<ServiceActivatingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theControl BusEI Pattern specificMessageHandlerimplementation at the currentIntegrationFlowchain position.
- ControlBusMethodFilter - Class in org.springframework.integration.expression
- 
SpELMethodFilterto restrict method invocations to:PausableorLifecyclecomponentsget,setandshutdownmethods ofCustomizableThreadCreatormethods withManagedAttributeandManagedOperationannotations This class isn't designed for target applications and typically is used fromExpressionControlBusFactoryBean.
- ControlBusMethodFilter() - Constructor for class org.springframework.integration.expression.ControlBusMethodFilter
- ControlBusParser - Class in org.springframework.integration.config.xml
- ControlBusParser() - Constructor for class org.springframework.integration.config.xml.ControlBusParser
- convert(byte[]) - Method in class org.springframework.integration.support.converter.AllowListDeserializingConverter
- convert(JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
- convert(Class<P>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMessageTransformingHandlerinstance for the providedpayloadTypeto convert at runtime.
- convert(Class<P>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate theMessageTransformingHandlerinstance for the providedpayloadTypeto convert at runtime.
- convert(Object) - Method in class org.springframework.integration.util.UUIDConverter
- 
Convert the input to a UUID using the convenience methodUUIDConverter.getUUID(Object).
- convert(Object, TypeDescriptor, TypeDescriptor) - Method in class org.springframework.integration.json.JsonNodeWrapperToJsonNodeConverter
- convert(MBeanServerConnection, ObjectInstance) - Method in class org.springframework.integration.jmx.DefaultMBeanObjectConverter
- convert(MBeanServerConnection, ObjectInstance) - Method in interface org.springframework.integration.jmx.MBeanObjectConverter
- convert(Binary) - Method in class org.springframework.integration.mongodb.support.BinaryToMessageConverter
- convert(Message<?>) - Method in class org.springframework.integration.mongodb.support.MessageToBinaryConverter
- convertAndSend(Message<?>) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
- convertAndSend(Message<?>) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- convertAndSend(Message<?>) - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
- converter - Variable in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- converter(Converter<T, U>) - Static method in class org.springframework.integration.dsl.Transformers
- CONVERTER_REGISTRAR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- ConverterParser - Class in org.springframework.integration.config.xml
- ConverterParser() - Constructor for class org.springframework.integration.config.xml.ConverterParser
- convertExceptions(boolean) - Method in class org.springframework.integration.http.dsl.HttpRequestHandlerEndpointSpec
- 
Flag to determine if conversion and writing out of message handling exceptions should be attempted.
- convertExpressions(Collection<ProcedureParameter>) - Static method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
- 
Utility method that converts a Collection ofProcedureParameterto a Map containing only expression parameters.
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.integration.support.converter.ObjectStringMessageConverter
- ConvertingBytesMessageMapper - Class in org.springframework.integration.mapping
- 
TheBytesMessageMapperimplementation to delegate to/fromMessageconversion into the providedMessageConverter.
- ConvertingBytesMessageMapper(MessageConverter) - Constructor for class org.springframework.integration.mapping.ConvertingBytesMessageMapper
- ConvertingMessagingTemplate() - Constructor for class org.springframework.integration.gateway.MessagingGatewaySupport.ConvertingMessagingTemplate
- convertPayload(Message) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- convertRequestMappingToAnnotation(RequestMapping) - Static method in class org.springframework.integration.http.config.HttpContextUtils
- 
Converts a providedRequestMappingto the Spring WebRequestMappingannotation.
- convertStaticParameters(Collection<ProcedureParameter>) - Static method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
- 
Utility method that converts a Collection ofProcedureParameterto a Map containing only static parameters.
- convertToDocument(Object) - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
- convertToDocument(Object) - Method in interface org.springframework.integration.xml.XmlPayloadConverter
- convertToJdbcTypesEnum(String) - Static method in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- 
Retrieve the matching enum constant for a provided String representation of the SQL Types.
- convertToNode(Object) - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
- convertToNode(Object) - Method in interface org.springframework.integration.xml.XmlPayloadConverter
- convertToSource(Object) - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
- convertToSource(Object) - Method in interface org.springframework.integration.xml.XmlPayloadConverter
- convertToString(Object) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
- convertValue(Object, TypeDescriptor, TypeDescriptor) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
- copy(InputStream) - Method in class org.springframework.integration.zip.transformer.SpringZipUtils
- copy(InputStream, File) - Static method in class org.springframework.integration.zip.transformer.SpringZipUtils
- copy(MessageGroup) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
- 
Used by expireMessageGroups.
- copy(MessageGroup) - Method in class org.springframework.integration.store.SimpleMessageStore
- copyFileToLocalDirectory(String, EvaluationContext, F, File, Session<F>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
- copyHeaders(Map<String, ?>) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
- 
Copy the name-value pairs from the provided Map.
- copyHeaders(Map<String, ?>) - Method in class org.springframework.integration.support.MessageBuilder
- 
Copy the name-value pairs from the provided Map.
- copyHeaders(Map<String, ?>) - Method in class org.springframework.integration.support.MutableMessageBuilder
- copyHeadersIfAbsent(Map<String, ?>) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
- 
Copy the name-value pairs from the provided Map.
- copyHeadersIfAbsent(Map<String, ?>) - Method in class org.springframework.integration.support.MessageBuilder
- 
Copy the name-value pairs from the provided Map.
- copyHeadersIfAbsent(Map<String, ?>) - Method in class org.springframework.integration.support.MutableMessageBuilder
- copyToSizedArray(byte[], int) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
- 
Copy size bytes to a new buffer exactly size bytes long.
- CoroutinesUtils - Class in org.springframework.integration.util
- 
Additional utilities for working with Kotlin Coroutines.
- CorrelatingMessageBarrier - Class in org.springframework.integration.aggregator
- 
This Endpoint serves as a barrier for messages that should not be processed yet.
- CorrelatingMessageBarrier() - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageBarrier
- CorrelatingMessageBarrier(MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageBarrier
- CORRELATION_DATA - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
- CORRELATION_ID - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
- correlationExpression(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- 
Configure the handler with anExpressionEvaluatingCorrelationStrategyfor the given expression.
- CorrelationHandlerSpec<S extends CorrelationHandlerSpec<S,H>, H extends AbstractCorrelatingMessageHandler> - Class in org.springframework.integration.dsl 
- CorrelationHandlerSpec(H) - Constructor for class org.springframework.integration.dsl.CorrelationHandlerSpec
- correlationId(Object) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aIntegrationMessageHeaderAccessor.CORRELATION_IDheader.
- correlationId(Object, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aIntegrationMessageHeaderAccessor.CORRELATION_IDheader.
- correlationIdExpression(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aIntegrationMessageHeaderAccessor.CORRELATION_IDheader where the value is a SpELExpressionevaluation result.
- correlationIdExpression(String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aIntegrationMessageHeaderAccessor.CORRELATION_IDheader where the value is a SpELExpressionevaluation result.
- correlationIdFunction(Function<Message<P>, ?>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aIntegrationMessageHeaderAccessor.CORRELATION_IDheader where the value is obtained by invoking theFunctioncallback.
- correlationIdFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- 
Add aIntegrationMessageHeaderAccessor.CORRELATION_IDheader where the value is obtained by invoking theFunctioncallback.
- correlationKey(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- correlationKey(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- correlationStrategy(Object, String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- 
Configure the handler with anMethodInvokingCorrelationStrategyfor the target object and method name.
- correlationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.dsl.BarrierSpec
- correlationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- CorrelationStrategy - Interface in org.springframework.integration.aggregator
- 
Strategy for determining how messages can be correlated.
- CorrelationStrategy - Annotation Interface in org.springframework.integration.annotation
- 
Indicates that a given method is capable of determining the correlation key of a message sent as parameter.
- CorrelationStrategyFactoryBean - Class in org.springframework.integration.config
- 
Convenience factory for XML configuration of aCorrelationStrategy.
- CorrelationStrategyFactoryBean() - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
- counterBuilder(String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor
- 
Create a counter builder for a counter with the provided name.
- counterBuilder(String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
- CounterFacade - Interface in org.springframework.integration.support.management.metrics
- create() - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- create() - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec
- create() - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
- create() - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
- create() - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
- create(Object) - Method in interface org.springframework.integration.store.MessageGroupFactory
- 
Create aMessageGroupinstance based on the providedgroupId.
- create(Object) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
- create(Object) - Method in class org.springframework.integration.transaction.DefaultTransactionSynchronizationFactory
- create(Object) - Method in class org.springframework.integration.transaction.PassThroughTransactionSynchronizationFactory
- create(Object) - Method in interface org.springframework.integration.transaction.TransactionSynchronizationFactory
- create(Collection<? extends Message<?>>, Object) - Method in interface org.springframework.integration.store.MessageGroupFactory
- create(Collection<? extends Message<?>>, Object) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
- create(Collection<? extends Message<?>>, Object, long, boolean) - Method in interface org.springframework.integration.store.MessageGroupFactory
- create(Collection<? extends Message<?>>, Object, long, boolean) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
- create(MessageGroupStore, Object) - Method in interface org.springframework.integration.store.MessageGroupFactory
- 
Create aMessageGroupinstance based on the providedgroupId.
- create(MessageGroupStore, Object) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
- create(MessageGroupStore, Object, long, boolean) - Method in interface org.springframework.integration.store.MessageGroupFactory
- 
Create aMessageGroupinstance based on the providedgroupId.
- create(MessageGroupStore, Object, long, boolean) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
- create(Message<?>, String, Integer, Long, K, V, Headers) - Method in interface org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler.ProducerRecordCreator
- 
Create a record.
- CREATE - Enum constant in enum class org.springframework.integration.file.FileReadingMessageSource.WatchEventType
- createCallback(AmqpMessageSource.AmqpAckInfo) - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallbackFactory
- createCallback(KafkaMessageSource.KafkaAckInfo<K, V>) - Method in record class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
- createCallback(T) - Method in interface org.springframework.integration.acks.AcknowledgmentCallbackFactory
- 
Create the callback.
- createClientInstance() - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
- createClientInstance() - Method in class org.springframework.integration.ftp.session.DefaultFtpSessionFactory
- createClientInstance() - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
- createConnection() - Method in class org.springframework.integration.jms.JmsOutboundGateway
- 
Create a new JMS Connection for this JMS gateway.
- createConsumer() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
- created(ServerSession, Path, Map<String, ?>, Throwable) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
- createDefaultHandler() - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
- createDefaultHandler() - Method in class org.springframework.integration.config.SplitterFactoryBean
- createDefaultHeaderMatcher(String, Collection<String>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
- 
Create the initialAbstractHeaderMapper.HeaderMatcherbased on the specified headers and standard header prefix.
- createDirectChannel(Element, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- createDirectHandlerIfPossible(Object, String) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
- 
If the target object is aMessageHandlerand the method is 'handleMessage', return anAbstractMessageProducingHandlerthat wraps it.
- createDispatcher() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- createDispatcher() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
- createDispatcher() - Method in class org.springframework.integration.kafka.channel.PublishSubscribeKafkaChannel
- createDispatcher() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
- createElementDescription(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- 
Provides a user friendly description of an element based on its node name and, if available, its "id" attribute value.
- createEndpoint(MessageHandler, Method, List<Annotation>) - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- createEndpoint(MessageHandler, Method, List<Annotation>) - Method in class org.springframework.integration.config.BridgeToAnnotationPostProcessor
- createEndpointBeanDefinition(ComponentDefinition, ComponentDefinition, List<Annotation>) - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- createEndpointBeanDefinition(ComponentDefinition, ComponentDefinition, List<Annotation>) - Method in class org.springframework.integration.config.BridgeToAnnotationPostProcessor
- createEndpointBeanDefinition(ComponentDefinition, ComponentDefinition, List<Annotation>) - Method in class org.springframework.integration.config.InboundChannelAdapterAnnotationPostProcessor
- createEvaluationContext() - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
- createEvaluationContext() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
- createEvaluationContext() - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
- createExpressionDefIfAttributeDefined(String, Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- createExpressionDefinitionFromValueOrExpression(String, String, ParserContext, Element, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
- createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.FilterFactoryBean
- createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.RouterFactoryBean
- createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
- createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.SplitterFactoryBean
- createExpressionEvaluatingHandler(Expression) - Method in class org.springframework.integration.config.TransformerFactoryBean
- createFilter(MessageSelector) - Method in class org.springframework.integration.config.FilterFactoryBean
- createForPool() - Method in interface org.springframework.integration.util.SimplePool.PoolItemCallback
- 
Called by the pool when a new instance is required to populate the pool.
- createHandler() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
- createHandler() - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
- createHandler() - Method in class org.springframework.integration.config.AggregatorFactoryBean
- createHandler() - Method in class org.springframework.integration.config.ExpressionControlBusFactoryBean
- createHandler() - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
- createHandler() - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
- createHandler() - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- 
Subclasses must implement this method to create the MessageHandler.
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.AggregatorAnnotationPostProcessor
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.BridgeFromAnnotationPostProcessor
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.BridgeToAnnotationPostProcessor
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.FilterAnnotationPostProcessor
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.InboundChannelAdapterAnnotationPostProcessor
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.RouterAnnotationPostProcessor
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.ServiceActivatorAnnotationPostProcessor
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.SplitterAnnotationPostProcessor
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.TransformerAnnotationPostProcessor
- createHandler(Transformer) - Method in class org.springframework.integration.config.TransformerFactoryBean
- createHandlerInternal() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
- createHeaderMatcher(Collection<String>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
- 
Create aAbstractHeaderMapper.HeaderMatcherthat match if any of the specifiedpatternsmatch.
- createInstance() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- createInstance() - Method in class org.springframework.integration.config.ExpressionFactoryBean
- createInstance() - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
- createInstance() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
- createInstance() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
- createInstance() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
- createInstance() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
- createInstance() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
- createInstance() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
- createInvocableHandlerMethod(Object, Method) - Method in class org.springframework.integration.handler.support.IntegrationMessageHandlerMethodFactory
- createJavaType(Map<String, Object>, String) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
- createJsonParser(String) - Method in class org.springframework.integration.support.json.Jackson2JsonMessageParser
- createMessageFromAmqp(Message, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- createMessageFromPayload(Object, Channel, Map<String, Object>, long, List<Map<String, Object>>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- createMessageProcessingHandler(MessageProcessor<T>) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
- createMessageProcessingHandler(MessageProcessor<T>) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
- createMessageProcessor(String, ScriptSource, ScriptVariableGenerator) - Method in class org.springframework.integration.groovy.config.GroovyAwareScriptExecutingProcessorFactory
- createMessageProcessor(String, ScriptSource, ScriptVariableGenerator) - Method in class org.springframework.integration.scripting.config.ScriptExecutingProcessorFactory
- createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
- 
Subclasses must implement this method to create the MessageHandler.
- createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.FilterFactoryBean
- createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.RouterFactoryBean
- createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
- createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.SplitterFactoryBean
- createMethodInvokingHandler(Object, String) - Method in class org.springframework.integration.config.TransformerFactoryBean
- createMethodInvokingRouter(Object, String) - Method in class org.springframework.integration.config.RouterFactoryBean
- createMethodInvokingSplitter(Object, String) - Method in class org.springframework.integration.config.SplitterFactoryBean
- createNewConnection(Socket, boolean, boolean, ApplicationEventPublisher, String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNetConnectionSupport
- createNewConnection(Socket, boolean, boolean, ApplicationEventPublisher, String) - Method in interface org.springframework.integration.ip.tcp.connection.TcpNetConnectionSupport
- 
Create a newTcpNetConnectionobject wrapping theSocket.
- createNewConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNioConnectionSupport
- createNewConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNioSSLConnectionSupport
- 
Creates aTcpNioSSLConnection.
- createNewConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String) - Method in interface org.springframework.integration.ip.tcp.connection.TcpNioConnectionSupport
- 
Create a newTcpNioConnectionobject wrapping theSocketChannel.
- createOutputMessage(Object, MessageHeaders) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
- createOutputStream(File, boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
- 
Create a buffered output stream for the file.
- createParameterSource(Object) - Method in class org.springframework.integration.jdbc.BeanPropertySqlParameterSourceFactory
- createParameterSource(Object) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
- createParameterSource(Object) - Method in interface org.springframework.integration.jdbc.SqlParameterSourceFactory
- 
Return a newSqlParameterSource.
- createParameterSource(Object) - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSourceFactory
- createParameterSource(Object) - Method in class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
- createParameterSource(Object) - Method in interface org.springframework.integration.jpa.support.parametersource.ParameterSourceFactory
- 
Return a newParameterSource.
- createParameterSourceNoCache(Object) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
- 
Create an expression evaluatingSqlParameterSourcethat does not cache it's results.
- createResult(Object) - Method in class org.springframework.integration.xml.result.DomResultFactory
- createResult(Object) - Method in interface org.springframework.integration.xml.result.ResultFactory
- createResult(Object) - Method in class org.springframework.integration.xml.result.StringResultFactory
- createSelect(String) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource.SelectCreator
- createSelect(SqlIdentifier) - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource.SelectCreator
- createServerSocket(int, int, InetAddress) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
- 
Create a newServerSocket.
- createSession() - Method in class org.springframework.integration.smb.session.SmbSessionFactory
- createSession(Connection) - Method in class org.springframework.integration.jms.JmsOutboundGateway
- 
Create a new JMS Session using the provided Connection.
- createSimpleEvaluationContext() - Static method in class org.springframework.integration.expression.ExpressionUtils
- 
Used to create a context with no BeanFactory, usually in tests.
- createSimpleEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.expression.ExpressionUtils
- 
Obtains the context from the beanFactory if not null; emits a warning if the beanFactory is null.
- createSmbDirectoryObject(String) - Method in class org.springframework.integration.smb.session.SmbSession
- 
Create an SMB file object pointing to a remote directory.
- createSmbFileObject(String) - Method in class org.springframework.integration.smb.session.SmbSession
- 
Create an SMB file object pointing to a remote file.
- createSocket(String, int) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
- 
Create a newSocket.
- createSource(Object) - Method in class org.springframework.integration.xml.source.DomSourceFactory
- createSource(Object) - Method in interface org.springframework.integration.xml.source.SourceFactory
- 
Create appropriateSourceinstance forpayload
- createSource(Object) - Method in class org.springframework.integration.xml.source.StringSourceFactory
- createStandardEvaluationContext() - Static method in class org.springframework.integration.expression.ExpressionUtils
- 
Used to create a context with no BeanFactory, usually in tests.
- createStandardEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.expression.ExpressionUtils
- 
Obtains the context from the beanFactory if not null; emits a warning if the beanFactory is null.
- createTargetPropertyName(String, boolean) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
- 
Alter the specifiedpropertyNameif necessary.
- createTaskScheduler(int) - Static method in class org.springframework.integration.test.util.TestUtils
- 
A factory for theThreadPoolTaskSchedulerinstances based on the providedpoolSize.
- createTestApplicationContext() - Static method in class org.springframework.integration.test.util.TestUtils
- 
Create aTestUtils.TestApplicationContextinstance supplied with the basic Spring Integration infrastructure.
- createWriter(File, boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
- 
Create a buffered writer for the file, for String payloads.
- credentials(String, String) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
- 
Set the credentials.
- criteria(String) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
- 
Set a SpEL expression to evaluate aCriteriafor query to execute.
- criteria(Function<Message<P>, Criteria>) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
- 
Set aFunctionto evaluate aCriteriafor query to execute.
- criteria(Expression) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageHandlerSpec
- 
Set a SpEL expression to evaluate aCriteriafor query to execute.
- CRITICAL - Enum constant in enum class org.springframework.integration.syslog.RFC5424SyslogParser.Severity
- crlf() - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
- 
Return a serializer with the default max message size for deserialization.
- crlf(int) - Static method in class org.springframework.integration.ip.tcp.serializer.TcpCodecs
- 
Return a serializer with the provided max message size for deserialization.
- cron() - Element in annotation interface org.springframework.integration.annotation.Poller
- cron(String) - Method in class org.springframework.integration.dsl.PollerFactory
- 
Create aPollerSpecbased on the provided cron expression.
- cron(String) - Static method in class org.springframework.integration.dsl.Pollers
- 
Create aPollerSpecbased on the provided cron expression.
- cron(String, TimeZone) - Method in class org.springframework.integration.dsl.PollerFactory
- 
Create aPollerSpecbased on the provided cron expression andTimeZone.
- cron(String, TimeZone) - Static method in class org.springframework.integration.dsl.Pollers
- 
Create aPollerSpecbased on the provided cron expression andTimeZone.
- crossOrigin(Consumer<HttpInboundEndpointSupportSpec.CrossOriginSpec>) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
- CrossOrigin - Class in org.springframework.integration.http.inbound
- 
The mapping to permit cross origin requests (CORS) forHttpRequestHandlingEndpointSupport.
- CrossOrigin() - Constructor for class org.springframework.integration.http.inbound.CrossOrigin
- CuratorFrameworkFactoryBean - Class in org.springframework.integration.zookeeper.config
- 
A Spring-friendly way to build aCuratorFrameworkand implementingSmartLifecycle.
- CuratorFrameworkFactoryBean(String) - Constructor for class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
- 
Construct an instance using the supplied connection string and using a default retry policynew ExponentialBackoffRetry(1000, 3).
- CuratorFrameworkFactoryBean(String, RetryPolicy) - Constructor for class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
- 
Construct an instance using the supplied connection string and retry policy.
- currencyTimeLimit() - Element in annotation interface org.springframework.integration.support.management.IntegrationManagedResource
- current() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
- currentComponent(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- currentInterceptableChannel() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Return the current channel if it is anInterceptableChannel, otherwise register a new implicitDirectChannelin the flow and return that one.
- currentMessageChannel(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- customizeMonoReply(BiFunction<Message<?>, Mono<T>, Publisher<V>>) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form