- AbstractAggregatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
-
Base class for MessageGroupProcessor implementations that aggregate the group of Messages into a single Message.
- AbstractAggregatingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
-
- AbstractAmqpChannel - Class in org.springframework.integration.amqp.channel
-
- AbstractAmqpOutboundEndpoint - Class in org.springframework.integration.amqp.outbound
-
- AbstractAmqpOutboundEndpoint() - Constructor for class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- AbstractAmqpOutboundEndpoint.CorrelationDataWrapper - Class in org.springframework.integration.amqp.outbound
-
- AbstractBatchingMessageGroupStore - Class in org.springframework.integration.store
-
- AbstractBatchingMessageGroupStore() - Constructor for class org.springframework.integration.store.AbstractBatchingMessageGroupStore
-
- AbstractByteArraySerializer - Class in org.springframework.integration.ip.tcp.serializer
-
Base class for (de)serializers that provide a mechanism to
reconstruct a byte array from an arbitrary stream.
- AbstractByteArraySerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
-
- AbstractCandidate - Class in org.springframework.integration.leader
-
- AbstractCandidate() - Constructor for class org.springframework.integration.leader.AbstractCandidate
-
Instantiate a abstract candidate.
- AbstractCandidate(String, String) - Constructor for class org.springframework.integration.leader.AbstractCandidate
-
Instantiate a abstract candidate.
- AbstractChannelAdapterParser - Class in org.springframework.integration.config.xml
-
Base parser for Channel Adapters.
- AbstractChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.AbstractChannelAdapterParser
-
- AbstractChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
-
- AbstractChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
-
- AbstractChannelParser - Class in org.springframework.integration.config.xml
-
Base class for channel parsers.
- AbstractChannelParser() - Constructor for class org.springframework.integration.config.xml.AbstractChannelParser
-
- AbstractClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
-
Abstract class for client connection factories; client connection factories
establish outgoing connections.
- AbstractClientConnectionFactory(String, int) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
Constructs a factory that will established connections to the host and port.
- AbstractConfigurableMongoDbMessageStore - Class in org.springframework.integration.mongodb.store
-
The abstract MongoDB
BasicMessageGroupStore
implementation to provide configuration for common options
for implementations of this class.
- AbstractConfigurableMongoDbMessageStore(MongoTemplate, String) - Constructor for class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- AbstractConfigurableMongoDbMessageStore(MongoDbFactory, String) - Constructor for class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- AbstractConfigurableMongoDbMessageStore(MongoDbFactory, MappingMongoConverter, String) - Constructor for class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- AbstractConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
-
Base class for all connection factories.
- AbstractConnectionFactory(int) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- AbstractConnectionFactory(String, int) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- AbstractConsumerEndpointParser - Class in org.springframework.integration.config.xml
-
Base class parser for elements that create Message Endpoints.
- AbstractConsumerEndpointParser() - Constructor for class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
-
- AbstractCorrelatingMessageHandler - Class in org.springframework.integration.aggregator
-
Abstract Message handler that holds a buffer of correlated messages in a
MessageStore
.
- AbstractCorrelatingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- AbstractCorrelatingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- AbstractCorrelatingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- AbstractCorrelatingMessageHandler.SequenceAwareMessageGroup - Class in org.springframework.integration.aggregator
-
- AbstractCorrelatingMessageHandlerParser - Class in org.springframework.integration.config.xml
-
- AbstractCorrelatingMessageHandlerParser() - Constructor for class org.springframework.integration.config.xml.AbstractCorrelatingMessageHandlerParser
-
- AbstractDispatcher - Class in org.springframework.integration.dispatcher
-
- AbstractDispatcher() - Constructor for class org.springframework.integration.dispatcher.AbstractDispatcher
-
- AbstractEndpoint - Class in org.springframework.integration.endpoint
-
The base class for Message Endpoint implementations.
- AbstractEndpoint() - Constructor for class org.springframework.integration.endpoint.AbstractEndpoint
-
- AbstractEvaluationContextFactoryBean - Class in org.springframework.integration.config
-
Abstract class for integration evaluation context factory beans.
- AbstractEvaluationContextFactoryBean() - Constructor for class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
-
- AbstractExecutorChannel - Class in org.springframework.integration.channel
-
- AbstractExecutorChannel(Executor) - Constructor for class org.springframework.integration.channel.AbstractExecutorChannel
-
- AbstractExecutorChannel.MessageHandlingTask - Class in org.springframework.integration.channel
-
- AbstractExpressionEvaluator - Class in org.springframework.integration.util
-
- AbstractExpressionEvaluator() - Constructor for class org.springframework.integration.util.AbstractExpressionEvaluator
-
- AbstractFileInfo<F> - Class in org.springframework.integration.file.remote
-
Abstract implementation of
FileInfo
; provides a setter
for the remote directory and a generic toString implementation.
- AbstractFileInfo() - Constructor for class org.springframework.integration.file.remote.AbstractFileInfo
-
- AbstractFileListFilter<F> - Class in org.springframework.integration.file.filters
-
A convenience base class for any
FileListFilter
whose criteria can be
evaluated against each File in isolation.
- AbstractFileListFilter() - Constructor for class org.springframework.integration.file.filters.AbstractFileListFilter
-
- AbstractFileLockerFilter - Class in org.springframework.integration.file.locking
-
Convenience base class for implementing FileLockers that check a lock before accepting a file.
- AbstractFileLockerFilter() - Constructor for class org.springframework.integration.file.locking.AbstractFileLockerFilter
-
- AbstractFilePayloadTransformer<T> - Class in org.springframework.integration.file.transformer
-
Base class for transformers that convert a File payload.
- AbstractFilePayloadTransformer() - Constructor for class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
-
- AbstractFilePayloadTransformerParser - Class in org.springframework.integration.file.config
-
Base class for File payload transformer parsers.
- AbstractFilePayloadTransformerParser() - Constructor for class org.springframework.integration.file.config.AbstractFilePayloadTransformerParser
-
- AbstractFtpSessionFactory<T extends org.apache.commons.net.ftp.FTPClient> - Class in org.springframework.integration.ftp.session
-
Base class for FTP SessionFactory implementations.
- AbstractFtpSessionFactory() - Constructor for class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- AbstractHandleMessageAdvice - Class in org.springframework.integration.handler.advice
-
- AbstractHandleMessageAdvice() - Constructor for class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
-
- AbstractHeaderMapper<T> - Class in org.springframework.integration.mapping
-
- AbstractHeaderMapper(String, Collection<String>, Collection<String>) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper
-
Create a new instance.
- AbstractHeaderMapper.CompositeHeaderMatcher - Class in org.springframework.integration.mapping
-
- AbstractHeaderMapper.ContentBasedHeaderMatcher - Class in org.springframework.integration.mapping
-
- AbstractHeaderMapper.HeaderMatcher - Interface in org.springframework.integration.mapping
-
Strategy interface to determine if a given header name matches.
- AbstractHeaderMapper.PatternBasedHeaderMatcher - Class in org.springframework.integration.mapping
-
- AbstractHeaderMapper.PrefixBasedMatcher - Class in org.springframework.integration.mapping
-
- AbstractHeaderMapper.SinglePatternBasedHeaderMatcher - Class in org.springframework.integration.mapping
-
- AbstractHeaderValueMessageProcessor<T> - Class in org.springframework.integration.transformer.support
-
- AbstractHeaderValueMessageProcessor() - Constructor for class org.springframework.integration.transformer.support.AbstractHeaderValueMessageProcessor
-
- AbstractInboundFileSynchronizer<F> - Class in org.springframework.integration.file.remote.synchronizer
-
Base class charged with knowing how to connect to a remote file system,
scan it for new files and then download the files.
- AbstractInboundFileSynchronizer(SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- AbstractInboundFileSynchronizingMessageSource<F> - Class in org.springframework.integration.file.remote.synchronizer
-
Factors out the common logic between the FTP and SFTP adapters.
- AbstractInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<F>) - Constructor for class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- AbstractInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<F>, Comparator<File>) - Constructor for class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- AbstractInboundGatewayParser - Class in org.springframework.integration.config.xml
-
Base class for inbound gateway parsers.
- AbstractInboundGatewayParser() - Constructor for class org.springframework.integration.config.xml.AbstractInboundGatewayParser
-
- AbstractIntegrationMessageBuilder<T> - Class in org.springframework.integration.support
-
- AbstractIntegrationMessageBuilder() - Constructor for class org.springframework.integration.support.AbstractIntegrationMessageBuilder
-
- AbstractIntegrationNamespaceHandler - Class in org.springframework.integration.config.xml
-
Base class for NamespaceHandlers that registers a BeanFactoryPostProcessor
for configuring default bean definitions.
- AbstractIntegrationNamespaceHandler() - Constructor for class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
-
- AbstractInternetProtocolReceivingChannelAdapter - Class in org.springframework.integration.ip
-
Base class for inbound TCP/UDP Channel Adapters.
- AbstractInternetProtocolReceivingChannelAdapter(int) - Constructor for class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- AbstractInternetProtocolSendingMessageHandler - Class in org.springframework.integration.ip
-
Base class for all TCP/UDP MessageHandlers.
- AbstractInternetProtocolSendingMessageHandler(String, int) - Constructor for class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- AbstractJacksonJsonObjectMapper<N,P,J> - Class in org.springframework.integration.support.json
-
- AbstractJacksonJsonObjectMapper() - Constructor for class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
-
- AbstractJmsChannel - Class in org.springframework.integration.jms
-
- AbstractJmsChannel(JmsTemplate) - Constructor for class org.springframework.integration.jms.AbstractJmsChannel
-
- AbstractJpaOutboundGatewayParser - Class in org.springframework.integration.jpa.config.xml
-
The Abstract Parser for the JPA Outbound Gateways.
- AbstractJpaOutboundGatewayParser() - Constructor for class org.springframework.integration.jpa.config.xml.AbstractJpaOutboundGatewayParser
-
- AbstractJsonInboundMessageMapper<P> - Class in org.springframework.integration.support.json
-
- AbstractJsonInboundMessageMapper(Type) - Constructor for class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
-
- AbstractKeyValueMessageStore - Class in org.springframework.integration.store
-
- AbstractKeyValueMessageStore() - Constructor for class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- AbstractKeyValueMessageStore(String) - Constructor for class org.springframework.integration.store.AbstractKeyValueMessageStore
-
Construct an instance based on the provided prefix for keys to distinguish between
different store instances in the same target key-value data base.
- AbstractKryoCodec - Class in org.springframework.integration.codec.kryo
-
Base class for
Codec
s using
Kryo
.
- AbstractKryoCodec() - Constructor for class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
- AbstractKryoRegistrar - Class in org.springframework.integration.codec.kryo
-
- AbstractKryoRegistrar() - Constructor for class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
-
- AbstractLeaderEvent - Class in org.springframework.integration.leader.event
-
- AbstractLeaderEvent(Object) - Constructor for class org.springframework.integration.leader.event.AbstractLeaderEvent
-
Create a new ApplicationEvent.
- AbstractLeaderEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.AbstractLeaderEvent
-
Create a new ApplicationEvent.
- AbstractMailMessageTransformer<T> - Class in org.springframework.integration.mail.transformer
-
Base class for Transformers that convert from a JavaMail Message to a
Spring Integration Message.
- AbstractMailMessageTransformer() - Constructor for class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
-
- AbstractMailReceiver - Class in org.springframework.integration.mail
-
- AbstractMailReceiver() - Constructor for class org.springframework.integration.mail.AbstractMailReceiver
-
- AbstractMailReceiver(URLName) - Constructor for class org.springframework.integration.mail.AbstractMailReceiver
-
- AbstractMailReceiver(String) - Constructor for class org.springframework.integration.mail.AbstractMailReceiver
-
- AbstractMappingMessageRouter - Class in org.springframework.integration.router
-
Base class for all Message Routers that support mapping from arbitrary String values
to Message Channel names.
- AbstractMappingMessageRouter() - Constructor for class org.springframework.integration.router.AbstractMappingMessageRouter
-
- AbstractMessageChannel - Class in org.springframework.integration.channel
-
Base class for
MessageChannel
implementations providing common
properties such as the channel name.
- AbstractMessageChannel() - Constructor for class org.springframework.integration.channel.AbstractMessageChannel
-
- AbstractMessageChannel.ChannelInterceptorList - Class in org.springframework.integration.channel
-
A convenience wrapper class for the list of ChannelInterceptors.
- AbstractMessageChannelMetrics - Class in org.springframework.integration.support.management
-
Abstract base class for channel metrics implementations.
- AbstractMessageChannelMetrics(String) - Constructor for class org.springframework.integration.support.management.AbstractMessageChannelMetrics
-
- AbstractMessageGroupStore - Class in org.springframework.integration.store
-
- AbstractMessageGroupStore() - Constructor for class org.springframework.integration.store.AbstractMessageGroupStore
-
- AbstractMessageGroupStore(boolean) - Constructor for class org.springframework.integration.store.AbstractMessageGroupStore
-
- AbstractMessageHandler - Class in org.springframework.integration.handler
-
Base class for MessageHandler implementations that provides basic validation
and error handling capabilities.
- AbstractMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractMessageHandler
-
- AbstractMessageHandlerMetrics - Class in org.springframework.integration.support.management
-
Abstract base class for handler metrics implementations.
- AbstractMessageHandlerMetrics(String) - Constructor for class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
-
- AbstractMessageProcessingSelector - Class in org.springframework.integration.filter
-
- AbstractMessageProcessingSelector(MessageProcessor<Boolean>) - Constructor for class org.springframework.integration.filter.AbstractMessageProcessingSelector
-
- AbstractMessageProcessingTransformer - Class in org.springframework.integration.transformer
-
- AbstractMessageProcessingTransformer(MessageProcessor<?>) - Constructor for class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
-
- AbstractMessageProcessor<T> - Class in org.springframework.integration.handler
-
- AbstractMessageProcessor() - Constructor for class org.springframework.integration.handler.AbstractMessageProcessor
-
- AbstractMessageProducingHandler - Class in org.springframework.integration.handler
-
- AbstractMessageProducingHandler() - Constructor for class org.springframework.integration.handler.AbstractMessageProducingHandler
-
- AbstractMessageRouter - Class in org.springframework.integration.router
-
Base class for all Message Routers.
- AbstractMessageRouter() - Constructor for class org.springframework.integration.router.AbstractMessageRouter
-
- AbstractMessageSource<T> - Class in org.springframework.integration.endpoint
-
- AbstractMessageSource() - Constructor for class org.springframework.integration.endpoint.AbstractMessageSource
-
- AbstractMessageSourceAdvice - Class in org.springframework.integration.aop
-
Advice for a
MessageSource.receive()
method to decide whether a poll
should be ignored and/or take action after the receive.
- AbstractMessageSourceAdvice() - Constructor for class org.springframework.integration.aop.AbstractMessageSourceAdvice
-
- AbstractMessageSplitter - Class in org.springframework.integration.splitter
-
Base class for Message-splitting handlers.
- AbstractMessageSplitter() - Constructor for class org.springframework.integration.splitter.AbstractMessageSplitter
-
- AbstractMethodAnnotationPostProcessor<T extends Annotation> - Class in org.springframework.integration.config.annotation
-
Base class for Method-level annotation post-processors.
- AbstractMethodAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- AbstractMqttMessageDrivenChannelAdapter - Class in org.springframework.integration.mqtt.inbound
-
Abstract class for MQTT Message-Driven Channel Adapters.
- AbstractMqttMessageDrivenChannelAdapter(String, String, String...) - Constructor for class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
-
- AbstractMqttMessageHandler - Class in org.springframework.integration.mqtt.outbound
-
Abstract class for MQTT outbound channel adapters.
- AbstractMqttMessageHandler(String, String) - Constructor for class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
- AbstractOutboundChannelAdapterParser - Class in org.springframework.integration.config.xml
-
Base class for outbound Channel Adapter parsers.
- AbstractOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
-
- AbstractOutboundGatewayParser - Class in org.springframework.integration.config.xml
-
Base class for url-based outbound gateway parsers.
- AbstractOutboundGatewayParser() - Constructor for class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
-
- AbstractPayloadTransformer<T,U> - Class in org.springframework.integration.transformer
-
- AbstractPayloadTransformer() - Constructor for class org.springframework.integration.transformer.AbstractPayloadTransformer
-
- AbstractPersistentAcceptOnceFileListFilter<F> - Class in org.springframework.integration.file.filters
-
Stores "seen" files in a MetadataStore to survive application restarts.
- AbstractPersistentAcceptOnceFileListFilter(ConcurrentMetadataStore, String) - Constructor for class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
-
- AbstractPollableChannel - Class in org.springframework.integration.channel
-
Base class for all pollable channels.
- AbstractPollableChannel() - Constructor for class org.springframework.integration.channel.AbstractPollableChannel
-
- AbstractPollingEndpoint - Class in org.springframework.integration.endpoint
-
- AbstractPollingEndpoint() - Constructor for class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- AbstractPollingInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
-
Base parser for inbound Channel Adapters that poll a source.
- AbstractPollingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.AbstractPollingInboundChannelAdapterParser
-
- AbstractPooledBufferByteArraySerializer - Class in org.springframework.integration.ip.tcp.serializer
-
Base class for deserializers that cannot determine the buffer size needed.
- AbstractPooledBufferByteArraySerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
-
- AbstractRegexPatternFileListFilter<F> - Class in org.springframework.integration.file.filters
-
Filters a listing of files by qualifying their 'name'
against a regular expression (an instance of
Pattern
)
- AbstractRegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
-
- AbstractRegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
-
- AbstractRemoteFileInboundChannelAdapterParser - Class in org.springframework.integration.file.config
-
Abstract base class for parsing remote file inbound channel adapters.
- AbstractRemoteFileInboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
-
- AbstractRemoteFileOutboundGateway<F> - Class in org.springframework.integration.file.remote.gateway
-
Base class for Outbound Gateways that perform remote file operations.
- AbstractRemoteFileOutboundGateway(SessionFactory<F>, MessageSessionCallback<F, ?>) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Construct an instance using the provided session factory and callback for
performing operations on the session.
- AbstractRemoteFileOutboundGateway(RemoteFileTemplate<F>, MessageSessionCallback<F, ?>) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Construct an instance with the supplied remote file template and callback
for performing operations on the session.
- AbstractRemoteFileOutboundGateway(SessionFactory<F>, String, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Construct an instance with the supplied session factory, a command ('ls', 'get'
etc), and an expression to determine the filename.
- AbstractRemoteFileOutboundGateway(SessionFactory<F>, AbstractRemoteFileOutboundGateway.Command, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Construct an instance with the supplied session factory, a command ('ls', 'get'
etc), and an expression to determine the filename.
- AbstractRemoteFileOutboundGateway(RemoteFileTemplate<F>, String, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Construct an instance with the supplied remote file template, a command ('ls',
'get' etc), and an expression to determine the filename.
- AbstractRemoteFileOutboundGateway(RemoteFileTemplate<F>, AbstractRemoteFileOutboundGateway.Command, String) - Constructor for class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Construct an instance with the supplied remote file template, a command ('ls',
'get' etc), and an expression to determine the filename.
- AbstractRemoteFileOutboundGateway.Command - Enum in org.springframework.integration.file.remote.gateway
-
Enumeration of commands supported by the gateways.
- AbstractRemoteFileOutboundGateway.Option - Enum in org.springframework.integration.file.remote.gateway
-
Enumeration of options supported by various commands.
- AbstractRemoteFileOutboundGatewayParser - Class in org.springframework.integration.file.config
-
- AbstractRemoteFileOutboundGatewayParser() - Constructor for class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
-
- AbstractRemoteFileStreamingInboundChannelAdapterParser - Class in org.springframework.integration.file.config
-
Abstract base class for parsing remote file streaming inbound channel adapters.
- AbstractRemoteFileStreamingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
-
- AbstractRemoteFileStreamingMessageSource<F> - Class in org.springframework.integration.file.remote
-
A message source that produces a message with an
InputStream
payload
referencing a remote file.
- AbstractRemoteFileStreamingMessageSource(RemoteFileTemplate<F>, Comparator<AbstractFileInfo<F>>) - Constructor for class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
- AbstractReplyProducingMessageHandler - Class in org.springframework.integration.handler
-
Base class for MessageHandlers that are capable of producing replies.
- AbstractReplyProducingMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
- AbstractReplyProducingMessageHandler.RequestHandler - Interface in org.springframework.integration.handler
-
- AbstractReplyProducingPostProcessingMessageHandler - Class in org.springframework.integration.handler
-
- AbstractReplyProducingPostProcessingMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
-
- AbstractRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
-
- AbstractRequestHandlerAdvice() - Constructor for class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
-
- AbstractRequestHandlerAdvice.ExecutionCallback - Interface in org.springframework.integration.handler.advice
-
Called by subclasses in doInvoke() to proceed() the invocation.
- AbstractRequestResponseScenarioTests - Class in org.springframework.integration.test.support
-
Convenience class for testing Spring Integration request-response message scenarios.
- AbstractRequestResponseScenarioTests() - Constructor for class org.springframework.integration.test.support.AbstractRequestResponseScenarioTests
-
- AbstractResponseValidator<T> - Class in org.springframework.integration.test.support
-
- AbstractResponseValidator() - Constructor for class org.springframework.integration.test.support.AbstractResponseValidator
-
- AbstractRouterParser - Class in org.springframework.integration.config.xml
-
Base parser for routers.
- AbstractRouterParser() - Constructor for class org.springframework.integration.config.xml.AbstractRouterParser
-
- AbstractScriptExecutingMessageProcessor<T> - Class in org.springframework.integration.scripting
-
- AbstractScriptExecutingMessageProcessor() - Constructor for class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
-
- AbstractScriptExecutingMessageProcessor(ScriptVariableGenerator) - Constructor for class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
-
- AbstractScriptExecutor - Class in org.springframework.integration.scripting.jsr223
-
- AbstractScriptExecutor(String) - Constructor for class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
-
- AbstractScriptParser - Class in org.springframework.integration.scripting.config
-
- AbstractScriptParser() - Constructor for class org.springframework.integration.scripting.config.AbstractScriptParser
-
- AbstractServerConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
-
Base class for all server connection factories.
- AbstractServerConnectionFactory(int) - Constructor for class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
The port on which the factory will listen.
- AbstractSimpleMessageHandlerFactoryBean<H extends MessageHandler> - Class in org.springframework.integration.config
-
- AbstractSimpleMessageHandlerFactoryBean() - Constructor for class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- AbstractSimplePatternFileListFilter<F> - Class in org.springframework.integration.file.filters
-
Base class for filters that support ant style path expressions, which are less powerful
but more readable than regular expressions.
- AbstractSimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.AbstractSimplePatternFileListFilter
-
- AbstractStandardMessageHandlerFactoryBean - Class in org.springframework.integration.config
-
Base class for FactoryBeans that create standard MessageHandler instances.
- AbstractStandardMessageHandlerFactoryBean() - Constructor for class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
- AbstractStompSessionManager - Class in org.springframework.integration.stomp
-
- AbstractStompSessionManager(StompClientSupport) - Constructor for class org.springframework.integration.stomp.AbstractStompSessionManager
-
- AbstractSubscribableChannel - Class in org.springframework.integration.channel
-
- AbstractSubscribableChannel() - Constructor for class org.springframework.integration.channel.AbstractSubscribableChannel
-
- AbstractTransformer - Class in org.springframework.integration.transformer
-
- AbstractTransformer() - Constructor for class org.springframework.integration.transformer.AbstractTransformer
-
- AbstractTransformerParser - Class in org.springframework.integration.config.xml
-
- AbstractTransformerParser() - Constructor for class org.springframework.integration.config.xml.AbstractTransformerParser
-
- AbstractWebServiceInboundGateway - Class in org.springframework.integration.ws
-
- AbstractWebServiceInboundGateway() - Constructor for class org.springframework.integration.ws.AbstractWebServiceInboundGateway
-
- AbstractWebServiceOutboundGateway - Class in org.springframework.integration.ws
-
Base class for outbound Web Service-invoking Messaging Gateways.
- AbstractWebServiceOutboundGateway(String, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- AbstractWebServiceOutboundGateway(DestinationProvider, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- AbstractWebServiceOutboundGateway.RequestMessageCallback - Class in org.springframework.integration.ws
-
- AbstractWebServiceOutboundGateway.ResponseMessageExtractor - Class in org.springframework.integration.ws
-
- AbstractXmlTransformer - Class in org.springframework.integration.xml.transformer
-
super class for XmlTransformer
- AbstractXmlTransformer() - Constructor for class org.springframework.integration.xml.transformer.AbstractXmlTransformer
-
- AbstractXmppConnectionAwareEndpoint - Class in org.springframework.integration.xmpp.core
-
- AbstractXmppConnectionAwareEndpoint() - Constructor for class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
-
- AbstractXmppConnectionAwareEndpoint(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
-
- AbstractXmppConnectionAwareMessageHandler - Class in org.springframework.integration.xmpp.core
-
- AbstractXmppConnectionAwareMessageHandler() - Constructor for class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
-
- AbstractXmppConnectionAwareMessageHandler(XMPPConnection) - Constructor for class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
-
- AbstractXmppInboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
-
Base class for XMPP inbound parsers
- AbstractXmppInboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
-
- AbstractXmppOutboundChannelAdapterParser - Class in org.springframework.integration.xmpp.config
-
Base class of XMPP outbound parsers
- AbstractXmppOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.xmpp.config.AbstractXmppOutboundChannelAdapterParser
-
- AbstractXPathMessageSelector - Class in org.springframework.integration.xml.selector
-
- AbstractXPathMessageSelector(String) - Constructor for class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
-
- AbstractXPathMessageSelector(String, String, String) - Constructor for class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
-
- AbstractXPathMessageSelector(String, Map<String, String>) - Constructor for class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
-
- AbstractXPathMessageSelector(XPathExpression) - Constructor for class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
-
- accept(S) - Method in interface org.springframework.integration.core.GenericSelector
-
- accept(Message<?>) - Method in interface org.springframework.integration.core.MessageSelector
-
- accept(F) - Method in class org.springframework.integration.file.filters.AbstractFileListFilter
-
Subclasses must implement this method.
- accept(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
-
- accept(F) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
-
- accept(F) - Method in class org.springframework.integration.file.filters.AbstractSimplePatternFileListFilter
-
Accepts the given file if its name matches the pattern.
- accept(F) - Method in class org.springframework.integration.file.filters.AcceptAllFileListFilter
-
- accept(F) - Method in class org.springframework.integration.file.filters.AcceptOnceFileListFilter
-
- accept(File) - Method in class org.springframework.integration.file.filters.IgnoreHiddenFileListFilter
-
- accept(File) - Method in class org.springframework.integration.file.locking.AbstractFileLockerFilter
-
- accept(Message<?>) - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
-
- ACCEPT - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- accept(ObjectName, String) - Method in class org.springframework.integration.jmx.DefaultMBeanAttributeFilter
-
- accept(ObjectName, String) - Method in interface org.springframework.integration.jmx.MBeanAttributeFilter
-
- accept(ObjectName, String) - Method in class org.springframework.integration.jmx.NamedFieldsMBeanAttributeFilter
-
- accept(ObjectName, String) - Method in class org.springframework.integration.jmx.NotNamedFieldsMBeanAttributeFilter
-
- accept(Message<?>) - Method in class org.springframework.integration.router.RecipientListRouter.Recipient
-
- accept(Message<?>) - Method in class org.springframework.integration.selector.MessageSelectorChain
-
Pass the message through the selector chain.
- accept(Message<?>) - Method in class org.springframework.integration.selector.MetadataStoreSelector
-
- accept(Message<?>) - Method in class org.springframework.integration.selector.PayloadTypeSelector
-
- accept(Message<?>) - Method in class org.springframework.integration.selector.UnexpiredMessageSelector
-
- accept(Message<?>) - Method in class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
-
- accept(Message<?>) - Method in class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
-
Evaluate the payload and return true if the value returned by the
XPathExpression
matches the
regex
.
- accept(Message<?>) - Method in class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
-
Evaluate the payload and return true if the value returned by the
XPathExpression
is equal to the
valueToTestFor
.
- accept(Message<?>) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
-
- ACCEPT_CHARSET - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- ACCEPT_ENCODING - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- ACCEPT_LANGUAGE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- ACCEPT_RANGES - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- AcceptAllFileListFilter<F> - Class in org.springframework.integration.file.filters
-
- AcceptAllFileListFilter() - Constructor for class org.springframework.integration.file.filters.AcceptAllFileListFilter
-
- AcceptOnceCollectionFilter<T> - Class in org.springframework.integration.util
-
An implementation of
CollectionFilter
that remembers the elements passed in
the previous invocation in order to avoid returning those elements more than once.
- AcceptOnceCollectionFilter() - Constructor for class org.springframework.integration.util.AcceptOnceCollectionFilter
-
- AcceptOnceFileListFilter<F> - Class in org.springframework.integration.file.filters
-
- AcceptOnceFileListFilter(int) - Constructor for class org.springframework.integration.file.filters.AcceptOnceFileListFilter
-
Creates an AcceptOnceFileListFilter that is based on a bounded queue.
- AcceptOnceFileListFilter() - Constructor for class org.springframework.integration.file.filters.AcceptOnceFileListFilter
-
Creates an AcceptOnceFileListFilter based on an unbounded queue.
- ACK - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
-
- ACK_ADDRESS - Static variable in class org.springframework.integration.ip.IpHeaders
-
The remote ip address to which UDP application-level acks will be sent.
- ACK_ID - Static variable in class org.springframework.integration.ip.IpHeaders
-
A correlation id for UDP application-level acks.
- acquire(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
- acquire(String) - Method in interface org.springframework.integration.jdbc.lock.LockRepository
-
- activeCount - Variable in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
-
- ACTUAL_CONNECTION_ID - Static variable in class org.springframework.integration.ip.IpHeaders
-
For information only - when using a cached or failover client connection
factory, contains the actual underlying connection id.
- add(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
-
- add(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
-
- add(String, PropertyAccessor) - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
-
Add the provided named property accessor.
- add(PropertyAccessor...) - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
-
Add the provided property accessors.
- add(Properties) - Method in class org.springframework.integration.history.MessageHistory
-
- add(int, Properties) - Method in class org.springframework.integration.history.MessageHistory
-
- add(MessageSelector) - Method in class org.springframework.integration.selector.MessageSelectorChain
-
Add a selector to the end of the chain.
- add(int, MessageSelector) - Method in class org.springframework.integration.selector.MessageSelectorChain
-
Add a selector to the chain at the specified index.
- add(Message<?>) - Method in interface org.springframework.integration.store.MessageGroup
-
Add the message to this group.
- add(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- addAll(Collection<? extends Properties>) - Method in class org.springframework.integration.history.MessageHistory
-
- addAll(int, Collection<? extends Properties>) - Method in class org.springframework.integration.history.MessageHistory
-
- addAttribute(String, Object) - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
-
- addConnection(TcpConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- addConstructorValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- addConstuctorValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- addCustomHeaders(TcpConnection, AbstractIntegrationMessageBuilder<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
- addDelayProperty(Message<?>, Message) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- addDestination(String...) - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
-
Add a destination (or destinations) to the subscribed list and subscribe it.
- addDestinationConfigToConstructor(Element, BeanDefinitionBuilder, ParserContext) - Static method in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
Adds destination configuration to constructor.
- addElementToHeaderMapping(String, String) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
-
- addElementToHeaderMapping(String, String, Class<?>) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
-
- addFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
-
- addFilters(FileListFilter<F>...) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
-
- addFilters(Collection<? extends FileListFilter<F>>) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
-
Not thread safe.
- addHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
-
Add the handler to the internal Set.
- addHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
-
- addHeaders(Message<?>, Map<String, Object>) - Method in class org.springframework.integration.file.splitter.FileSplitter
-
- addHeaders(Message<?>, Map<String, Object>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
-
Allows subclasses to add extra headers to the output messages.
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
-
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
-
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Add a channel interceptor to the end of the list.
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Add a channel interceptor to the specified index of the list.
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
- addInterceptor(ChannelInterceptor) - Method in interface org.springframework.integration.channel.ChannelInterceptorAware
-
- addInterceptor(int, ChannelInterceptor) - Method in interface org.springframework.integration.channel.ChannelInterceptorAware
-
- addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- addLifecyclesToRole(String, List<String>) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
- addLifecycleToRole(String, SmartLifecycle) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
- addLifecycleToRole(String, String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
- addListener(MetadataStoreListener) - Method in interface org.springframework.integration.metadata.ListenableMetadataStore
-
Registers a listener with the metadata store
- addListener(MetadataStoreListener) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
-
- addMatchingInterceptors(ChannelInterceptorAware, String) - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
-
Add any interceptor whose pattern matches against the channel's name.
- addMessage(Message<T>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
- addMessage(Message<T>) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- addMessage(Message<T>) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- addMessage(Message<T>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- addMessage(Message<T>) - Method in interface org.springframework.integration.store.MessageStore
-
Put the provided Message into the MessageStore.
- addMessage(Message<T>) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- addMessageDocument(MessageDocument) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
- addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- addMessagesToGroup(Object, Message<?>...) - Method in interface org.springframework.integration.store.MessageGroupStore
-
Store messages with an association to a group id.
- addMessagesToGroup(Object, Message<?>...) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Store a message in the database.
- addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
-
- addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
-
- addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
-
- addMessageToGroup(Object, Message<?>) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
- addMessageToGroup(Object, Message<?>) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
-
Store a message with an association to a group id.
- addMessagingAnnotationPostProcessor(Class<A>, MethodAnnotationPostProcessor<A>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
-
- addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- addNewConnection(TcpConnection) - Method in interface org.springframework.integration.ip.tcp.connection.TcpSender
-
When we are using sockets owned by a
TcpListener
, this
method is called each time a new connection is made.
- addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- addNewConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- addNotPropagatedHeaders(String...) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
-
- addNotPropagatedHeaders(String...) - Method in interface org.springframework.integration.handler.HeaderPropagationAware
-
Add headers that will NOT be copied from the inbound message if
the handler is configured to copy headers, instead of overwriting
the existing set.
- addPatternMapping(Pattern, ChannelAccessPolicy) - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
-
- addReadOnlyHeaders(String...) - Method in class org.springframework.integration.support.DefaultMessageBuilderFactory
-
Add headers to the configured list of read only headers.
- addRecipient(String, String) - Method in class org.springframework.integration.router.RecipientListRouter
-
- addRecipient(String) - Method in class org.springframework.integration.router.RecipientListRouter
-
- addRecipient(String, String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
-
Add a recipient with channelName and expression.
- addRecipient(String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
-
Add a recipient with channelName.
- addSessionFactory(String, SessionFactory<F>) - Method in class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
-
Add a session factory.
- addStandardHeaders(TcpConnection, AbstractIntegrationMessageBuilder<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
- addSupportedProtocols(String...) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
-
- addTopic(String, int) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
-
Add a topic to the subscribed list.
- addTopic(String...) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
-
Add a topic (or topics) to the subscribed list (qos=1).
- addTopic(String, int) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
- addTopics(String[], int[]) - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
-
Add topics to the subscribed list.
- addWhiteListPatterns(String...) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
Add patterns for packages/classes that are allowed to be deserialized.
- addWhiteListPatterns(String...) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Add patterns for packages/classes that are allowed to be deserialized.
- addWhiteListPatterns(String...) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
Add patterns for packages/classes that are allowed to be deserialized.
- addWhiteListPatterns(String...) - Method in class org.springframework.integration.mongodb.support.MongoDbMessageBytesConverter
-
Add patterns for packages/classes that are allowed to be deserialized.
- addWhiteListPatterns(String...) - Method in class org.springframework.integration.support.converter.WhiteListDeserializingConverter
-
Add package/class patterns to the white list.
- AdviceMessage<T> - Class in org.springframework.integration.message
-
A message implementation that is produced by an advice after
successful message handling.
- AdviceMessage(T, Message<?>) - Constructor for class org.springframework.integration.message.AdviceMessage
-
- AdviceMessage(T, Map<String, Object>, Message<?>) - Constructor for class org.springframework.integration.message.AdviceMessage
-
- AdviceMessage(T, MessageHeaders, Message<?>) - Constructor for class org.springframework.integration.message.AdviceMessage
-
- AdviceMessageJacksonDeserializer - Class in org.springframework.integration.support.json
-
- AdviceMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.AdviceMessageJacksonDeserializer
-
- afterCommit(Object) - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
- afterCommit(String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterCommit(String, String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterCommit(MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterCommit(String, MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterError() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
-
- afterError() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
-
- afterHandle(MetricsContext, boolean) - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
-
End a handle event
- afterHandle(MetricsContext, boolean) - Method in class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics
-
- afterHandle(MetricsContext, boolean) - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
-
- afterMessageHandled(Message<?>, MessageChannel, MessageHandler, Exception) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
-
- afterMessageHandled(Message<?>, MessageChannel, MessageHandler, Exception) - Method in class org.springframework.integration.security.channel.SecurityContextPropagationChannelInterceptor
-
- afterPropertiesSet() - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
-
- afterPropertiesSet() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
-
- afterPropertiesSet() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- afterPropertiesSet() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
-
- afterPropertiesSet() - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
-
- afterPropertiesSet() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
- afterPropertiesSet() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- afterPropertiesSet() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- afterPropertiesSet() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- afterPropertiesSet() - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
-
Deprecated.
- afterPropertiesSet() - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
- afterPropertiesSet() - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
-
- afterPropertiesSet() - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- afterPropertiesSet() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSSLSocketFactorySupport
-
- afterPropertiesSet() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNioSSLConnectionSupport
-
- afterPropertiesSet() - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
-
- afterPropertiesSet() - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
- afterPropertiesSet() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
- afterPropertiesSet() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
- afterPropertiesSet() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- afterPropertiesSet() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- afterPropertiesSet() - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Verify and sets the parameters.
- afterPropertiesSet() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
-
- afterPropertiesSet() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- afterPropertiesSet() - Method in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
-
- afterPropertiesSet() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- afterPropertiesSet() - Method in class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
-
- afterPropertiesSet() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
-
- afterPropertiesSet() - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
-
- afterPropertiesSet() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
-
- afterPropertiesSet() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
- afterPropertiesSet() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- afterPropertiesSet() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
-
- afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.aop.AbstractMessageSourceAdvice
-
Subclasses can take actions based on the result of the poll; e.g.
- afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.aop.CompoundTriggerAdvice
-
- afterReceive(Message<?>, MessageSource<?>) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
-
- afterReceive() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
-
- afterReceive() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
-
- afterReceiveCompletion(Message<?>, MessageChannel, Exception, Deque<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
-
- afterRelease(MessageGroup, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
Allows you to provide additional logic that needs to be performed after the MessageGroup was released.
- afterRelease(MessageGroup, Collection<Message<?>>, boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
Subclasses may override if special action is needed because the group was released or discarded
due to a timeout.
- afterRelease(MessageGroup, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.AggregatingMessageHandler
-
- afterRelease(MessageGroup, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
-
- afterRelease(MessageGroup, Collection<Message<?>>, boolean) - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
-
- afterRollback(Object) - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
- afterRollback(String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterRollback(String, String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterRollback(MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterRollback(String, MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- afterSend(MetricsContext, boolean) - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
-
End a send event.
- afterSend(MetricsContext, boolean) - Method in class org.springframework.integration.support.management.AggregatingMessageChannelMetrics
-
- afterSend(MetricsContext, boolean) - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
-
- afterSendCompletion(Message<?>, MessageChannel, boolean, Exception, Deque<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
-
- afterSessionEnded(WebSocketSession, CloseStatus) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
- afterSessionEnded(WebSocketSession, CloseStatus, MessageChannel) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
-
- afterSessionEnded(WebSocketSession, CloseStatus) - Method in interface org.springframework.integration.websocket.WebSocketListener
-
- afterSessionStarted(WebSocketSession) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
- afterSessionStarted(WebSocketSession, MessageChannel) - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
-
- afterSessionStarted(WebSocketSession) - Method in interface org.springframework.integration.websocket.WebSocketListener
-
- afterShutdown() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- afterShutdown() - Method in interface org.springframework.integration.context.OrderlyShutdownCapable
-
Called after normal shutdown of schedulers, executors etc,
and after the shutdown delay has elapsed, but before any
forced shutdown of any remaining active scheduler/executor
threads.Can optionally return the number of active messages
still in process.
- afterShutdown() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
- afterShutdown() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
- afterShutdown() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- afterShutdown() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- afterShutdown() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- afterShutdown() - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
-
- afterSingletonsInstantiated() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
-
- afterSingletonsInstantiated() - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
-
- afterSingletonsInstantiated() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- afterSingletonsInstantiated() - Method in class org.springframework.integration.expression.IntegrationEvaluationContextAwareBeanPostProcessor
-
Deprecated.
- afterSingletonsInstantiated() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- afterSingletonsInstantiated() - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
-
- afterTest() - Method in class org.springframework.integration.test.support.LogAdjustingTestSupport
-
- AGE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- AggregatedXmlMessageValidationException - Exception in org.springframework.integration.xml
-
- AggregatedXmlMessageValidationException(List<Throwable>) - Constructor for exception org.springframework.integration.xml.AggregatedXmlMessageValidationException
-
- aggregateHeaders(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
-
This default implementation simply returns all headers that have no conflicts among the group.
- AggregateMessageDeliveryException - Exception in org.springframework.integration.dispatcher
-
An Exception that encapsulates an aggregated group of Exceptions for use by dispatchers
that may try multiple handler invocations within a single dispatch operation.
- AggregateMessageDeliveryException(Message<?>, String, List<? extends Exception>) - Constructor for exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
-
- aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
-
- aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.DefaultAggregatingMessageGroupProcessor
-
- aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
-
Evaluate the expression provided on the messages (a collection) in the group, and delegate to the
MessagingTemplate
to send downstream.
- aggregatePayloads(MessageGroup, Map<String, Object>) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
-
- AggregatingChannelMetricsContext(long, long) - Constructor for class org.springframework.integration.support.management.AggregatingMessageChannelMetrics.AggregatingChannelMetricsContext
-
- AggregatingHandlerMetricsContext(long, long) - Constructor for class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics.AggregatingHandlerMetricsContext
-
- AggregatingMessageChannelMetrics - Class in org.springframework.integration.support.management
-
An implementation of
MessageChannelMetrics
that aggregates the total response
time over a sample, to avoid fetching the system time twice for every message.
- AggregatingMessageChannelMetrics() - Constructor for class org.springframework.integration.support.management.AggregatingMessageChannelMetrics
-
- AggregatingMessageChannelMetrics(String, int) - Constructor for class org.springframework.integration.support.management.AggregatingMessageChannelMetrics
-
Construct an instance with default metrics with window=10, period=1 second,
lapsePeriod=1 minute
.
- AggregatingMessageChannelMetrics(String, ExponentialMovingAverage, ExponentialMovingAverageRate, ExponentialMovingAverageRatio, ExponentialMovingAverageRate, int) - Constructor for class org.springframework.integration.support.management.AggregatingMessageChannelMetrics
-
Construct an instance with the supplied metrics.
- AggregatingMessageChannelMetrics.AggregatingChannelMetricsContext - Class in org.springframework.integration.support.management
-
- AggregatingMessageHandler - Class in org.springframework.integration.aggregator
-
- AggregatingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
-
- AggregatingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
-
- AggregatingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.AggregatingMessageHandler
-
- AggregatingMessageHandlerMetrics - Class in org.springframework.integration.support.management
-
An implementation of
MessageHandlerMetrics
that aggregates the total response
time over a sample, to avoid fetching the system time twice for every message.
- AggregatingMessageHandlerMetrics() - Constructor for class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics
-
- AggregatingMessageHandlerMetrics(String, int) - Constructor for class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics
-
Construct an instance with the default moving average window (10).
- AggregatingMessageHandlerMetrics(String, ExponentialMovingAverage, int) - Constructor for class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics
-
Construct an instance with the supplied
ExponentialMovingAverage
calculating
the duration of processing by the message handler (and any downstream synchronous
endpoints).
- AggregatingMessageHandlerMetrics.AggregatingHandlerMetricsContext - Class in org.springframework.integration.support.management
-
- AggregatingMetricsFactory - Class in org.springframework.integration.support.management
-
Implementation that returns aggregating metrics.
- AggregatingMetricsFactory(int) - Constructor for class org.springframework.integration.support.management.AggregatingMetricsFactory
-
- Aggregator - Annotation Type in org.springframework.integration.annotation
-
Indicates that a method is capable of aggregating messages.
- AggregatorAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
-
- AggregatorAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
-
- AggregatorFactoryBean - Class in org.springframework.integration.config
-
- AggregatorFactoryBean() - Constructor for class org.springframework.integration.config.AggregatorFactoryBean
-
- AggregatorParser - Class in org.springframework.integration.config.xml
-
Parser for the aggregator element of the integration namespace.
- AggregatorParser() - Constructor for class org.springframework.integration.config.xml.AggregatorParser
-
- allEndpointsRunning(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
-
Return true if all endpoints in the role are running.
- allocate(int) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
Allocates a ByteBuffer of the requested length using normal or
direct buffers, depending on the usingDirectBuffers field.
- ALLOW - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- AMQP_RAW_MESSAGE - Static variable in class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
-
Header name/retry context variable for the raw received message.
- AmqpChannelFactoryBean - Class in org.springframework.integration.amqp.config
-
If point-to-point, we send to the default exchange with the routing key
equal to "[beanName]" and we declare that same Queue and register a listener
if message-driven or poll explicitly otherwise.
- AmqpChannelFactoryBean() - Constructor for class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- AmqpChannelFactoryBean(boolean) - Constructor for class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- AmqpChannelParser - Class in org.springframework.integration.amqp.config
-
Parser for the 'channel' and 'publish-subscribe-channel' elements of the
Spring Integration AMQP namespace.
- AmqpChannelParser() - Constructor for class org.springframework.integration.amqp.config.AmqpChannelParser
-
- AmqpHeaderMapper - Interface in org.springframework.integration.amqp.support
-
- AmqpInboundChannelAdapter - Class in org.springframework.integration.amqp.inbound
-
Adapter that receives Messages from an AMQP Queue, converts them into
Spring Integration Messages, and sends the results to a Message Channel.
- AmqpInboundChannelAdapter(AbstractMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- AmqpInboundChannelAdapter.Listener - Class in org.springframework.integration.amqp.inbound
-
- AmqpInboundChannelAdapterParser - Class in org.springframework.integration.amqp.config
-
Parser for the AMQP 'inbound-channel-adapter' element.
- AmqpInboundGateway - Class in org.springframework.integration.amqp.inbound
-
Adapter that receives Messages from an AMQP Queue, converts them into
Spring Integration Messages, and sends the results to a Message Channel.
- AmqpInboundGateway(AbstractMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
- AmqpInboundGateway(AbstractMessageListenerContainer, AmqpTemplate) - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
- AmqpInboundGateway.Listener - Class in org.springframework.integration.amqp.inbound
-
- AmqpInboundGatewayParser - Class in org.springframework.integration.amqp.config
-
Parser for the AMQP 'inbound-gateway' element.
- AmqpMessageHeaderErrorMessageStrategy - Class in org.springframework.integration.amqp.support
-
An
ErrorMessageStrategy
extension that adds the raw AMQP message as
a header to the
org.springframework.integration.message.EnhancedErrorMessage
.
- AmqpMessageHeaderErrorMessageStrategy() - Constructor for class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
-
- AmqpNamespaceHandler - Class in org.springframework.integration.amqp.config
-
Namespace handler for the AMQP schema.
- AmqpNamespaceHandler() - Constructor for class org.springframework.integration.amqp.config.AmqpNamespaceHandler
-
- AmqpOutboundChannelAdapterParser - Class in org.springframework.integration.amqp.config
-
Parser for the AMQP 'outbound-channel-adapter' element.
- AmqpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.amqp.config.AmqpOutboundChannelAdapterParser
-
- AmqpOutboundEndpoint - Class in org.springframework.integration.amqp.outbound
-
Adapter that converts and sends Messages to an AMQP Exchange.
- AmqpOutboundEndpoint(AmqpTemplate) - Constructor for class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- AmqpOutboundGatewayParser - Class in org.springframework.integration.amqp.config
-
Parser for the AMQP 'outbound-channel-adapter' element.
- AmqpOutboundGatewayParser() - Constructor for class org.springframework.integration.amqp.config.AmqpOutboundGatewayParser
-
- AnnotatedMethodFilter - Class in org.springframework.integration.util
-
A MethodFilter implementation that enables the following:
matching on method name, if available
exclusion of void-returning methods if 'requiresReply' is true
limiting to annotated methods if at least one is present
- AnnotatedMethodFilter(Class<? extends Annotation>, String, boolean) - Constructor for class org.springframework.integration.util.AnnotatedMethodFilter
-
- AnnotationConfigParser - Class in org.springframework.integration.config.xml
-
Parser for the <annotation-config> element of the integration namespace.
- AnnotationConfigParser() - Constructor for class org.springframework.integration.config.xml.AnnotationConfigParser
-
- AnnotationConstants - Class in org.springframework.integration.annotation
-
Common value constants for annotation attributes.
- annotationType - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- ApacheCommonsFileTailingMessageProducer - Class in org.springframework.integration.file.tail
-
File tailer that delegates to the Apache Commons Tailer.
- ApacheCommonsFileTailingMessageProducer() - Constructor for class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
-
- APP_NAME - Static variable in class org.springframework.integration.syslog.SyslogHeaders
-
- append(Message<?>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Send a file to a remote server, based on information in a message, appending.
- append(Message<?>, String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Send a file to a remote server, based on information in a message, appending.
- append(Message<?>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- append(Message<?>, String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- append(InputStream, String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- append(InputStream, String) - Method in interface org.springframework.integration.file.remote.session.Session
-
Append to a file.
- append(InputStream, String) - Method in class org.springframework.integration.ftp.session.FtpSession
-
- append(InputStream, String) - Method in class org.springframework.integration.sftp.session.SftpSession
-
- append(double) - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
-
Add a new measurement to the series.
- applicationContext - Variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
- ApplicationEventListeningMessageProducer - Class in org.springframework.integration.event.inbound
-
- ApplicationEventListeningMessageProducer() - Constructor for class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- ApplicationEventMulticasterParser - Class in org.springframework.integration.config.xml
-
Parser for the <application-event-multicaster> element of the
integration namespace.
- ApplicationEventMulticasterParser() - Constructor for class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
-
- ApplicationEventPublishingMessageHandler - Class in org.springframework.integration.event.outbound
-
- ApplicationEventPublishingMessageHandler() - Constructor for class org.springframework.integration.event.outbound.ApplicationEventPublishingMessageHandler
-
- apply(Statement, Description) - Method in class org.springframework.integration.test.rule.Log4jClassLevelAdjuster
-
- apply(Statement, FrameworkMethod, Object) - Method in class org.springframework.integration.test.rule.Log4jLevelAdjuster
-
- apply(Statement, Description) - Method in class org.springframework.integration.test.support.LongRunningIntegrationTest
-
- apply(T) - Method in interface org.springframework.integration.util.Function
-
Execute the logic of the action, accepting the given parameter.
- APPLY_SEQUENCE - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- applyAndBind(String, Iterable<T>, EntityManager) - Static method in class org.springframework.integration.jpa.support.JpaUtils
-
Creates a where-clause referencing the given entities and appends it to the given query string.
- applyReceiveOnlyAdviceChain(Collection<Advice>) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- applyReceiveOnlyAdviceChain(Collection<Advice>) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- applySystemFileSeparator(String) - Static method in class org.springframework.integration.test.util.TestUtils
-
Update file path by replacing any '/' with the system's file separator.
- ArgumentsStrategy - Interface in org.springframework.integration.redis.outbound
-
- asFileInfoList(Collection<F>) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
- asFileInfoList(Collection<F>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- asFileInfoList(Collection<FTPFile>) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
-
- asFileInfoList(Collection<FTPFile>) - Method in class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
-
- asFileInfoList(Collection<ChannelSftp.LsEntry>) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
-
- asFileInfoList(Collection<ChannelSftp.LsEntry>) - Method in class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
-
- asMap() - Method in class org.springframework.integration.syslog.DefaultMessageConverter
-
- assertions - Variable in class org.springframework.integration.test.mail.TestMailServer.MailServer
-
- assertReceived(String) - Method in class org.springframework.integration.test.mail.TestMailServer.MailServer
-
- AsyncAmqpOutboundGateway - Class in org.springframework.integration.amqp.outbound
-
An outbound gateway where the sending thread is released immediately and the reply
is sent on the async template's listener container thread.
- AsyncAmqpOutboundGateway(AsyncRabbitTemplate) - Constructor for class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
-
- asyncConvertAndSend(Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertAndSend(MessageChannel, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertAndSend(String, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertAndSend(Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertAndSend(MessageChannel, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertAndSend(String, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertSendAndReceive(Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertSendAndReceive(MessageChannel, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertSendAndReceive(String, Object) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertSendAndReceive(Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertSendAndReceive(MessageChannel, Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertSendAndReceive(String, Object, MessagePostProcessor) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncConvertSendAndReceive(Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertSendAndReceive(MessageChannel, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertSendAndReceive(String, Object) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertSendAndReceive(Object, MessagePostProcessor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertSendAndReceive(MessageChannel, Object, MessagePostProcessor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncConvertSendAndReceive(String, Object, MessagePostProcessor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- AsyncMessagingOperations - Interface in org.springframework.integration.core
-
- AsyncMessagingTemplate - Class in org.springframework.integration.core
-
- AsyncMessagingTemplate() - Constructor for class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncReceive() - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncReceive(PollableChannel) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncReceive(String) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncReceive() - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncReceive(PollableChannel) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncReceive(String) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncReceiveAndConvert() - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncReceiveAndConvert(PollableChannel) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncReceiveAndConvert(String) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncReceiveAndConvert() - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncReceiveAndConvert(PollableChannel) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncReceiveAndConvert(String) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSend(Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncSend(MessageChannel, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncSend(String, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncSend(Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSend(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSend(String, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSendAndReceive(Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncSendAndReceive(MessageChannel, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncSendAndReceive(String, Message<?>) - Method in interface org.springframework.integration.core.AsyncMessagingOperations
-
- asyncSendAndReceive(Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSendAndReceive(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSendAndReceive(String, Message<?>) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- asyncSendMessage(DatagramPacket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- ATTACHMENT_FILENAME - Static variable in class org.springframework.integration.mail.MailHeaders
-
- AttributePollingChannelAdapterParser - Class in org.springframework.integration.jmx.config
-
- AttributePollingChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.AttributePollingChannelAdapterParser
-
- AttributePollingMessageSource - Class in org.springframework.integration.jmx
-
- AttributePollingMessageSource() - Constructor for class org.springframework.integration.jmx.AttributePollingMessageSource
-
- AUTHORIZATION - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- AUTO_ACKNOWLEDGE - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
-
- AUTO_ACKNOWLEDGE_STRING - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
-
- AUTO_CREATE_CHANNEL_CANDIDATES_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
-
- AUTO_STARTUP - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- autoCreateDirectChannel(String, BeanDefinitionRegistry) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
-
- availablePermits() - Method in class org.springframework.integration.util.UpperBound
-
- await() - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
-
- CACHE_CONTROL - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- CacheListeningMessageProducer - Class in org.springframework.integration.gemfire.inbound
-
An inbound endpoint that listens to a GemFire region for events and then publishes Messages to
a channel.
- CacheListeningMessageProducer(Region<?, ?>) - Constructor for class org.springframework.integration.gemfire.inbound.CacheListeningMessageProducer
-
- CacheWritingMessageHandler - Class in org.springframework.integration.gemfire.outbound
-
- CacheWritingMessageHandler(Region) - Constructor for class org.springframework.integration.gemfire.outbound.CacheWritingMessageHandler
-
- 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
-
A
SessionFactory
implementation 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.support.leader.LockRegistryLeaderInitiator.LeaderSelector
-
- CallerBlocksPolicy - Class in org.springframework.integration.util
-
- CallerBlocksPolicy(long) - Constructor for class org.springframework.integration.util.CallerBlocksPolicy
-
- 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
-
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.TransformerFactoryBean
-
- 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 the messages (a collection) in the group and 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
-
- 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
-
- CC - Static variable in class org.springframework.integration.mail.MailHeaders
-
- ChainFileListFilter<F> - Class in org.springframework.integration.file.filters
-
- ChainFileListFilter() - 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
-
- CHANNEL_INITIALIZER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
-
- ChannelAccessPolicy - Interface in org.springframework.integration.security.channel
-
Interface to encapsulate ConfigAttribute
s for secured channel
send and receive operations.
- ChannelInterceptorAware - Interface in org.springframework.integration.channel
-
- ChannelInterceptorList(Log) - 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
-
- ChannelInvocation - Class in org.springframework.integration.security.channel
-
- ChannelInvocation(MethodInvocation) - Constructor for class org.springframework.integration.security.channel.ChannelInvocation
-
- channelMappings - Variable in class org.springframework.integration.router.AbstractMappingMessageRouter
-
- ChannelMessageStore - Interface in org.springframework.integration.store
-
A marker interface that indicates this message store has optimizations for
use in a
QueueChannel
.
- ChannelMessageStoreQueryProvider - Interface in org.springframework.integration.jdbc.store.channel
-
- 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 a
MessageChannel
(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
-
- ChannelPurger(QueueChannel...) - Constructor for class org.springframework.integration.channel.ChannelPurger
-
- ChannelPurger(MessageSelector, QueueChannel...) - Constructor for class org.springframework.integration.channel.ChannelPurger
-
- channelResolver - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- channelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
-
- channels - Variable in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- CHANNELS_AUTOCREATE - Static variable in class org.springframework.integration.context.IntegrationProperties
-
Specifies whether to allow create automatically
DirectChannel
beans for non-declared channels or not.
- CHANNELS_MAX_BROADCAST_SUBSCRIBERS - Static variable in class org.springframework.integration.context.IntegrationProperties
-
- CHANNELS_MAX_UNICAST_SUBSCRIBERS - Static variable in class org.springframework.integration.context.IntegrationProperties
-
- ChannelSecurityInterceptor - Class in org.springframework.integration.security.channel
-
An AOP interceptor that enforces authorization for MessageChannel send and/or receive calls.
- ChannelSecurityInterceptor() - Constructor for class org.springframework.integration.security.channel.ChannelSecurityInterceptor
-
- ChannelSecurityInterceptor(ChannelSecurityMetadataSource) - Constructor for class org.springframework.integration.security.channel.ChannelSecurityInterceptor
-
- ChannelSecurityInterceptorBeanPostProcessor - Class in org.springframework.integration.security.config
-
- ChannelSecurityInterceptorBeanPostProcessor(Map<String, Set<Pattern>>) - Constructor for class org.springframework.integration.security.config.ChannelSecurityInterceptorBeanPostProcessor
-
- ChannelSecurityInterceptorBeanPostProcessor(Map<String, Set<Pattern>>, Map<String, Map<Pattern, ChannelAccessPolicy>>) - Constructor for class org.springframework.integration.security.config.ChannelSecurityInterceptorBeanPostProcessor
-
- ChannelSecurityMetadataSource - Class in org.springframework.integration.security.channel
-
The
SecurityMetadataSource
implementation for secured
MessageChannel
s.
- ChannelSecurityMetadataSource() - Constructor for class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
-
- ChannelSecurityMetadataSource(Map<Pattern, ChannelAccessPolicy>) - Constructor for class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
-
- channelToChannelName(Object) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- channelToChannelName(Object, long) - 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 interface org.springframework.integration.support.channel.HeaderChannelRegistry
-
Converts the channel to a name (String).
- CharacterStreamReadingMessageSource - Class in org.springframework.integration.stream
-
- CharacterStreamReadingMessageSource(Reader) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
- CharacterStreamReadingMessageSource(Reader, int) - Constructor for class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
- CharacterStreamWritingMessageHandler - Class in org.springframework.integration.stream
-
- CharacterStreamWritingMessageHandler(Writer) - Constructor for class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
-
- CharacterStreamWritingMessageHandler(Writer, int) - Constructor for class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
-
- 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
-
- 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.
- 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.annotation.AbstractMethodAnnotationPostProcessor
-
- checkTaskExecutor(String) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
Creates a default task executor if none was supplied.
- checkWhiteList(Class<?>) - Method in class org.springframework.integration.support.converter.WhiteListDeserializingConverter
-
- 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.
- 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.
- 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
-
- 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
-
- clearCache() - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Clear the resource bundle cache.
- clearMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- clearQueue() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- clearQueue() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- 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
-
- 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
-
RemoteFileTemplate
callback with the underlying client instance providing
access to lower level methods.
- ClientCallbackWithoutResult<C> - Class in org.springframework.integration.file.remote
-
RemoteFileTemplate
callback with the underlying client instance providing
access to lower level methods where no result is returned.
- ClientCallbackWithoutResult() - Constructor for class org.springframework.integration.file.remote.ClientCallbackWithoutResult
-
- clientMode - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- 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
-
- ClientStompEncoder - Class in org.springframework.integration.websocket.support
-
A
StompEncoder
extension 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
-
- ClientWebSocketContainer(WebSocketClient, String, Object...) - Constructor for class org.springframework.integration.websocket.ClientWebSocketContainer
-
- ClientWebSocketContainerParser - Class in org.springframework.integration.websocket.config
-
- ClientWebSocketContainerParser() - Constructor for class org.springframework.integration.websocket.config.ClientWebSocketContainerParser
-
- 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.
- close(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
-
- close(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway.Listener
-
- 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(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- 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
-
Closes 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.util.FunctionIterator
-
- CLOSEABLE_RESOURCE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
-
- CloseableIterator<E> - Interface in org.springframework.integration.util
-
A
CloseableIterator
is intended to be used when it may hold resources (such as file or socket handles).
- closeConnection(String) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Close a connection with the specified connection id.
- 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().
- 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
-
- Codec - Interface in org.springframework.integration.codec
-
Interface for classes that perform both encode (serialize) and decode (deserialize) on multiple classes.
- CodecMessageConverter - Class in org.springframework.integration.codec
-
- CodecMessageConverter(Codec) - Constructor for class org.springframework.integration.codec.CodecMessageConverter
-
- COLLECTION_NAME - Static variable in class org.springframework.integration.mongodb.support.MongoHeaders
-
- 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
-
- command - Variable in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- COMMAND - Static variable in class org.springframework.integration.redis.support.RedisHeaders
-
- CommonSocketOptions - Interface in org.springframework.integration.ip
-
- compare(Message<?>, Message<?>) - Method in class org.springframework.integration.aggregator.MessageSequenceComparator
-
- compare(Message<?>, Message<?>) - Method in class org.springframework.integration.aggregator.SequenceNumberComparator
-
If both messages have a sequence number then compare that, otherwise if one has a sequence number and the other
doesn't then the numbered message comes first, or finally of neither has a sequence number then they are equal in
rank.
- compareTo(FileInfo<F>) - Method in class org.springframework.integration.file.remote.AbstractFileInfo
-
- COMPLETE - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
-
- complete() - Method in interface org.springframework.integration.store.MessageGroup
-
Complete the group.
- complete() - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- completeGroup(Object, MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- completeGroup(Message<?>, Object, MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- completeGroup(Object) - Method in class org.springframework.integration.jdbc.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
-
- ComponentsEvaluationCallback(EvaluationContext, Object, Class<?>) - Constructor for class org.springframework.integration.expression.ExpressionEvalMap.ComponentsEvaluationCallback
-
- 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
-
An
Executor
that encapsulates two underlying executors.
- CompositeExecutor(Executor, Executor) - Constructor for class org.springframework.integration.util.CompositeExecutor
-
- CompositeFileListFilter<F> - Class in org.springframework.integration.file.filters
-
- 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
-
A
KryoRegistrar
that 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.support.management.graph
-
Represents a composite message handler.
- CompositeMessageHandlerNode(int, String, MessageHandler, String, String, List<CompositeMessageHandlerNode.InnerHandler>) - Constructor for class org.springframework.integration.support.management.graph.CompositeMessageHandlerNode
-
- CompositeMessageHandlerNode.InnerHandler - Class in org.springframework.integration.support.management.graph
-
- CompoundTrigger - Class in org.springframework.integration.util
-
- 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
-
- CompoundTriggerAdvice(CompoundTrigger, Trigger) - Constructor for class org.springframework.integration.aop.CompoundTriggerAdvice
-
- ConcurrentMetadataStore - Interface in org.springframework.integration.metadata
-
Supports atomic updates to values in the store.
- config - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- ConfigurableMetrics - Interface in org.springframework.integration.support.management
-
Marker interface for metrics.
- ConfigurableMetricsAware<M extends ConfigurableMetrics> - Interface in org.springframework.integration.support.management
-
- ConfigurableMongoDbMessageStore - Class in org.springframework.integration.mongodb.store
-
- ConfigurableMongoDbMessageStore(MongoTemplate) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- ConfigurableMongoDbMessageStore(MongoTemplate, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- ConfigurableMongoDbMessageStore(MongoDbFactory) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- ConfigurableMongoDbMessageStore(MongoDbFactory, MappingMongoConverter) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- ConfigurableMongoDbMessageStore(MongoDbFactory, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- ConfigurableMongoDbMessageStore(MongoDbFactory, MappingMongoConverter, String) - Constructor for class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- configure(RmiProxyFactoryBean) - Method in interface org.springframework.integration.rmi.RmiOutboundGateway.RmiProxyFactoryBeanConfigurer
-
Perform additional configuration of the factory bean before the
RequestReplyExchanger
is created.
- configureAdviceChain(Element, Element, BeanDefinition, ParserContext) - 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
-
- 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.
- 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
-
- configureMappingRouter(AbstractMappingMessageRouter) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- configureMetrics(AbstractMessageChannelMetrics) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
- configureMetrics(AbstractMessageChannelMetrics) - Method in class org.springframework.integration.channel.NullChannel
-
- configureMetrics(AbstractMessageHandlerMetrics) - Method in class org.springframework.integration.handler.AbstractMessageHandler
-
- configureMetrics(M) - Method in interface org.springframework.integration.support.management.ConfigurableMetricsAware
-
- configureMetrics(AbstractMessageHandlerMetrics) - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
-
- 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, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- configureRouter(AbstractMessageRouter) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- configureSplitter(AbstractMessageSplitter) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- configureTransactionAttributes(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Parse a "transactional" element and configure a
TransactionInterceptor
with "transactionManager" and other "transactionDefinition" properties.
- configureTransactionDefinition(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Parse attributes of "transactional" element and configure a
DefaultTransactionAttribute
with provided "transactionDefinition" properties.
- confirm(CorrelationData, boolean, String) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- connect(StompSessionHandler) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- connect(StompSessionHandler) - Method in interface org.springframework.integration.stomp.StompSessionManager
-
- connectIfNeeded() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
- CONNECTION - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- 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 - Interface in org.springframework.integration.ip.tcp.connection
-
A factory used to create TcpConnection objects.
- connectionLost(Throwable) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
- connectionLost(Throwable) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
- 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
-
- constructType(Type) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
-
- constructType(Type) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
-
- ConsumerEndpointFactoryBean - Class in org.springframework.integration.config
-
- ConsumerEndpointFactoryBean() - Constructor for class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- ConsumerStopAction - Enum in org.springframework.integration.mqtt.core
-
Action to take regarding subscrptions when consumer stops.
- contains(Object) - Method in class org.springframework.integration.history.MessageHistory
-
- containsAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
-
- containsElementIgnoreCase(String[], String) - 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_DISPOSITION - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- CONTENT_ENCODING - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- CONTENT_LANGUAGE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- CONTENT_LENGTH - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- CONTENT_LOCATION - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- CONTENT_MD5 - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- CONTENT_RANGE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- CONTENT_TYPE - 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
-
- Context - Interface in org.springframework.integration.leader
-
Interface that defines the context for candidate leadership.
- ContinuousQueryMessageProducer - Class in org.springframework.integration.gemfire.inbound
-
Responds to a Gemfire continuous query (set using the #query field) that is
constantly evaluated against a cache
Region
.
- ContinuousQueryMessageProducer(ContinuousQueryListenerContainer, String) - Constructor for class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
-
- ControlBusMethodFilter - Class in org.springframework.integration.expression
-
- 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
-
- controlEncoding - Variable in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- conversionService - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- convert(MBeanServerConnection, ObjectInstance) - Method in class org.springframework.integration.jmx.DefaultMBeanObjectConverter
-
- convert(MBeanServerConnection, ObjectInstance) - Method in interface org.springframework.integration.jmx.MBeanObjectConverter
-
- convert(Object, TypeDescriptor, TypeDescriptor) - Method in class org.springframework.integration.mongodb.support.MongoDbMessageBytesConverter
-
- convert(byte[]) - Method in class org.springframework.integration.support.converter.WhiteListDeserializingConverter
-
- convert(JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
-
- convert(Object) - Method in class org.springframework.integration.util.UUIDConverter
-
- 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.transformer.PayloadTypeConvertingTransformer
-
- 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
-
- convertExpressions(Collection<ProcedureParameter>) - Static method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
Utility method that converts a Collection of
ProcedureParameter
to
a Map containing only expression parameters.
- convertStaticParameters(Collection<ProcedureParameter>) - Static method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
Utility method that converts a Collection of
ProcedureParameter
to
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 org.springframework.integration.jdbc.config.JdbcTypesEnum
-
Retrieves 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
-
- COOKIE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- 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, 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.
- CorrelatingMessageBarrier - Class in org.springframework.integration.aggregator
-
This Endpoint serves as a barrier for messages that should not be processed yet.
- CorrelatingMessageBarrier(MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageBarrier
-
- CorrelatingMessageBarrier() - Constructor for class org.springframework.integration.aggregator.CorrelatingMessageBarrier
-
- CORRELATION_ID - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
-
- CORRELATION_ID - Static variable in class org.springframework.integration.jms.JmsHeaders
-
Deprecated.
- CorrelationStrategy - Interface in org.springframework.integration.aggregator
-
Strategy for determining how messages can be correlated.
- CorrelationStrategy - Annotation Type 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
-
- CorrelationStrategyFactoryBean() - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
-
- CorrelationStrategyFactoryBean(Object) - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
-
- CorrelationStrategyFactoryBean(Object, String) - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
-
- CqEventType - Enum in org.springframework.integration.gemfire.inbound
-
Enumeration of GemFire Continuous Query Event Types
- create(Object) - Method in interface org.springframework.integration.store.MessageGroupFactory
-
Create a
MessageGroup
instance based on the provided
groupId
.
- create(Collection<? extends Message<?>>, Object) - Method in interface org.springframework.integration.store.MessageGroupFactory
-
Create a
MessageGroup
instance based on the provided
groupId
and with the
messages
for the group.
- create(Collection<? extends Message<?>>, Object, long, boolean) - Method in interface org.springframework.integration.store.MessageGroupFactory
-
Create a
MessageGroup
instance based on the provided
groupId
and with the
messages
for the group.
- create(MessageGroupStore, Object) - Method in interface org.springframework.integration.store.MessageGroupFactory
-
Create a
MessageGroup
instance based on the provided
groupId
.
- create(MessageGroupStore, Object, long, boolean) - Method in interface org.springframework.integration.store.MessageGroupFactory
-
Create a
MessageGroup
instance based on the provided
groupId
.
- create(Object) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
-
- create(Collection<? extends Message<?>>, Object) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
-
- create(Collection<? extends Message<?>>, Object, long, boolean) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
-
- create(MessageGroupStore, Object) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
-
- create(MessageGroupStore, Object, long, boolean) - Method in class org.springframework.integration.store.SimpleMessageGroupFactory
-
- create(Object) - Method in class org.springframework.integration.transaction.DefaultTransactionSynchronizationFactory
-
- create(Object) - Method in interface org.springframework.integration.transaction.TransactionSynchronizationFactory
-
- createChannelMetrics(String) - Method in class org.springframework.integration.support.management.AggregatingMetricsFactory
-
- createChannelMetrics(String) - Method in class org.springframework.integration.support.management.DefaultMetricsFactory
-
- createChannelMetrics(String) - Method in interface org.springframework.integration.support.management.MetricsFactory
-
- 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.
- CREATED_DATE - Static variable in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- CREATED_DATE_KEY - Static variable in class org.springframework.integration.jdbc.JdbcMessageStore
-
The name of the message header that stores a timestamp for the time the message was inserted.
- CREATED_DATE_KEY - Static variable in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
The name of the message header that stores a timestamp for the time the message was inserted.
- CREATED_DATE_KEY - Static variable in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
-
The name of the message header that stores a timestamp for the time the message was inserted.
- CREATED_DATE_KEY - Static variable in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
The name of the message header that stores a timestamp for the time the message was inserted.
- 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
-
- createDirectChannel(Element, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- createDirectHandlerIfPossible(Object, String) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- createDispatcher() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
-
- createDispatcher() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
-
- 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.annotation.AbstractMethodAnnotationPostProcessor
-
- createEndpoint(MessageHandler, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeToAnnotationPostProcessor
-
- createEvaluationContext() - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
- createEvaluationContext() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
- 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(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
Subclasses must implement this method to create the MessageHandler.
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeToAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.FilterAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.InboundChannelAdapterAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.RouterAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.ServiceActivatorAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.SplitterAnnotationPostProcessor
-
- createHandler(Object, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.TransformerAnnotationPostProcessor
-
- createHandler() - Method in class org.springframework.integration.config.ExpressionControlBusFactoryBean
-
- createHandler(Transformer) - Method in class org.springframework.integration.config.TransformerFactoryBean
-
- createHandler() - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- createHandler() - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
-
- createHandlerInternal() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- createHandlerMetrics(String) - Method in class org.springframework.integration.support.management.AggregatingMetricsFactory
-
- createHandlerMetrics(String) - Method in class org.springframework.integration.support.management.DefaultMetricsFactory
-
- createHandlerMetrics(String) - Method in interface org.springframework.integration.support.management.MetricsFactory
-
- createHeaderMatcher(Collection<String>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
- 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.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.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- createInstance() - Method in class org.springframework.integration.sftp.session.JschProxyFactoryBean
-
- createInstance() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- createInstance() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- createJavaType(Map<String, Object>, String) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
-
- createJavaType(Map<String, Object>, String) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
-
- createJsonParser(String) - Method in class org.springframework.integration.support.json.Jackson2JsonMessageParser
-
- createMessageProcessingHandler(MessageProcessor<T>) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
-
- createMessageProcessingHandler(MessageProcessor<T>) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- 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(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
-
- createNewConnection(SocketChannel, boolean, boolean, ApplicationEventPublisher, String) - Method in interface org.springframework.integration.ip.tcp.connection.TcpNioConnectionSupport
-
- 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
-
- 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
-
- createParameterSourceNoCache(Object) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
-
- 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
-
- createServerSocket(int, int, InetAddress) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
- 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.
- createSocket(String, int) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
-
- createSource(Object) - Method in class org.springframework.integration.xml.source.DomSourceFactory
-
- createSource(Object) - Method in interface org.springframework.integration.xml.source.SourceFactory
-
Create appropriate
Source
instance for
payload
- 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 specified propertyName
if necessary.
- createTaskScheduler(int) - Static method in class org.springframework.integration.test.util.TestUtils
-
- createTestApplicationContext() - Static method in class org.springframework.integration.test.util.TestUtils
-
- createWriter(File, boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Create a buffered writer for the file, for String payloads.
- CrossOrigin - Class in org.springframework.integration.http.inbound
-
- CrossOrigin() - Constructor for class org.springframework.integration.http.inbound.CrossOrigin
-
- CuratorFrameworkFactoryBean - Class in org.springframework.integration.zookeeper.config
-
A spring-friendly way to build a
CuratorFramework
and implementing
SmartLifecycle
.
- CuratorFrameworkFactoryBean(String) - Constructor for class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
-
Construct an instance using the supplied connection string and using a default
retry policy new 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.
- current() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
-
- DatagramPacketMessageMapper - Class in org.springframework.integration.ip.udp
-
Message Mapper for converting to and from UDP DatagramPackets.
- DatagramPacketMessageMapper() - Constructor for class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
-
- DATE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- DATE_FORMATS - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- decode(InputStream, Class<T>) - Method in interface org.springframework.integration.codec.Codec
-
Decode an object of a given type
- decode(byte[], Class<T>) - Method in interface org.springframework.integration.codec.Codec
-
Decode an object of a given type
- decode(InputStream, Class<T>) - Method in class org.springframework.integration.codec.CompositeCodec
-
- decode(byte[], Class<T>) - Method in class org.springframework.integration.codec.CompositeCodec
-
- decode(byte[], Class<T>) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
- decode(InputStream, Class<T>) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
- DECODE_ERRORS - Static variable in class org.springframework.integration.syslog.SyslogHeaders
-
- DecodingTransformer<T> - Class in org.springframework.integration.transformer
-
- DecodingTransformer(Codec, Class<T>) - Constructor for class org.springframework.integration.transformer.DecodingTransformer
-
Construct an instance to use the supplied codec to decode to the supplied type.
- DecodingTransformer(Codec, Expression) - Constructor for class org.springframework.integration.transformer.DecodingTransformer
-
Construct an instance to use the supplied codec to decode to the supplied type.
- decorate(Node, BeanDefinitionHolder, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
-
- decorate(MessageHandlingRunnable) - Method in interface org.springframework.integration.dispatcher.MessageHandlingTaskDecorator
-
- decorateMessage(Message<?>) - Method in interface org.springframework.integration.support.MessageDecorator
-
- DEFAULT_BUSY_WAIT_TIME - Static variable in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- DEFAULT_CHARSET - Static variable in class org.springframework.integration.util.UUIDConverter
-
- DEFAULT_COLLECTION_NAME - Static variable in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- DEFAULT_COLLECTION_NAME - Static variable in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
-
- DEFAULT_CONFIGURING_POSTPROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
-
- DEFAULT_DOMAIN - Static variable in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- DEFAULT_FILE_REGISTRATION_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
-
- DEFAULT_HEADER_TYPES - Static variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
-
- DEFAULT_HEART_BEAT_TIME - Static variable in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- DEFAULT_MESSAGEHEADERS_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
-
- DEFAULT_MOVING_AVERAGE_WINDOW - Static variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
-
- DEFAULT_MUTABLE_MESSAGEHEADERS_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
-
- DEFAULT_POLLER - Static variable in class org.springframework.integration.scheduling.PollerMetadata
-
A convenient short alias for the global default poller bean name.
- DEFAULT_POLLER_METADATA_BEAN_NAME - Static variable in class org.springframework.integration.scheduling.PollerMetadata
-
- DEFAULT_PORT - Static variable in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
-
- DEFAULT_PORT_RANGE_MAX - Static variable in class org.springframework.integration.test.util.SocketUtils
-
- DEFAULT_PORT_RANGE_MIN - Static variable in class org.springframework.integration.test.util.SocketUtils
-
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- DEFAULT_REGION - Static variable in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Default region property, used to partition the message store.
- DEFAULT_REPLY_TIMEOUT - Static variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- DEFAULT_SI_USER_FLAG - Static variable in class org.springframework.integration.mail.AbstractMailReceiver
-
Default user flag for marking messages as seen by this receiver:
"spring-integration-mail-adapter".
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.JdbcMessageStore
-
Default value for the table prefix property.
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Default value for the table prefix property.
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Default value for the table prefix property.
- DEFAULT_THRESHOLD - Static variable in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
-
Default threshold is effectively infinite.
- DEFAULT_TIMEOUT - Static variable in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
-
Default timeout is one minute.
- DEFAULT_TTL - Static variable in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Default value for the time-to-live property.
- DefaultAggregatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
-
This implementation of MessageGroupProcessor will take the messages from the
MessageGroup and pass them on in a single message with a Collection as a payload.
- DefaultAggregatingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.DefaultAggregatingMessageGroupProcessor
-
- DefaultAmqpHeaderMapper - Class in org.springframework.integration.amqp.support
-
- DefaultAmqpHeaderMapper() - Constructor for class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
- DefaultCandidate - Class in org.springframework.integration.leader
-
- DefaultCandidate() - Constructor for class org.springframework.integration.leader.DefaultCandidate
-
Instantiate a default candidate.
- DefaultCandidate(String, String) - Constructor for class org.springframework.integration.leader.DefaultCandidate
-
Instantiate a default candidate.
- DefaultChannelAccessPolicy - Class in org.springframework.integration.security.channel
-
Creates the ConfigAttribute
s for secured channel
send and receive operations based on simple String values.
- DefaultChannelAccessPolicy(String, String) - Constructor for class org.springframework.integration.security.channel.DefaultChannelAccessPolicy
-
Create an access policy instance.
- DefaultChannelAccessPolicy(String[], String[]) - Constructor for class org.springframework.integration.security.channel.DefaultChannelAccessPolicy
-
Create an access policy instance.
- DefaultChannelMetricsContext(long) - Constructor for class org.springframework.integration.support.management.DefaultMessageChannelMetrics.DefaultChannelMetricsContext
-
- DefaultDatatypeChannelMessageConverter - Class in org.springframework.integration.support.converter
-
Default message converter for datatype channels.
- DefaultDatatypeChannelMessageConverter() - Constructor for class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
-
- DefaultDirectoryScanner - Class in org.springframework.integration.file
-
Default directory scanner and base class for other directory scanners.
- DefaultDirectoryScanner() - Constructor for class org.springframework.integration.file.DefaultDirectoryScanner
-
- DefaultErrorMessageStrategy - Class in org.springframework.integration.support
-
- DefaultErrorMessageStrategy() - Constructor for class org.springframework.integration.support.DefaultErrorMessageStrategy
-
- DefaultFileNameGenerator - Class in org.springframework.integration.file
-
Default implementation of the filename generator strategy.
- DefaultFileNameGenerator() - Constructor for class org.springframework.integration.file.DefaultFileNameGenerator
-
- DefaultFtpSessionFactory - Class in org.springframework.integration.ftp.session
-
Default implementation of FTP SessionFactory.
- DefaultFtpSessionFactory() - Constructor for class org.springframework.integration.ftp.session.DefaultFtpSessionFactory
-
- DefaultFtpsSessionFactory - Class in org.springframework.integration.ftp.session
-
SessionFactory for FTPS.
- DefaultFtpsSessionFactory() - Constructor for class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- DefaultHandlerMetricsContext(long) - Constructor for class org.springframework.integration.support.management.DefaultMessageHandlerMetrics.DefaultHandlerMetricsContext
-
- DefaultHeaderChannelRegistry - Class in org.springframework.integration.channel
-
Converts a channel to a name, retaining a reference to the channel keyed by the name.
- DefaultHeaderChannelRegistry() - Constructor for class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
Constructs a registry with the default delay for channel expiry.
- DefaultHeaderChannelRegistry(long) - Constructor for class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
Constructs a registry with the provided delay (milliseconds) for
channel expiry.
- DefaultHttpHeaderMapper - Class in org.springframework.integration.http.support
-
- DefaultHttpHeaderMapper() - Constructor for class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- DefaultInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
-
Parser for the <inbound-channel-adapter/> element.
- DefaultInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.DefaultInboundChannelAdapterParser
-
- DefaultJmsHeaderMapper - Class in org.springframework.integration.jms
-
- DefaultJmsHeaderMapper() - Constructor for class org.springframework.integration.jms.DefaultJmsHeaderMapper
-
- DefaultJpaOperations - Class in org.springframework.integration.jpa.core
-
Class similar to JPA template limited to the operations required for the JPA adapters/gateway
not using JpaTemplate as the class is deprecated since Spring 3.1
- DefaultJpaOperations() - Constructor for class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- DefaultLeaderEventPublisher - Class in org.springframework.integration.leader.event
-
- DefaultLeaderEventPublisher() - Constructor for class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
-
Instantiates a new leader event publisher.
- DefaultLeaderEventPublisher(ApplicationEventPublisher) - Constructor for class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
-
Instantiates a new leader event publisher.
- DefaultLockRegistry - Class in org.springframework.integration.support.locks
-
Default implementation of
LockRegistry
which uses Masked Hashcode algorithm to obtain locks.
- DefaultLockRegistry() - Constructor for class org.springframework.integration.support.locks.DefaultLockRegistry
-
Constructs a DefaultLockRegistry with the default
mask 0xFF with 256 locks.
- DefaultLockRegistry(int) - Constructor for class org.springframework.integration.support.locks.DefaultLockRegistry
-
Constructs a DefaultLockRegistry with the supplied
mask - the mask must have a value Math.pow(2, n) - 1 where n
is 1 to 31, creating a hash of Math.pow(2, n) locks.
- DefaultLockRepository - Class in org.springframework.integration.jdbc.lock
-
The default implementation of the
LockRepository
based on the
table from the script presented in the
org/springframework/integration/jdbc/schema-*.sql
.
- DefaultLockRepository(DataSource) - Constructor for class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Constructor that initializes the client id that will be associated for
all the locks persisted by the store instance to a random
UUID
.
- DefaultLockRepository(DataSource, String) - Constructor for class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Constructor that allows the user to specify a client id that will
be associated for all the locks persisted by the store instance.
- DefaultMailHeaderMapper - Class in org.springframework.integration.mail.support
-
- DefaultMailHeaderMapper() - Constructor for class org.springframework.integration.mail.support.DefaultMailHeaderMapper
-
- DefaultMBeanAttributeFilter - Class in org.springframework.integration.jmx
-
- DefaultMBeanAttributeFilter() - Constructor for class org.springframework.integration.jmx.DefaultMBeanAttributeFilter
-
- DefaultMBeanObjectConverter - Class in org.springframework.integration.jmx
-
- DefaultMBeanObjectConverter() - Constructor for class org.springframework.integration.jmx.DefaultMBeanObjectConverter
-
- DefaultMBeanObjectConverter(MBeanAttributeFilter) - Constructor for class org.springframework.integration.jmx.DefaultMBeanObjectConverter
-
- DefaultMessageBuilderFactory - Class in org.springframework.integration.support
-
- DefaultMessageBuilderFactory() - Constructor for class org.springframework.integration.support.DefaultMessageBuilderFactory
-
- DefaultMessageChannelMetrics - Class in org.springframework.integration.support.management
-
Default implementation; use the full constructor to customize the moving averages.
- DefaultMessageChannelMetrics() - Constructor for class org.springframework.integration.support.management.DefaultMessageChannelMetrics
-
- DefaultMessageChannelMetrics(String) - Constructor for class org.springframework.integration.support.management.DefaultMessageChannelMetrics
-
Construct an instance with default metrics with window=10, period=1 second,
lapsePeriod=1 minute
.
- DefaultMessageChannelMetrics(String, ExponentialMovingAverage, ExponentialMovingAverageRate, ExponentialMovingAverageRatio, ExponentialMovingAverageRate) - Constructor for class org.springframework.integration.support.management.DefaultMessageChannelMetrics
-
Construct an instance with the supplied metrics.
- DefaultMessageChannelMetrics.DefaultChannelMetricsContext - Class in org.springframework.integration.support.management
-
- DefaultMessageConverter - Class in org.springframework.integration.syslog
-
- DefaultMessageConverter() - Constructor for class org.springframework.integration.syslog.DefaultMessageConverter
-
- DefaultMessageHandlerMetrics - Class in org.springframework.integration.support.management
-
Default implementation; use the full constructor to customize the moving averages.
- DefaultMessageHandlerMetrics() - Constructor for class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
-
- DefaultMessageHandlerMetrics(String) - Constructor for class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
-
Construct an instance with the default moving average window (10).
- DefaultMessageHandlerMetrics(String, ExponentialMovingAverage) - Constructor for class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
-
Construct an instance with the supplied
ExponentialMovingAverage
calculating
the duration of processing by the message handler (and any downstream synchronous
endpoints).
- DefaultMessageHandlerMetrics.DefaultHandlerMetricsContext - Class in org.springframework.integration.support.management
-
- DefaultMessageSplitter - Class in org.springframework.integration.splitter
-
The default Message Splitter implementation.
- DefaultMessageSplitter() - Constructor for class org.springframework.integration.splitter.DefaultMessageSplitter
-
- DefaultMetricsFactory - Class in org.springframework.integration.support.management
-
Default implementation.
- DefaultMetricsFactory() - Constructor for class org.springframework.integration.support.management.DefaultMetricsFactory
-
- DefaultMqttPahoClientFactory - Class in org.springframework.integration.mqtt.core
-
Creates a default MqttClient
and a set of options as configured.
- DefaultMqttPahoClientFactory() - Constructor for class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
-
- DefaultMqttPahoClientFactory.Will - Class in org.springframework.integration.mqtt.core
-
- DefaultMultipartFileReader - Class in org.springframework.integration.http.multipart
-
- DefaultMultipartFileReader() - Constructor for class org.springframework.integration.http.multipart.DefaultMultipartFileReader
-
- DefaultOutboundChannelAdapterParser - Class in org.springframework.integration.config.xml
-
Parser for the <outbound-channel-adapter/> element.
- DefaultOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.DefaultOutboundChannelAdapterParser
-
- DefaultPahoMessageConverter - Class in org.springframework.integration.mqtt.support
-
Default implementation for mapping to/from Messages.
- DefaultPahoMessageConverter() - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter with default options (qos=0, retain=false, charset=UTF-8).
- DefaultPahoMessageConverter(int, boolean) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter to create outbound messages with the supplied default qos and retain settings and
a UTF-8 charset for converting outbound String payloads to
byte[]
and inbound
byte[]
to String (unless
payloadAdBytes
is true).
- DefaultPahoMessageConverter(String) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter with default options (qos=0, retain=false) and
the supplied charset.
- DefaultPahoMessageConverter(int, boolean, String) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter to create outbound messages with the supplied default qos and retain settings and
the supplied charset.
- DefaultRouterParser - Class in org.springframework.integration.config.xml
-
Parser for the <router/> element.
- DefaultRouterParser() - Constructor for class org.springframework.integration.config.xml.DefaultRouterParser
-
- defaults() - Static method in class org.springframework.integration.context.IntegrationProperties
-
- DefaultScriptExecutor - Class in org.springframework.integration.scripting.jsr223
-
- DefaultScriptExecutor(String) - Constructor for class org.springframework.integration.scripting.jsr223.DefaultScriptExecutor
-
Create a DefaultScriptExecutor for the specified language name (JSR233 alias).
- DefaultScriptVariableGenerator - Class in org.springframework.integration.scripting
-
- DefaultScriptVariableGenerator() - Constructor for class org.springframework.integration.scripting.DefaultScriptVariableGenerator
-
- DefaultScriptVariableGenerator(Map<String, Object>) - Constructor for class org.springframework.integration.scripting.DefaultScriptVariableGenerator
-
- DefaultSessionFactoryLocator<F> - Class in org.springframework.integration.file.remote.session
-
The default implementation of
SessionFactoryLocator
using a simple map lookup
and an optional default to fall back on.
- DefaultSessionFactoryLocator(Map<Object, SessionFactory<F>>) - Constructor for class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
-
- DefaultSessionFactoryLocator(Map<Object, SessionFactory<F>>, SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
-
- DefaultSftpSessionFactory - Class in org.springframework.integration.sftp.session
-
- DefaultSftpSessionFactory() - Constructor for class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
- DefaultSftpSessionFactory(boolean) - Constructor for class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
- DefaultSftpSessionFactory(JSch, boolean) - Constructor for class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Intended for use in tests so the jsch can be mocked.
- DefaultSoapHeaderMapper - Class in org.springframework.integration.ws
-
A
HeaderMapper
implementation for mapping to and from a SoapHeader.
- DefaultSoapHeaderMapper() - Constructor for class org.springframework.integration.ws.DefaultSoapHeaderMapper
-
- DefaultTcpNetSocketFactorySupport - Class in org.springframework.integration.ip.tcp.connection
-
- DefaultTcpNetSocketFactorySupport() - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSocketFactorySupport
-
- DefaultTcpNetSSLSocketFactorySupport - Class in org.springframework.integration.ip.tcp.connection
-
- DefaultTcpNetSSLSocketFactorySupport(TcpSSLContextSupport) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSSLSocketFactorySupport
-
- DefaultTcpNioConnectionSupport - Class in org.springframework.integration.ip.tcp.connection
-
- DefaultTcpNioConnectionSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNioConnectionSupport
-
- DefaultTcpNioSSLConnectionSupport - Class in org.springframework.integration.ip.tcp.connection
-
- DefaultTcpNioSSLConnectionSupport(TcpSSLContextSupport) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNioSSLConnectionSupport
-
- DefaultTcpSocketSupport - Class in org.springframework.integration.ip.tcp.connection
-
- DefaultTcpSocketSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpSocketSupport
-
- DefaultTcpSSLContextSupport - Class in org.springframework.integration.ip.tcp.connection
-
Default implementation of
TcpSSLContextSupport
; uses a
'TLS' (by default)
SSLContext
, initialized with 'JKS'
keystores, managed by 'SunX509' Key and Trust managers.
- DefaultTcpSSLContextSupport(String, String, String, String) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpSSLContextSupport
-
Prepares for the creation of an SSLContext using the supplied
key/trust stores and passwords.
- DefaultTransactionSynchronizationFactory - Class in org.springframework.integration.transaction
-
- DefaultTransactionSynchronizationFactory(TransactionSynchronizationProcessor) - Constructor for class org.springframework.integration.transaction.DefaultTransactionSynchronizationFactory
-
- DefaultXmlPayloadConverter - Class in org.springframework.integration.xml
-
- DefaultXmlPayloadConverter() - Constructor for class org.springframework.integration.xml.DefaultXmlPayloadConverter
-
- DefaultXmlPayloadConverter(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.DefaultXmlPayloadConverter
-
- DefaultXmppHeaderMapper - Class in org.springframework.integration.xmpp.support
-
- DefaultXmppHeaderMapper() - Constructor for class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
-
- defineRequestResponseScenario() - Method in class org.springframework.integration.test.support.SingleRequestResponseScenarioTests
-
- defineRequestResponseScenarios() - Method in class org.springframework.integration.test.support.AbstractRequestResponseScenarioTests
-
Implement this method to define RequestResponse scenarios
- defineRequestResponseScenarios() - Method in class org.springframework.integration.test.support.SingleRequestResponseScenarioTests
-
- DelayerParser - Class in org.springframework.integration.config.xml
-
Parser for the <delayer> element.
- DelayerParser() - Constructor for class org.springframework.integration.config.xml.DelayerParser
-
- DelayHandler - Class in org.springframework.integration.handler
-
A
MessageHandler
that is capable of delaying the continuation of a
Message flow based on the result of evaluation
delayExpression
on an inbound
Message
or a default delay value configured on this handler.
- DelayHandler(String) - Constructor for class org.springframework.integration.handler.DelayHandler
-
- DelayHandler(String, TaskScheduler) - Constructor for class org.springframework.integration.handler.DelayHandler
-
Create a DelayHandler with the given default delay.
- DelayHandler.DelayedMessageWrapper - Class in org.springframework.integration.handler
-
- DelayHandlerManagement - Interface in org.springframework.integration.handler
-
- delayRead(Selector, long, SelectionKey) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- delegate - Variable in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
-
- DelegatingSessionFactory<F> - Class in org.springframework.integration.file.remote.session
-
- DelegatingSessionFactory(Map<Object, SessionFactory<F>>, SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.session.DelegatingSessionFactory
-
- DelegatingSessionFactory(SessionFactoryLocator<F>) - Constructor for class org.springframework.integration.file.remote.session.DelegatingSessionFactory
-
Construct an instance using the supplied factory.
- delete(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
- delete(String) - Method in interface org.springframework.integration.jdbc.lock.LockRepository
-
- delete(Object) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- delete(Object) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
- DELETE_ALL_QUERY_STRING - Static variable in class org.springframework.integration.jpa.support.JpaUtils
-
- deleteInBatch(Iterable<?>) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- deleteInBatch(Iterable<?>) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
- deleteMessages(Message[]) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Deletes the given messages from this receiver's folder.
- deleteMessages(Message[]) - Method in class org.springframework.integration.mail.Pop3MailReceiver
-
Deletes the given messages from this receiver's folder, and closes it to expunge deleted messages.
- deliveryComplete(IMqttDeliveryToken) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
- deliveryComplete(IMqttDeliveryToken) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
- DerbyChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
-
- DerbyChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.DerbyChannelMessageStoreQueryProvider
-
- describeTo(Description) - Method in class org.springframework.integration.test.matcher.EqualsResultMatcher
-
- describeTo(Description) - Method in class org.springframework.integration.test.matcher.EventuallyMatcher
-
- describeTo(Description) - Method in class org.springframework.integration.test.matcher.HeaderMatcher
- describeTo(Description) - Method in class org.springframework.integration.test.matcher.MapContentMatchers
- describeTo(Description) - Method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
-
- describeTo(Description) - Method in class org.springframework.integration.test.matcher.PayloadMatcher
- deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
-
- deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
Reads the header from the stream and then reads the provided length
from the stream and returns the data in a byte[].
- deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
-
- deserialize(ByteArrayInputStream) - Method in class org.springframework.integration.support.converter.WhiteListDeserializingConverter
-
- deserialize(InputStream) - Method in class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
-
- DESTINATION - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
-
- destroy() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- destroy() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
-
- destroy() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
-
Remove (close) any unused sessions in the pool.
- destroy() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- destroy() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
- destroy() - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- destroy() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- destroy() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
-
- destroy() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- destroy() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- destroy() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- destroy() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
- destroy() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
-
- destroy() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
-
- destroy() - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
-
- destroy() - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
-
- destroyInstance(AbstractAmqpChannel) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- destroyInstance(AbstractJmsChannel) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- detectAlias(String) - Static method in class org.springframework.integration.jpa.support.JpaUtils
-
Resolves the alias for the entity to be retrieved from the given JPA query.
- detectHandlerMethods(Object) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
-
- determinePayload(Throwable, AttributeAccessor) - Method in class org.springframework.integration.support.ErrorMessagePublisher
-
- determineRetryState(Message<?>) - Method in interface org.springframework.integration.handler.advice.RetryStateGenerator
-
- determineRetryState(Message<?>) - Method in class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
-
- determineTargetChannels(Message<?>) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
- determineTargetChannels(Message<?>) - Method in class org.springframework.integration.router.AbstractMessageRouter
-
Subclasses must implement this method to return a Collection of zero or more
MessageChannels to which the given Message should be routed.
- determineTargetChannels(Message<?>) - Method in class org.springframework.integration.router.RecipientListRouter
-
- DirectChannel - Class in org.springframework.integration.channel
-
A channel that invokes a single subscriber for each sent Message.
- DirectChannel() - Constructor for class org.springframework.integration.channel.DirectChannel
-
- DirectChannel(LoadBalancingStrategy) - Constructor for class org.springframework.integration.channel.DirectChannel
-
- DirectMessageReceivingMessageSource - Class in org.springframework.integration.twitter.inbound
-
This class handles support for receiving DMs (direct messages) using Twitter.
- DirectMessageReceivingMessageSource(Twitter, String) - Constructor for class org.springframework.integration.twitter.inbound.DirectMessageReceivingMessageSource
-
- DirectMessageSendingMessageHandler - Class in org.springframework.integration.twitter.outbound
-
Simple adapter to support sending outbound direct messages ("DM"s) using Twitter.
- DirectMessageSendingMessageHandler(Twitter) - Constructor for class org.springframework.integration.twitter.outbound.DirectMessageSendingMessageHandler
-
- DirectoryScanner - Interface in org.springframework.integration.file
-
Strategy for scanning directories.
- dirty() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- DiscardingMessageHandler - Interface in org.springframework.integration.handler
-
Classes implementing this interface are capable of discarding messages.
- DiscardingMessageHandlerNode - Class in org.springframework.integration.support.management.graph
-
Represents an endpoint that has a discard channel.
- DiscardingMessageHandlerNode(int, String, MessageHandler, String, String, String) - Constructor for class org.springframework.integration.support.management.graph.DiscardingMessageHandlerNode
-
- disconnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- disconnect(StompSessionHandler) - Method in interface org.springframework.integration.stomp.StompSessionManager
-
- dispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
- dispatch(Message<?>) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
-
- dispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
-
- dispatcher - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
-
- DM_TARGET_USER_ID - Static variable in class org.springframework.integration.twitter.core.TwitterHeaders
-
- doAccept(Selector, ServerSocketChannel, long) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- doAccept(Selector, ServerSocketChannel, long) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
- doAddMessage(Message<?>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- doBegin(Object, TransactionDefinition) - Method in class org.springframework.integration.transaction.PseudoTransactionManager
-
- doChmod(RemoteFileTemplate<F>, String, int) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Set the mode on the remote file after transfer; the default implementation does
nothing.
- doChmod(RemoteFileTemplate<F>, String, int) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
Set the mode on the remote file after transfer; the default implementation does
nothing.
- doChmod(RemoteFileTemplate<ChannelSftp.LsEntry>, String, int) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
-
- doChmod(RemoteFileTemplate<ChannelSftp.LsEntry>, String, int) - Method in class org.springframework.integration.sftp.outbound.SftpMessageHandler
-
- doCommit(DefaultTransactionStatus) - Method in class org.springframework.integration.transaction.PseudoTransactionManager
-
- doConnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
-
- doConnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.Reactor2TcpStompSessionManager
-
- doConnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.WebSocketStompSessionManager
-
- doCreateEndpoint(MessageHandler, MessageChannel, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- DOCUMENT_LIST - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
-
- doDecode(Kryo, Input, Class<T>) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
Subclasses implement this method to decode with Kryo.
- doDecode(Kryo, Input, Class<T>) - Method in class org.springframework.integration.codec.kryo.PojoCodec
-
- doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
-
- doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
-
Reads the data in the inputStream to a byte[].
- doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
-
- doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArraySingleTerminatorSerializer
-
Reads the data in the inputStream to a byte[].
- doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
-
Reads the data in the inputStream to a byte[].
- doEncode(Kryo, Object, Output) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
Subclasses implement this method to encode with Kryo.
- doEncode(Kryo, Object, Output) - Method in class org.springframework.integration.codec.kryo.PojoCodec
-
- doExecuteWithClient(ClientCallback<FTPClient, T>) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
-
- doExecuteWithClient(ClientCallback<ChannelSftp, T>) - Method in class org.springframework.integration.sftp.session.SftpRemoteFileTemplate
-
- doExtractData(WebServiceMessage) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.ResponseMessageExtractor
-
- doGetTransaction() - Method in class org.springframework.integration.transaction.PseudoTransactionManager
-
- doHandle(String, Message<?>, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- doHandle(String, Message<?>, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
-
- doHandle(String, Message<?>, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
-
- doHandleRequest(HttpServletRequest, HttpServletResponse) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Handles the HTTP request by generating a Message and sending it to the request channel.
- doHandleRequestMessage(Message<?>) - Method in class org.springframework.integration.filter.MessageFilter
-
- doHandleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
-
- doInit() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- doInit() - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
- doInit() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
- doInit() - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- doInit() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- doInit() - Method in class org.springframework.integration.filter.MessageFilter
-
- doInit() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
- doInit() - Method in class org.springframework.integration.handler.DelayHandler
-
- doInit() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
-
- doInit() - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
- doInit() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- doInit() - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
- doInit() - Method in class org.springframework.integration.jdbc.StoredProcOutboundGateway
-
- doInit() - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- doInit() - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
-
- doInit() - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
-
- doInit() - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
-
- doInit() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
-
- doInit() - Method in class org.springframework.integration.transformer.ContentEnricher
-
Initializes the Content Enricher.
- doInit() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
-
- doInit() - Method in class org.springframework.integration.twitter.outbound.TwitterSearchOutboundGateway
-
- doInit() - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- doInit() - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
-
- doInParser(JsonInboundMessageMapper, String) - Method in interface org.springframework.integration.support.json.JsonInboundMessageMapper.JsonMessageParser
-
- doInSession(Session<F>, Message<?>) - Method in interface org.springframework.integration.file.remote.MessageSessionCallback
-
Called within the context of a session and requestMessage.
- doInSession(Session<F>) - Method in interface org.springframework.integration.file.remote.SessionCallback
-
Called within the context of a session.
- doInSession(Session<F>) - Method in class org.springframework.integration.file.remote.SessionCallbackWithoutResult
-
- doInSessionWithoutResult(Session<F>) - Method in class org.springframework.integration.file.remote.SessionCallbackWithoutResult
-
Called within the context of a session.
- doInvoke(MethodInvocation, boolean) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- doInvoke(MethodInvocation, Message<?>) - Method in class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
-
- doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
-
Subclasses implement this method to apply behavior to the
MessageHandler
.
- doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
- doInvoke(MethodInvocation, Message<?>) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
-
- doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
-
- doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- doInvoke(MessageContext) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
-
- doInvoke(MessageContext) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
-
- doInvoke(MessageContext) - Method in class org.springframework.integration.ws.SimpleWebServiceInboundGateway
-
- doInvokeAdvisedRequestHandler(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
- doInvokeAdvisedRequestHandler(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
-
- doListKeys(String) - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
-
- doListKeys(String) - Method in class org.springframework.integration.redis.store.RedisMessageStore
-
- doListKeys(String) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- DOM_RESULT - Static variable in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
-
- DomResultFactory - Class in org.springframework.integration.xml.result
-
- DomResultFactory() - Constructor for class org.springframework.integration.xml.result.DomResultFactory
-
- DomResultFactory(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.result.DomResultFactory
-
- DomSourceFactory - Class in org.springframework.integration.xml.source
-
- DomSourceFactory() - Constructor for class org.springframework.integration.xml.source.DomSourceFactory
-
- DomSourceFactory(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.source.DomSourceFactory
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
-
Subclasses must implement this method to parse the adapter element.
- doParse(BeanDefinitionBuilder, Element, BeanMetadataElement, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractCorrelatingMessageHandlerParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.config.xml.AbstractPollingInboundChannelAdapterParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.SelectorChainParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.SelectorParser
-
- doParse(Element, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.SpelFunctionParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.event.config.EventInboundChannelAdapterParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.gemfire.config.xml.GemfireCqInboundChannelAdapterParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.gemfire.config.xml.GemfireInboundChannelAdapterParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.ip.config.TcpConnectionEventInboundChannelAdapterParser
-
Deprecated.
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.ip.config.TcpInboundChannelAdapterParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.ip.config.UdpInboundChannelAdapterParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.mqtt.config.xml.MqttMessageDrivenChannelAdapterParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.redis.config.RedisInboundChannelAdapterParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.redis.config.RedisQueueInboundChannelAdapterParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.scripting.config.AbstractScriptParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.security.config.SecuredChannelsParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.stomp.config.StompInboundChannelAdapterParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.syslog.config.SyslogInboundChannelAdapterParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.websocket.config.ClientWebSocketContainerParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.websocket.config.ServerWebSocketContainerParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.websocket.config.WebSocketInboundChannelAdapterParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.XPathExpressionParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xmpp.config.XmppConnectionParser
-
- doParseAndRegisterConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
-
Override this method to control the registration process and return the bean name.
- doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractRouterParser
-
- doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ErrorMessageExceptionTypeRouterParser
-
- doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.HeaderValueRouterParser
-
- doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PayloadTypeRouterParser
-
- doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.RecipientListRouterParser
-
- doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.xml.config.XPathRouterParser
-
- doPoll(SqlParameterSource) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
- doPoll() - Method in class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
-
- doPoll(ParameterSource, int, int) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- doPollForMessage(String) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
This method executes a call to the DB to get the oldest Message in the MessageGroup
Override this method if need to.
- doPollForMessage(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
This method executes a call to the DB to get the oldest Message in the
MessageGroup which in the context of the
JdbcChannelMessageStore
means the channel identifier.
- doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
-
Subclasses may add to the bean definition by overriding this method.
- doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.ip.config.TcpInboundGatewayParser
-
- doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.redis.config.RedisQueueInboundGatewayParser
-
- doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.rmi.config.RmiInboundGatewayParser
-
- doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
-
- doReceive() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- doReceive(long) - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
Subclasses must implement this method.
- doReceive(long) - Method in class org.springframework.integration.channel.PriorityChannel
-
- doReceive(long) - Method in class org.springframework.integration.channel.QueueChannel
-
- doReceive() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
-
Subclasses must implement this method.
- doReceive() - Method in class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
-
- doReceive() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
-
- doReceive() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
- doReceive() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
Polls from the file source.
- doReceive() - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
-
Retrieves the JMX attribute value.
- doReceive() - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
-
Provides the mapped tree object
- doReceive() - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
-
- doReceive() - Method in class org.springframework.integration.scripting.ScriptExecutingMessageSource
-
- doRemove(Object) - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
-
- doRemove(Object) - Method in class org.springframework.integration.redis.store.RedisMessageStore
-
- doRemove(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- doRetrieve(Object) - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
-
- doRetrieve(Object) - Method in class org.springframework.integration.redis.store.RedisMessageStore
-
- doRetrieve(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- doRollback(DefaultTransactionStatus) - Method in class org.springframework.integration.transaction.PseudoTransactionManager
-
- doSend(Message<?>, long) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
- doSend(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Subclasses must implement this method.
- doSend(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
-
- doSend(Message<?>, long) - Method in class org.springframework.integration.channel.PriorityChannel
-
- doSend(Message<?>, long) - Method in class org.springframework.integration.channel.QueueChannel
-
- doSend(DatagramPacket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- doSend(Message<?>, long) - Method in class org.springframework.integration.jms.AbstractJmsChannel
-
- doSend(Message<?>, long) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- doSetFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
- doSetRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- doStart() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- doStart() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
- doStart() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- doStart() - Method in class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
-
- doStart() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
Subclasses must implement this method with the start behavior.
- doStart() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- doStart() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
-
- doStart() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
Takes no action by default.
- doStart() - Method in class org.springframework.integration.endpoint.PollingConsumer
-
- doStart() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- doStart() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- doStart() - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
-
- doStart() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
-
- doStart() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- doStart() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- doStart() - Method in class org.springframework.integration.gemfire.inbound.CacheListeningMessageProducer
-
- doStart() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
Protected by lifecycleLock
- doStart() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- doStart() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- doStart() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- doStart() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- doStart() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- doStart() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
Registers the notification listener with the specified ObjectNames.
- doStart() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
- doStart() - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
- doStart() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
- doStart() - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
- doStart() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- doStart() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- doStart() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- doStart() - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
-
- doStart() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
-
- doStart() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
-
- doStart() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
- doStart() - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
-
- doStart() - Method in class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
-
- doStop() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- doStop() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
- doStop() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
- doStop() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- doStop() - Method in class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
-
- doStop(Runnable) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
Stop the component and invoke callback.
- doStop() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
Subclasses must implement this method with the stop behavior.
- doStop() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- doStop() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
-
- doStop() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
Takes no action by default.
- doStop() - Method in class org.springframework.integration.endpoint.PollingConsumer
-
- doStop() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- doStop() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- doStop() - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
-
- doStop() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
-
- doStop() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- doStop() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- doStop() - Method in class org.springframework.integration.gemfire.inbound.CacheListeningMessageProducer
-
- doStop() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- doStop() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- doStop() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- doStop() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- doStop() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- doStop() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- doStop() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- doStop() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
Unregisters the notification listener.
- doStop() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
- doStop() - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
-
- doStop() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
- doStop() - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
-
- doStop() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- doStop(Runnable) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- doStop() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
-
- doStop(Runnable) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- doStop() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- doStop() - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
-
- doStop() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
-
- doStop() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
-
- doStop() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
-
- doStop() - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
-
- doStop() - Method in class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
-
- doStore(Object, Object) - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
-
- doStore(Object, Object) - Method in class org.springframework.integration.redis.store.RedisMessageStore
-
- doStore(Object, Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- doTransform(Message<?>) - Method in class org.springframework.integration.json.JsonToObjectTransformer
-
- doTransform(Message<?>) - Method in class org.springframework.integration.json.ObjectToJsonTransformer
-
- doTransform(Message) - Method in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
-
- doTransform(Message) - Method in class org.springframework.integration.mail.transformer.MailToStringTransformer
-
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractPayloadTransformer
-
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractTransformer
-
Subclasses must implement this method to provide the transformation
logic.
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.ClaimCheckInTransformer
-
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
-
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.DecodingTransformer
-
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.StreamTransformer
-
- doTransform(Message<?>) - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
-
- doTransform(Message<?>) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
-
- doTransform(Message<?>) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
- doWhileLocked() - Method in class org.springframework.integration.util.WhileLockedProcessor
-
- doWithClient(C) - Method in interface org.springframework.integration.file.remote.ClientCallback
-
Called within the context of a
Session
.
- doWithClient(C) - Method in class org.springframework.integration.file.remote.ClientCallbackWithoutResult
-
- doWithClientWithoutResult(C) - Method in class org.springframework.integration.file.remote.ClientCallbackWithoutResult
-
Called within the context of a session.
- doWithInputStream(InputStream) - Method in interface org.springframework.integration.file.remote.InputStreamCallback
-
Called with the InputStream for the remote file.
- doWithMessage(WebServiceMessage) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.RequestMessageCallback
-
- doWithMessageInternal(WebServiceMessage, Object) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.RequestMessageCallback
-
- doWrite(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
Method that actually does the write.
- drainTo(Collection<? super Message<?>>) - Method in class org.springframework.integration.store.MessageGroupQueue
-
- drainTo(Collection<? super Message<?>>, int) - Method in class org.springframework.integration.store.MessageGroupQueue
-
- DUPLICATE - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
-
- DUPLICATE_MESSAGE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
-
- DUPS_OK_ACKNOWLEDGE - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
-
- DUPS_OK_ACKNOWLEDGE_STRING - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
-
- duration - Variable in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
-
- DynamicExpression - Class in org.springframework.integration.expression
-
An implementation of
Expression
that delegates to an
ExpressionSource
for resolving the actual Expression instance per-invocation at runtime.
- DynamicExpression(String, ExpressionSource) - Constructor for class org.springframework.integration.expression.DynamicExpression
-
- DynamicJmsTemplate - Class in org.springframework.integration.jms
-
- DynamicJmsTemplate() - Constructor for class org.springframework.integration.jms.DynamicJmsTemplate
-
- DynamicPeriodicTrigger - Class in org.springframework.integration.util
-
This is a dynamically changeable
Trigger
.
- DynamicPeriodicTrigger(long) - Constructor for class org.springframework.integration.util.DynamicPeriodicTrigger
-
Create a trigger with the given period in milliseconds.
- DynamicPeriodicTrigger(long, TimeUnit) - Constructor for class org.springframework.integration.util.DynamicPeriodicTrigger
-
Create a trigger with the given period and time unit.
- EnableIntegration - Annotation Type in org.springframework.integration.config
-
The main configuration annotation to enable Spring Integration infrastructure:
- Registers some built-in beans;
- Adds several BeanFactoryPostProcessor
s;
- Adds several BeanPostProcessor
s;
- Adds annotations processors.
- EnableIntegrationGraphController - Annotation Type in org.springframework.integration.http.config
-
- EnableIntegrationManagement - Annotation Type in org.springframework.integration.config
-
Enables default configuring of management in Spring Integration components in an existing application.
- EnableIntegrationMBeanExport - Annotation Type in org.springframework.integration.jmx.config
-
Enables default exporting for Spring Integration components in an existing application, as
well as well all @ManagedResource
annotated beans.
- enableManualListenerRegistration() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
Set whether to automatically (default) or manually add a
TcpListener
to the
connections created by this factory.
- enableManualListenerRegistration() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- enableManualListenerRegistration() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
Set whether or not automatic or manual registration of the
TcpListener
is to be
used.
- EnableMessageHistory - Annotation Type in org.springframework.integration.config
-
- EnablePublisher - Annotation Type in org.springframework.integration.config
-
- encode(Object, OutputStream) - Method in interface org.springframework.integration.codec.Codec
-
Encode (encode) an object to an OutputStream
- encode(Object) - Method in interface org.springframework.integration.codec.Codec
-
Encode an object to a byte array
- encode(Object, OutputStream) - Method in class org.springframework.integration.codec.CompositeCodec
-
- encode(Object) - Method in class org.springframework.integration.codec.CompositeCodec
-
- encode(Object, OutputStream) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
- encode(Object) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
- encode(Map<String, Object>, byte[]) - Method in class org.springframework.integration.websocket.support.ClientStompEncoder
-
- EncodingPayloadTransformer<T> - Class in org.springframework.integration.transformer
-
- EncodingPayloadTransformer(Codec) - Constructor for class org.springframework.integration.transformer.EncodingPayloadTransformer
-
- endpointInit() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
-
Subclasses can override to perform any additional initialization.
- endpointInit() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- EndpointNode - Class in org.springframework.integration.support.management.graph
-
Base class for all endpoints.
- EndpointNode(int, String, Object, String, IntegrationNode.Stats) - Constructor for class org.springframework.integration.support.management.graph.EndpointNode
-
- ENDPOINTS_NO_AUTO_STARTUP - Static variable in class org.springframework.integration.context.IntegrationProperties
-
- EnhancedErrorMessage - Class in org.springframework.integration.message
-
- EnhancedErrorMessage(Throwable, Message<?>) - Constructor for class org.springframework.integration.message.EnhancedErrorMessage
-
Deprecated.
- EnhancedErrorMessage(Throwable, MessageHeaders, Message<?>) - Constructor for class org.springframework.integration.message.EnhancedErrorMessage
-
Deprecated.
- EnhancedErrorMessage(Throwable, Map<String, Object>, Message<?>) - Constructor for class org.springframework.integration.message.EnhancedErrorMessage
-
Deprecated.
- enhanceNameWithSubDirectory(F, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- enhanceNameWithSubDirectory(FTPFile, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
-
- enhanceNameWithSubDirectory(ChannelSftp.LsEntry, String) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
-
- EnricherParser - Class in org.springframework.integration.config.xml
-
Parser for the 'enricher' element.
- EnricherParser() - Constructor for class org.springframework.integration.config.xml.EnricherParser
-
- Entry() - Constructor for class org.springframework.integration.history.MessageHistory.Entry
-
- entrySet() - Method in class org.springframework.integration.expression.ExpressionEvalMap
-
- equals(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
-
- equals(Object) - Method in class org.springframework.integration.handler.DelayHandler.DelayedMessageWrapper
-
- equals(Object) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- equals(Object) - Method in class org.springframework.integration.json.JsonPropertyAccessor.ToStringFriendlyJsonNode
-
- equals(Object) - Method in class org.springframework.integration.support.MutableMessage
-
- equals(Object) - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
-
- equals(Object) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
-
- equalsResult(EqualsResultMatcher.Evaluator<U>) - Static method in class org.springframework.integration.test.matcher.EqualsResultMatcher
-
- EqualsResultMatcher<U> - Class in org.springframework.integration.test.matcher
-
A matcher that evaluates against the result of invoking a function,
wrapped by the
EqualsResultMatcher.Evaluator
The goal is to defer the computation until the matcher needs to be actually evaluated.
- EqualsResultMatcher(EqualsResultMatcher.Evaluator<U>) - Constructor for class org.springframework.integration.test.matcher.EqualsResultMatcher
-
- EqualsResultMatcher.Evaluator<U> - Interface in org.springframework.integration.test.matcher
-
- ERROR_CHANNEL_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
-
- ErrorCapableCompositeMessageHandlerNode - Class in org.springframework.integration.support.management.graph
-
Represents a composite message handler that can emit error messages
(pollable endpoint).
- ErrorCapableCompositeMessageHandlerNode(int, String, CompositeMessageHandler, String, String, String, List<CompositeMessageHandlerNode.InnerHandler>) - Constructor for class org.springframework.integration.support.management.graph.ErrorCapableCompositeMessageHandlerNode
-
- ErrorCapableDiscardingMessageHandlerNode - Class in org.springframework.integration.support.management.graph
-
Represents an endpoint that has a discard channel and can emit errors
(pollable endpoint).
- ErrorCapableDiscardingMessageHandlerNode(int, String, MessageHandler, String, String, String, String) - Constructor for class org.springframework.integration.support.management.graph.ErrorCapableDiscardingMessageHandlerNode
-
- ErrorCapableEndpointNode - Class in org.springframework.integration.support.management.graph
-
Represents nodes that can natively handle errors.
- ErrorCapableEndpointNode(int, String, Object, String, String, IntegrationNode.Stats) - Constructor for class org.springframework.integration.support.management.graph.ErrorCapableEndpointNode
-
- ErrorCapableMessageHandlerNode - Class in org.springframework.integration.support.management.graph
-
Represents a message handler that can produce errors (pollable).
- ErrorCapableMessageHandlerNode(int, String, MessageHandler, String, String, String) - Constructor for class org.springframework.integration.support.management.graph.ErrorCapableMessageHandlerNode
-
- ErrorCapableNode - Interface in org.springframework.integration.support.management.graph
-
Nodes implementing this interface are capable of emitting errors.
- ErrorCapableRoutingNode - Class in org.springframework.integration.support.management.graph
-
Represents an endpoint that can route to multiple channels and can emit errors
(pollable endpoint).
- ErrorCapableRoutingNode(int, String, MessageHandler, String, String, String, Collection<String>) - Constructor for class org.springframework.integration.support.management.graph.ErrorCapableRoutingNode
-
- errorCount - Variable in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
-
- ErrorHandlingTaskExecutor - Class in org.springframework.integration.util
-
A
TaskExecutor
implementation that wraps an existing Executor
instance in order to catch any exceptions.
- ErrorHandlingTaskExecutor(Executor, ErrorHandler) - Constructor for class org.springframework.integration.util.ErrorHandlingTaskExecutor
-
- ErrorMessageExceptionTypeRouter - Class in org.springframework.integration.router
-
A Message Router that resolves the target
MessageChannel
for
messages whose payload is an Exception.
- ErrorMessageExceptionTypeRouter() - Constructor for class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
-
- ErrorMessageExceptionTypeRouterParser - Class in org.springframework.integration.config.xml
-
Parser for the <exception-type-router/> element.
- ErrorMessageExceptionTypeRouterParser() - Constructor for class org.springframework.integration.config.xml.ErrorMessageExceptionTypeRouterParser
-
- ErrorMessageJacksonDeserializer - Class in org.springframework.integration.support.json
-
- ErrorMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.ErrorMessageJacksonDeserializer
-
- ErrorMessagePublisher - Class in org.springframework.integration.support
-
The component which can be used as general purpose of errors publishing.
- ErrorMessagePublisher() - Constructor for class org.springframework.integration.support.ErrorMessagePublisher
-
- ErrorMessageSendingRecoverer - Class in org.springframework.integration.handler.advice
-
A
RecoveryCallback
that sends the final throwable as an
ErrorMessage
after
retry exhaustion.
- ErrorMessageSendingRecoverer() - Constructor for class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
-
Construct instance with the default errorChannel
to publish recovery error message.
- ErrorMessageSendingRecoverer(MessageChannel) - Constructor for class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
-
Construct instance based on the provided message channel.
- ErrorMessageSendingRecoverer(MessageChannel, ErrorMessageStrategy) - Constructor for class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
-
- ErrorMessageSendingRecoverer.RetryExceptionNotAvailableException - Exception in org.springframework.integration.handler.advice
-
- ErrorMessageStrategy - Interface in org.springframework.integration.support
-
- ErrorMessageUtils - Class in org.springframework.integration.support
-
Utilities for building error messages.
- ERRORS - Static variable in class org.springframework.integration.syslog.SyslogHeaders
-
- escapeRegexSpecials(String) - Static method in class org.springframework.integration.ip.util.RegexUtils
-
Escapes (precedes with \) any characters in the parameter in the set
- ETAG - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- ETX - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
-
- evaluate(Expression) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ComponentsEvaluationCallback
-
- evaluate(Expression) - Method in interface org.springframework.integration.expression.ExpressionEvalMap.EvaluationCallback
-
- evaluate(Object, String, Predicate...) - Static method in class org.springframework.integration.json.JsonPathUtils
-
- evaluate() - Method in interface org.springframework.integration.test.matcher.EqualsResultMatcher.Evaluator
-
- evaluate(Object, String, Object...) - Static method in class org.springframework.integration.xml.xpath.XPathUtils
-
Utility method to evaluate an xpath on the provided object.
- evaluateExpression(Expression, Message<?>, Class<T>) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- evaluateExpression(String, Object) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- evaluateExpression(String, Object, Class<T>) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- evaluateExpression(Expression, Object) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- evaluateExpression(Expression, Class<T>) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- evaluateExpression(Expression) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- evaluateExpression(Expression, Object, Class<T>) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- evaluatePayloadExpression(Object) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
-
- evaluateXPath(XPathExpression, Node) - Method in enum org.springframework.integration.xml.xpath.XPathEvaluationType
-
- EventDrivenConsumer - Class in org.springframework.integration.endpoint
-
- EventDrivenConsumer(SubscribableChannel, MessageHandler) - Constructor for class org.springframework.integration.endpoint.EventDrivenConsumer
-
- EventInboundChannelAdapterParser - Class in org.springframework.integration.event.config
-
- EventInboundChannelAdapterParser() - Constructor for class org.springframework.integration.event.config.EventInboundChannelAdapterParser
-
- EventNamespaceHandler - Class in org.springframework.integration.event.config
-
Namespace handler for Spring Integration's 'event' namespace.
- EventNamespaceHandler() - Constructor for class org.springframework.integration.event.config.EventNamespaceHandler
-
- EventOutboundChannelAdapterParser - Class in org.springframework.integration.event.config
-
- EventOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.event.config.EventOutboundChannelAdapterParser
-
- EventType - Enum in org.springframework.integration.gemfire.inbound
-
Enumeration of GemFire event types.
- eventually(int, int, Matcher<U>) - Static method in class org.springframework.integration.test.matcher.EventuallyMatcher
-
- eventually(Matcher<U>) - Static method in class org.springframework.integration.test.matcher.EventuallyMatcher
-
- EventuallyMatcher<U> - Class in org.springframework.integration.test.matcher
-
A matcher that will evaluate another matcher repeatedly until it matches, or fail after some number of attempts.
- EventuallyMatcher(Matcher<U>) - Constructor for class org.springframework.integration.test.matcher.EventuallyMatcher
-
- EventuallyMatcher(Matcher<U>, int, int) - Constructor for class org.springframework.integration.test.matcher.EventuallyMatcher
-
- exchange(Message<?>) - Method in interface org.springframework.integration.gateway.RequestReplyExchanger
-
- exchange(Message<?>) - Method in class org.springframework.integration.rmi.RmiInboundGateway
-
- execute(SessionCallback<F, T>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Execute the callback's doInSession method after obtaining a session.
- execute(SessionCallback<F, T>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- execute() - Method in interface org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice.ExecutionCallback
-
Call this for a normal invocation.proceed().
- execute(MessageGroupStore, MessageGroup) - Method in interface org.springframework.integration.store.MessageGroupStore.MessageGroupCallback
-
- execute(Runnable) - Method in class org.springframework.integration.util.CompositeExecutor
-
Execute using the primary executor.
- execute(Runnable) - Method in class org.springframework.integration.util.ErrorHandlingTaskExecutor
-
- execute2(Runnable) - Method in class org.springframework.integration.util.CompositeExecutor
-
Execute using the secondary executor.
- executeOutboundJpaOperation(Message<?>) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Execute the actual Jpa Operation.
- executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
-
- executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
- executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
-
Subclasses must implement this method.
- executeScript(ScriptSource) - Method in class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
-
- executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
-
- executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
-
- executeScript(ScriptSource) - Method in interface org.springframework.integration.scripting.ScriptExecutor
-
- executeScript(ScriptSource, Map<String, Object>) - Method in interface org.springframework.integration.scripting.ScriptExecutor
-
- executeStoredProcedure() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- executeStoredProcedure(Message<?>) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- executeUpdate(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- executeUpdate(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
Executes the given update statement and uses the given parameter source to
set the required query parameters.
- executeUpdateQuery(Message<?>, boolean) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
-
- executeUpdateWithNamedQuery(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- executeUpdateWithNamedQuery(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
- executeUpdateWithNativeQuery(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- executeUpdateWithNativeQuery(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
- executeWithClient(ClientCallback<C, T>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Execute the callback's doWithClient method after obtaining a session's
client, providing access to low level methods.
- executeWithClient(ClientCallback<C, T>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- executeWithClient(ClientCallback<C, T>) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
-
- executeWithClient(ClientCallback<C, T>) - Method in class org.springframework.integration.sftp.session.SftpRemoteFileTemplate
-
- executor - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
-
- ExecutorChannel - Class in org.springframework.integration.channel
-
- ExecutorChannel(Executor) - Constructor for class org.springframework.integration.channel.ExecutorChannel
-
Create an ExecutorChannel that delegates to the provided
Executor
when dispatching Messages.
- ExecutorChannel(Executor, LoadBalancingStrategy) - Constructor for class org.springframework.integration.channel.ExecutorChannel
-
- ExecutorChannelInterceptorAware - Interface in org.springframework.integration.channel
-
- executorInterceptorsSize - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
-
- exists(String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Check if a file exists on the remote server.
- exists(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- exists(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- exists(String) - Method in interface org.springframework.integration.file.remote.session.Session
-
Check if the remote file or directory exists.
- exists(String) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
-
This particular FTP implementation is based on the
FTPClient.getStatus(String)
by default, but since not all FTP servers properly implement the
STAT
command,
the framework internal
FtpRemoteFileTemplate
instances are switched to the
FTPClient.listNames(String)
for only files operations.
- exists(String) - Method in class org.springframework.integration.ftp.session.FtpSession
-
- exists(String) - Method in class org.springframework.integration.sftp.session.SftpSession
-
- EXPECT - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- expect(char) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
-
- ExpirableLockRegistry - Interface in org.springframework.integration.support.locks
-
A
LockRegistry
implementing this interface supports the removal of aged locks
that are not currently locked.
- EXPIRATION_DATE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
-
- expireGroup(Object, MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- expireMessageGroups(long) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- expireMessageGroups(long) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
- expireMessageGroups(long) - Method in interface org.springframework.integration.store.MessageGroupStore
-
Extract all expired groups (whose timestamp is older than the current time less the threshold provided) and call
each of the registered callbacks on them in turn.
- EXPIRES - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- expireUnusedOlderThan(long) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
-
- expireUnusedOlderThan(long) - Method in interface org.springframework.integration.support.locks.ExpirableLockRegistry
-
Remove locks last acquired more than 'age' ago that are not currently locked.
- expireUnusedOlderThan(long) - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
-
Remove locks last acquired more than 'age' ago that are not currently locked.
- ExponentialMovingAverage - Class in org.springframework.integration.support.management
-
Cumulative statistics for a series of real numbers with higher weight given to recent data.
- ExponentialMovingAverage(int) - Constructor for class org.springframework.integration.support.management.ExponentialMovingAverage
-
Create a moving average accumulator with decay lapse window provided.
- ExponentialMovingAverage(int, double) - Constructor for class org.springframework.integration.support.management.ExponentialMovingAverage
-
Create a moving average accumulator with decay lapse window provided.
- ExponentialMovingAverageRate - Class in org.springframework.integration.support.management
-
Cumulative statistics for an event rate with higher weight given to recent data.
- ExponentialMovingAverageRate(double, double, int) - Constructor for class org.springframework.integration.support.management.ExponentialMovingAverageRate
-
- ExponentialMovingAverageRate(double, double, int, boolean) - Constructor for class org.springframework.integration.support.management.ExponentialMovingAverageRate
-
- ExponentialMovingAverageRatio - Class in org.springframework.integration.support.management
-
Cumulative statistics for success ratio with higher weight given to recent data.
- ExponentialMovingAverageRatio(double, int) - Constructor for class org.springframework.integration.support.management.ExponentialMovingAverageRatio
-
- ExponentialMovingAverageRatio(double, int, boolean) - Constructor for class org.springframework.integration.support.management.ExponentialMovingAverageRatio
-
- EXPRESSION_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
-
- EXPRESSION_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- EXPRESSION_PARSER - Static variable in class org.springframework.integration.context.IntegrationObjectSupport
-
- EXPRESSION_PARSER - Static variable in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- EXPRESSION_PARSER - Static variable in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- ExpressionArgumentsStrategy - Class in org.springframework.integration.redis.outbound
-
- ExpressionArgumentsStrategy(String[]) - Constructor for class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
-
- ExpressionArgumentsStrategy(String[], boolean) - Constructor for class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
-
- ExpressionCapable - Interface in org.springframework.integration.context
-
Components that implement this interface are capable of supporting a primary
SpEL expression as part of their configuration.
- ExpressionCommandMessageProcessor - Class in org.springframework.integration.handler
-
A MessageProcessor implementation that expects an Expression or expressionString
as the Message payload.
- ExpressionCommandMessageProcessor() - Constructor for class org.springframework.integration.handler.ExpressionCommandMessageProcessor
-
- ExpressionCommandMessageProcessor(MethodFilter) - Constructor for class org.springframework.integration.handler.ExpressionCommandMessageProcessor
-
- ExpressionCommandMessageProcessor(MethodFilter, BeanFactory) - Constructor for class org.springframework.integration.handler.ExpressionCommandMessageProcessor
-
- ExpressionControlBusFactoryBean - Class in org.springframework.integration.config
-
FactoryBean for creating
MessageHandler
instances to handle a message as a SpEL expression.
- ExpressionControlBusFactoryBean() - Constructor for class org.springframework.integration.config.ExpressionControlBusFactoryBean
-
- ExpressionEvalMap - Class in org.springframework.integration.expression
-
An immutable
AbstractMap
implementation that wraps a
Map<String, Object>
,
where values must be instances of
String
or
Expression
,
and evaluates an
expression
for the provided
key
from the underlying
original
Map.
- ExpressionEvalMap.ComponentsEvaluationCallback - Class in org.springframework.integration.expression
-
- ExpressionEvalMap.EvaluationCallback - Interface in org.springframework.integration.expression
-
- ExpressionEvalMap.ExpressionEvalMapBuilder - Class in org.springframework.integration.expression
-
- ExpressionEvalMap.ExpressionEvalMapComponentsBuilder - Interface in org.springframework.integration.expression
-
- ExpressionEvalMap.ExpressionEvalMapFinalBuilder - Interface in org.springframework.integration.expression
-
- ExpressionEvaluatingCorrelationStrategy - Class in org.springframework.integration.aggregator
-
- ExpressionEvaluatingCorrelationStrategy(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
-
- ExpressionEvaluatingCorrelationStrategy(Expression) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
-
- ExpressionEvaluatingHeaderValueMessageProcessor<T> - Class in org.springframework.integration.transformer.support
-
- ExpressionEvaluatingHeaderValueMessageProcessor(Expression, Class<T>) - Constructor for class org.springframework.integration.transformer.support.ExpressionEvaluatingHeaderValueMessageProcessor
-
Create a header value processor for the given Expression and the
expected type of the expression evaluation result.
- ExpressionEvaluatingHeaderValueMessageProcessor(String, Class<T>) - Constructor for class org.springframework.integration.transformer.support.ExpressionEvaluatingHeaderValueMessageProcessor
-
Create a header value processor for the given expression string and
the expected type of the expression evaluation result.
- ExpressionEvaluatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
-
- ExpressionEvaluatingMessageGroupProcessor(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
-
- ExpressionEvaluatingMessageHandler - Class in org.springframework.integration.handler
-
- ExpressionEvaluatingMessageHandler(Expression) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
-
- ExpressionEvaluatingMessageListProcessor - Class in org.springframework.integration.aggregator
-
A base class for aggregators that evaluates a SpEL expression with the message list as the root object within the
evaluation context.
- ExpressionEvaluatingMessageListProcessor(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
-
- ExpressionEvaluatingMessageProcessor<T> - Class in org.springframework.integration.handler
-
A
MessageProcessor
implementation that evaluates a SpEL expression
with the Message itself as the root object within the evaluation context.
- ExpressionEvaluatingMessageProcessor(Expression) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
-
- ExpressionEvaluatingMessageProcessor(Expression, Class<T>) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
-
- ExpressionEvaluatingMessageSource<T> - Class in org.springframework.integration.endpoint
-
- ExpressionEvaluatingMessageSource(Expression, Class<T>) - Constructor for class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
-
- ExpressionEvaluatingParameterSourceFactory - Class in org.springframework.integration.jpa.support.parametersource
-
- ExpressionEvaluatingParameterSourceFactory() - Constructor for class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
-
- ExpressionEvaluatingParameterSourceFactory(BeanFactory) - Constructor for class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
-
- ExpressionEvaluatingReleaseStrategy - Class in org.springframework.integration.aggregator
-
- ExpressionEvaluatingReleaseStrategy(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingReleaseStrategy
-
- ExpressionEvaluatingRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
-
- ExpressionEvaluatingRequestHandlerAdvice() - Constructor for class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-