Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W Y 

A

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
 
AbstractBatchingMessageGroupStore - Class in org.springframework.integration.store
 
AbstractBatchingMessageGroupStore() - Constructor for class org.springframework.integration.store.AbstractBatchingMessageGroupStore
 
AbstractCandidate - Class in org.springframework.integration.leader
Base implementation of a Candidate.
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
 
AbstractChannelParser - Class in org.springframework.integration.config.xml
Base class for channel parsers.
AbstractChannelParser() - Constructor for class org.springframework.integration.config.xml.AbstractChannelParser
 
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
Base class for parsers that create an instance of AbstractCorrelatingMessageHandler
AbstractCorrelatingMessageHandlerParser() - Constructor for class org.springframework.integration.config.xml.AbstractCorrelatingMessageHandlerParser
 
AbstractDispatcher - Class in org.springframework.integration.dispatcher
Base class for MessageDispatcher implementations.
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
The AbstractSubscribableChannel base implementation for those inheritors which logic may be based on the Executor.
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
 
AbstractHandleMessageAdvice - Class in org.springframework.integration.handler.advice
The base HandleMessageAdvice for advices which can be applied only for the MessageHandler.handleMessage(Message).
AbstractHandleMessageAdvice() - Constructor for class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
 
AbstractHeaderMapper<T> - Class in org.springframework.integration.mapping
Abstract base class for RequestReplyHeaderMapper implementations.
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
A composite AbstractHeaderMapper.HeaderMatcher that matches if one of provided AbstractHeaderMapper.HeaderMatchers matches to the headerName.
AbstractHeaderMapper.ContentBasedHeaderMatcher - Class in org.springframework.integration.mapping
A content-based AbstractHeaderMapper.HeaderMatcher that matches if the specified header is contained within a list of candidates.
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
A pattern-based AbstractHeaderMapper.HeaderMatcher that matches if the specified header matches one of the specified simple patterns.
AbstractHeaderMapper.PrefixBasedMatcher - Class in org.springframework.integration.mapping
A prefix-based AbstractHeaderMapper.HeaderMatcher that matches if the specified header starts with a configurable prefix.
AbstractHeaderMapper.SinglePatternBasedHeaderMatcher - Class in org.springframework.integration.mapping
A pattern-based AbstractHeaderMapper.HeaderMatcher that matches if the specified header matches the specified simple pattern.
AbstractHeaderValueMessageProcessor<T> - Class in org.springframework.integration.transformer.support
 
AbstractHeaderValueMessageProcessor() - Constructor for class org.springframework.integration.transformer.support.AbstractHeaderValueMessageProcessor
 
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
 
AbstractJacksonJsonObjectMapper<N,P,J> - Class in org.springframework.integration.support.json
Base class for Jackson JsonObjectMapper implementations.
AbstractJacksonJsonObjectMapper() - Constructor for class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
AbstractJsonInboundMessageMapper<P> - Class in org.springframework.integration.support.json
Abstract InboundMessageMapper implementation that maps incoming JSON messages to a Message with the specified payload type.
AbstractJsonInboundMessageMapper(Type) - Constructor for class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
AbstractKeyValueMessageStore - Class in org.springframework.integration.store
Base class for implementations of Key/Value style MessageGroupStore and MessageStore
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 Codecs using Kryo.
AbstractKryoCodec() - Constructor for class org.springframework.integration.codec.kryo.AbstractKryoCodec
 
AbstractKryoRegistrar - Class in org.springframework.integration.codec.kryo
Base class for KryoRegistrar implementations.
AbstractKryoRegistrar() - Constructor for class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
 
AbstractLeaderEvent - Class in org.springframework.integration.leader.event
Base ApplicationEvent class for leader based events.
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.
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
A base class for MessageSelector implementations that delegate to a MessageProcessor.
AbstractMessageProcessingSelector(MessageProcessor<Boolean>) - Constructor for class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
AbstractMessageProcessingTransformer - Class in org.springframework.integration.transformer
Base class for Message Transformers that delegate to a MessageProcessor.
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
The base AbstractMessageHandler implementation for the MessageProducer.
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 java.lang.annotation.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
 
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
A base class for Transformer implementations that modify the payload of a Message.
AbstractPayloadTransformer() - Constructor for class org.springframework.integration.transformer.AbstractPayloadTransformer
 
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
 
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
An implementation of this interface is used to wrap the AbstractReplyProducingMessageHandler.handleRequestMessage(Message) method.
AbstractReplyProducingPostProcessingMessageHandler - Class in org.springframework.integration.handler
 
AbstractReplyProducingPostProcessingMessageHandler() - Constructor for class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
 
AbstractRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
Base class for MessageHandler advice classes.
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.
AbstractRouterParser - Class in org.springframework.integration.config.xml
Base parser for routers.
AbstractRouterParser() - Constructor for class org.springframework.integration.config.xml.AbstractRouterParser
 
AbstractSimpleMessageHandlerFactoryBean<H extends org.springframework.messaging.MessageHandler> - Class in org.springframework.integration.config
Factory bean to create and configure a MessageHandler.
AbstractSimpleMessageHandlerFactoryBean() - Constructor for class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
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
 
AbstractSubscribableChannel - Class in org.springframework.integration.channel
Base implementation of MessageChannel that invokes the subscribed handler(s) by delegating to a MessageDispatcher.
AbstractSubscribableChannel() - Constructor for class org.springframework.integration.channel.AbstractSubscribableChannel
 
AbstractTransformer - Class in org.springframework.integration.transformer
A base class for Transformer implementations.
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
 
accept(S) - Method in interface org.springframework.integration.core.GenericSelector
 
accept(Message<?>) - Method in interface org.springframework.integration.core.MessageSelector
 
accept(Message<?>) - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
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
 
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
 
activeCount - Variable in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
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
Adds attribute to this ResourceHolder instance
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
 
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.splitter.AbstractMessageSplitter
Allows subclasses to add extra headers to the output messages.
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
And a ChannelInterceptor to the target implementation.
addInterceptor(int, ChannelInterceptor) - Method in interface org.springframework.integration.channel.ChannelInterceptorAware
And a ChannelInterceptor to the target implementation for the specific index.
addLifecyclesToRole(String, List<String>) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Add a SmartLifecycle beans to the role using their names.
addLifecycleToRole(String, SmartLifecycle) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Add a SmartLifecycle to the role.
addLifecycleToRole(String, String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Add a SmartLifecycle bean to the role using its name.
addListener(MetadataStoreListener) - Method in interface org.springframework.integration.metadata.ListenableMetadataStore
Registers a listener with the metadata store
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.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
 
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.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
 
addNotPropagatedHeaders(String...) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Add headers that will NOT be copied from the inbound message if AbstractMessageProducingHandler.shouldCopyRequestHeaders() is true, instead of overwriting the existing set.
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.
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.
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
A constructor with the MessageHeaders instance to use.
AdviceMessageJacksonDeserializer - Class in org.springframework.integration.support.json
The MessageJacksonDeserializer implementation for the AdviceMessage.
AdviceMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.AdviceMessageJacksonDeserializer
 
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
 
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.metadata.PropertiesPersistingMetadataStore
 
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
 
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(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
 
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.
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.support.management.IntegrationManagementConfigurer
 
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
Aggregator specific implementation of AbstractCorrelatingMessageHandler.
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
Post-processor for the @Aggregator annotation.
AggregatorAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
 
AggregatorFactoryBean - Class in org.springframework.integration.config
FactoryBean to create an AggregatingMessageHandler.
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.
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
 
append(double) - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
Add a new measurement to the series.
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
 
apply(T) - Method in interface org.springframework.integration.util.Function
Execute the logic of the action, accepting the given parameter.
applyReceiveOnlyAdviceChain(Collection<Advice>) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Add the advice chain to the component that responds to AbstractPollingEndpoint.receiveMessage() calls.
applyReceiveOnlyAdviceChain(Collection<Advice>) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
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
 
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
 

B

BarrierMessageHandler - Class in org.springframework.integration.aggregator
A message handler that suspends the thread until a message with corresponding correlation is passed into the trigger method or the timeout occurs.
BarrierMessageHandler(long) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
Construct an instance with the provided timeout and default correlation and output strategies.
BarrierMessageHandler(long, MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
Construct an instance with the provided timeout and output processor, and default correlation strategy.
BarrierMessageHandler(long, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
Construct an instance with the provided timeout and correlation strategy, and default output processor.
BarrierMessageHandler(long, MessageGroupProcessor, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
Construct an instance with the provided timeout and output processor, and default correlation strategy.
BarrierParser - Class in org.springframework.integration.config.xml
Parser for <int:barrier/>.
BarrierParser() - Constructor for class org.springframework.integration.config.xml.BarrierParser
 
BASE_PACKAGE - Static variable in class org.springframework.integration.config.IntegrationConfigUtils
 
BasicMessageGroupStore - Interface in org.springframework.integration.store
Defines a minimal message group store with basic capabilities.
beanAnnotationAware() - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
beanAnnotationAware() - Method in class org.springframework.integration.config.annotation.AggregatorAnnotationPostProcessor
 
BeanDefinitionRegisteringParser - Interface in org.springframework.integration.config.xml
Simple strategy interface for parsers that are responsible for parsing an element, creating a bean definition, and then registering the bean.
beanFactory - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
BeanFactoryChannelResolver - Class in org.springframework.integration.support.channel
DestinationResolver implementation based on a Spring BeanFactory.
BeanFactoryChannelResolver() - Constructor for class org.springframework.integration.support.channel.BeanFactoryChannelResolver
Create a new instance of the BeanFactoryChannelResolver class.
BeanFactoryChannelResolver(BeanFactory) - Constructor for class org.springframework.integration.support.channel.BeanFactoryChannelResolver
Create a new instance of the BeanFactoryChannelResolver class.
BeanFactoryTypeConverter - Class in org.springframework.integration.util
 
BeanFactoryTypeConverter() - Constructor for class org.springframework.integration.util.BeanFactoryTypeConverter
 
BeanFactoryTypeConverter(ConversionService) - Constructor for class org.springframework.integration.util.BeanFactoryTypeConverter
 
beforeCommit(String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
beforeCommit(String, String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
beforeCommit(MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
beforeCommit(String, MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
beforeHandle(Message<?>, MessageChannel, MessageHandler) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
beforeHandle() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
Begin a handle event.
beforeHandle() - Method in class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics
 
beforeHandle() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
beforeReceive(MessageSource<?>) - Method in class org.springframework.integration.aop.AbstractMessageSourceAdvice
Subclasses can decide whether to proceed with this poll.
beforeReceive(MessageSource<?>) - Method in class org.springframework.integration.aop.CompoundTriggerAdvice
 
beforeReceive(MessageSource<?>) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
 
beforeSend() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
Begin a send event.
beforeSend() - Method in class org.springframework.integration.support.management.AggregatingMessageChannelMetrics
 
beforeSend() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
beforeShutdown() - Method in interface org.springframework.integration.context.OrderlyShutdownCapable
Called before shutdown begins.
BoonJsonObjectMapper - Class in org.springframework.integration.support.json
The Boon (@link https://github.com/RichardHightower/boon) JsonObjectMapper implementation.
BoonJsonObjectMapper() - Constructor for class org.springframework.integration.support.json.BoonJsonObjectMapper
 
BoonJsonObjectMapper(JsonParserFactory, JsonSerializerFactory) - Constructor for class org.springframework.integration.support.json.BoonJsonObjectMapper
 
BridgeFrom - Annotation Type in org.springframework.integration.annotation
Messaging Annotation to mark a Bean method for a MessageChannel to produce a BridgeHandler and Consumer Endpoint.
BridgeFromAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for the @BridgeFrom annotation.
BridgeFromAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
 
BridgeHandler - Class in org.springframework.integration.handler
A simple MessageHandler implementation that passes the request Message directly to the output channel without modifying it.
BridgeHandler() - Constructor for class org.springframework.integration.handler.BridgeHandler
 
BridgeParser - Class in org.springframework.integration.config.xml
Parser for the <bridge> element.
BridgeParser() - Constructor for class org.springframework.integration.config.xml.BridgeParser
 
BridgeTo - Annotation Type in org.springframework.integration.annotation
Messaging Annotation to mark a Bean method for a MessageChannel to produce a BridgeHandler and Consumer Endpoint.
BridgeToAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for the @BridgeTo annotation.
BridgeToAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.BridgeToAnnotationPostProcessor
 
BroadcastingDispatcher - Class in org.springframework.integration.dispatcher
A broadcasting dispatcher implementation.
BroadcastingDispatcher() - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
BroadcastingDispatcher(Executor) - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
BroadcastingDispatcher(boolean) - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
BroadcastingDispatcher(Executor, boolean) - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
build() - Method in interface org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapFinalBuilder
 
build() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
build() - Method in class org.springframework.integration.support.MessageBuilder
 
build() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
Subclasses must implement this method to create the bean definition.
buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PointToPointChannelParser
 
buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PublishSubscribeChannelParser
 
buildErrorMessage(Message<?>, RuntimeException) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Build an error message for the exception and message using the configured ErrorMessageStrategy.
buildErrorMessage(Message<?>, Throwable) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Build an error message for the message and throwable using the configured ErrorMessageStrategy.
buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.support.DefaultErrorMessageStrategy
 
buildErrorMessage(Throwable, AttributeAccessor) - Method in interface org.springframework.integration.support.ErrorMessageStrategy
Build the error message.
buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.AdviceMessageJacksonDeserializer
 
buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.ErrorMessageJacksonDeserializer
 
buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.GenericMessageJacksonDeserializer
 
buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
 
buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.MutableMessageJacksonDeserializer
 
buildResult(Object, Message<?>, Message<?>) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
Override to change the default mechanism by which the inbound and release messages are returned as a result.
bytesToString(byte[], String) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
Utility method for null-safe conversion from byte[] to String

C

call() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator.LeaderSelector
 
CallerBlocksPolicy - Class in org.springframework.integration.util
A RejectedExecutionHandler that blocks the caller until the executor has room in its queue, or a timeout occurs (in which case a RejectedExecutionException is thrown.
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
Always returns true - any AbstractMessageProducingHandler can be used directly.
canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
canBeUsedDirect(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.TransformerFactoryBean
Always returns true - any AbstractMessageProducingHandler can be used directly.
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(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(EvaluationContext, Object, String) - Method in class org.springframework.integration.json.JsonPropertyAccessor
 
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
 
ChannelInterceptorAware - Interface in org.springframework.integration.channel
A marker interface providing the ability to configure ChannelInterceptors on MessageChannel implementations.
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
 
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.
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).
ChannelPurger - Class in org.springframework.integration.channel
A utility class for purging Messages from one or more QueueChannels.
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
Specify the DestinationResolver strategy to use.
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
Specifies the value for AbstractDispatcher.maxSubscribers in case of point-to-point channels (e.g.
CHANNELS_MAX_UNICAST_SUBSCRIBERS - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies the value for AbstractDispatcher.maxSubscribers in case of point-to-point channels (e.g.
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).
checkAndConfigureFixedSubscriberChannel(Element, ParserContext, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
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
 
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
Remove all Messages from this channel.
clear() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
clear() - Method in class org.springframework.integration.history.MessageHistory
 
clear() - Method in interface org.springframework.integration.store.MessageGroup
 
clear() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
clear() - Method in class org.springframework.integration.support.MutableMessageHeaders
 
clearCache() - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Clear the resource bundle cache.
clearMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
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.handler.advice.RequestHandlerRetryAdvice
 
close() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
close() - Method in class org.springframework.integration.util.FunctionIterator
 
close() - Method in class org.springframework.integration.util.SimplePool
 
CLOSEABLE_RESOURCE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
CloseableIterator<E> - Interface in org.springframework.integration.util
A CloseableIterator is intended to be used when it may hold resources (such as file or socket handles).
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
A MessageConverter that delegates to a Codec to convert
CodecMessageConverter(Codec) - Constructor for class org.springframework.integration.codec.CodecMessageConverter
 
CollectionFilter<T> - Interface in org.springframework.integration.util
Base strategy for filtering out a subset of a Collection of elements.
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.
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.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
 
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
A Trigger that delegates the CompoundTrigger.nextExecutionTime(TriggerContext) to one of two Triggers.
CompoundTrigger(Trigger) - Constructor for class org.springframework.integration.util.CompoundTrigger
Construct a compound trigger with the supplied primary trigger.
CompoundTriggerAdvice - Class in org.springframework.integration.aop
An AbstractMessageSourceAdvice that uses a CompoundTrigger to adjust the poller - when a message is present, the compound trigger's primary trigger is used to determine the next poll.
CompoundTriggerAdvice(CompoundTrigger, Trigger) - Constructor for class org.springframework.integration.aop.CompoundTriggerAdvice
 
ConcurrentMetadataStore - Interface in org.springframework.integration.metadata
Supports atomic updates to values in the store.
ConfigurableMetrics - Interface in org.springframework.integration.support.management
Marker interface for metrics.
ConfigurableMetricsAware<M extends ConfigurableMetrics> - Interface in org.springframework.integration.support.management
Classes implementing this interface can accept a ConfigurableMetrics.
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
 
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.
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
 
contains(Object) - Method in class org.springframework.integration.history.MessageHistory
 
containsAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
 
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_TYPE_ID - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
 
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.
ControlBusMethodFilter - Class in org.springframework.integration.expression
SpEL MethodFilter to restrict method invocations to: Lifecycle components get, set and shutdown methods of CustomizableThreadCreator methods with ManagedAttribute and ManagedOperation annotations This class isn't designed for target applications and typically is used from ExpressionControlBusFactoryBean.
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
 
conversionService - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
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
Convert the input to a UUID using the convenience method UUIDConverter.getUUID(Object).
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
 
convertValue(Object, TypeDescriptor, TypeDescriptor) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
copy(MessageGroup) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
Used by expireMessageGroups.
copy(MessageGroup) - Method in class org.springframework.integration.store.SimpleMessageStore
 
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
 
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
 
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
Convenience factory for XML configuration of a CorrelationStrategy.
CorrelationStrategyFactoryBean() - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
CorrelationStrategyFactoryBean(Object) - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
Deprecated.
since 4.2.5 in favor of appropriate setters to avoid BeanCurrentlyInCreationException during AbstractAutowireCapableBeanFactory.getSingletonFactoryBeanForTypeCheck()
CorrelationStrategyFactoryBean(Object, String) - Constructor for class org.springframework.integration.config.CorrelationStrategyFactoryBean
Deprecated.
since 4.2.5 in favor of appropriate setters to avoid BeanCurrentlyInCreationException during AbstractAutowireCapableBeanFactory.getSingletonFactoryBeanForTypeCheck()
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
Factory method to create an AbstractMessageChannelMetrics.
CREATED_DATE - Static variable in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
createDefaultHandler() - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
createDefaultHandler() - Method in class org.springframework.integration.config.SplitterFactoryBean
 
createDefaultHeaderMatcher(String, Collection<String>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Create the initial AbstractHeaderMapper.HeaderMatcher based on the specified headers and standard header prefix.
createDirectChannel(Element, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
createDirectHandlerIfPossible(Object, String) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
If the target object is a MessageHandler and the method is 'handleMessage', return an AbstractMessageProducingHandler that wraps it.
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.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
 
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
Factory method to create an AbstractMessageHandlerMetrics.
createHeaderMatcher(Collection<String>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Create a AbstractHeaderMapper.HeaderMatcher that match if any of the specified patterns match.
createInstance() - Method in class org.springframework.integration.config.ExpressionFactoryBean
 
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
 
createOutputMessage(Object, MessageHeaders) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
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.
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.

D

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
 
DecodingTransformer<T> - Class in org.springframework.integration.transformer
AbstractPayloadTransformer that delegates to a codec to decode the payload from a byte[].
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_ADVICE_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
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_CONFIGURING_POSTPROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
DEFAULT_ERROR_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DEFAULT_FILE_REGISTRATION_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DEFAULT_GENERIC_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
DEFAULT_HASH_MAP_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_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
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_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_UUID_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
 
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
 
DefaultCandidate - Class in org.springframework.integration.leader
Simple Candidate for leadership.
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.
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
 
DefaultErrorMessageStrategy - Class in org.springframework.integration.support
A simple ErrorMessageStrategy implementations which produces a error message with original message if the AttributeAccessor has ErrorMessageUtils.INPUT_MESSAGE_CONTEXT_KEY attribute.
DefaultErrorMessageStrategy() - Constructor for class org.springframework.integration.support.DefaultErrorMessageStrategy
 
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.
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
 
DefaultLeaderEventPublisher - Class in org.springframework.integration.leader.event
Default implementation of LeaderEventPublisher.
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.
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
 
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
 
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
 
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
 
DefaultTransactionSynchronizationFactory - Class in org.springframework.integration.transaction
Default implementation of TransactionSynchronizationFactory which takes an instance of TransactionSynchronizationProcessor allowing you to create a TransactionSynchronization using {DefaultTransactionSynchronizationFactory.create(Object) method.
DefaultTransactionSynchronizationFactory(TransactionSynchronizationProcessor) - Constructor for class org.springframework.integration.transaction.DefaultTransactionSynchronizationFactory
 
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
Create a DelayHandler with the given 'messageGroupId' that is used as 'key' for MessageGroup to store delayed Messages in the MessageGroupStore.
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
 
delegate - Variable in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
deserialize(ByteArrayInputStream) - Method in class org.springframework.integration.support.converter.WhiteListDeserializingConverter
 
destroy() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
destroy() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
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
 
determinePayload(Throwable, AttributeAccessor) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Build a Throwable payload for future ErrorMessage.
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
Create a channel with default RoundRobinLoadBalancingStrategy
DirectChannel(LoadBalancingStrategy) - Constructor for class org.springframework.integration.channel.DirectChannel
Create a DirectChannel with a LoadBalancingStrategy.
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
 
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
 
doAddMessage(Message<?>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
doBegin(Object, TransactionDefinition) - Method in class org.springframework.integration.transaction.PseudoTransactionManager
 
doCommit(DefaultTransactionStatus) - Method in class org.springframework.integration.transaction.PseudoTransactionManager
 
doCreateEndpoint(MessageHandler, MessageChannel, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
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
 
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
 
doGetTransaction() - Method in class org.springframework.integration.transaction.PseudoTransactionManager
 
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.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.scattergather.ScatterGatherHandler
 
doInit() - Method in class org.springframework.integration.transformer.ContentEnricher
Initializes the Content Enricher.
doInit() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
doInParser(JsonInboundMessageMapper, String) - Method in interface org.springframework.integration.support.json.JsonInboundMessageMapper.JsonMessageParser
 
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
 
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.store.AbstractKeyValueMessageStore
 
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
 
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
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
Subclasses may add to the bean definition by overriding this method.
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.resource.ResourceRetrievingMessageSource
 
doRemove(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
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.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
 
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.gateway.GatewayProxyFactoryBean
 
doStart() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
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.gateway.GatewayProxyFactoryBean
 
doStop() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
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.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
 
doWhileLocked() - Method in class org.springframework.integration.util.WhileLockedProcessor
 
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_MESSAGE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
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
 
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.

E

EnableIntegration - Annotation Type in org.springframework.integration.config
The main configuration annotation to enable Spring Integration infrastructure: - Registers some built-in beans; - Adds several BeanFactoryPostProcessors; - Adds several BeanPostProcessors; - Adds annotations processors.
EnableIntegrationManagement - Annotation Type in org.springframework.integration.config
Enables default configuring of management in Spring Integration components in an existing application.
EnableMessageHistory - Annotation Type in org.springframework.integration.config
Enables MessageHistory for Integration components.
EnablePublisher - Annotation Type in org.springframework.integration.config
Provides the registration for the PublisherAnnotationBeanPostProcessor to allow the use of the Publisher annotation.
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
 
EncodingPayloadTransformer<T> - Class in org.springframework.integration.transformer
AbstractPayloadTransformer that delegates to a codec to encode the payload into a byte[].
EncodingPayloadTransformer(Codec) - Constructor for class org.springframework.integration.transformer.EncodingPayloadTransformer
 
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
Specifies the value of AbstractEndpoint.autoStartup.
EnhancedErrorMessage - Class in org.springframework.integration.message
Deprecated.
since 4.3.10 in favor of direct ErrorMessage usage since 5.0.
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.
 
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.json.JsonPropertyAccessor.ToStringFriendlyJsonNode
 
equals(Object) - Method in class org.springframework.integration.support.MutableMessage
 
equals(Object) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
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
The MessageJacksonDeserializer implementation for the ErrorMessage.
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
Construct instance based on the provided message channel and ErrorMessageStrategy.
ErrorMessageSendingRecoverer.RetryExceptionNotAvailableException - Exception in org.springframework.integration.handler.advice
 
ErrorMessageStrategy - Interface in org.springframework.integration.support
A strategy to build an ErrorMessage based on the provided Throwable and AttributeAccessor as a context.
ErrorMessageUtils - Class in org.springframework.integration.support
Utilities for building error messages.
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
 
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
 
EventDrivenConsumer - Class in org.springframework.integration.endpoint
Message Endpoint that connects any MessageHandler implementation to a SubscribableChannel.
EventDrivenConsumer(SubscribableChannel, MessageHandler) - Constructor for class org.springframework.integration.endpoint.EventDrivenConsumer
 
exchange(Message<?>) - Method in interface org.springframework.integration.gateway.RequestReplyExchanger
 
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.
executor - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
 
ExecutorChannel - Class in org.springframework.integration.channel
An implementation of MessageChannel that delegates to an instance of UnicastingDispatcher which in turn delegates all dispatching invocations to an Executor.
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
Create an ExecutorChannel with a LoadBalancingStrategy that delegates to the provided Executor when dispatching Messages.
ExecutorChannelInterceptorAware - Interface in org.springframework.integration.channel
The ChannelInterceptorAware extension for the cases when the ExecutorChannelInterceptors may have reason (e.g.
executorInterceptorsSize - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
 
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.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.
expireUnusedOlderThan(long) - Method in interface org.springframework.integration.support.locks.ExpirableLockRegistry
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.util.AbstractExpressionEvaluator
 
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
The ExpressionEvalMap.EvaluationCallback implementation which evaluates an expression using the provided context, root and returnType variables.
ExpressionEvalMap.EvaluationCallback - Interface in org.springframework.integration.expression
Implementations of this interface can be provided to build 'on demand ExpressionEvalMap.get(Object) logic' for ExpressionEvalMap.
ExpressionEvalMap.ExpressionEvalMapBuilder - Class in org.springframework.integration.expression
The builder class to instantiate ExpressionEvalMap.
ExpressionEvalMap.ExpressionEvalMapComponentsBuilder - Interface in org.springframework.integration.expression
 
ExpressionEvalMap.ExpressionEvalMapFinalBuilder - Interface in org.springframework.integration.expression
 
ExpressionEvaluatingCorrelationStrategy - Class in org.springframework.integration.aggregator
CorrelationStrategy implementation that evaluates an expression.
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
A MessageGroupProcessor implementation that evaluates a SpEL expression.
ExpressionEvaluatingMessageGroupProcessor(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
 
ExpressionEvaluatingMessageHandler - Class in org.springframework.integration.handler
A MessageHandler that evaluates the provided Expression expecting a void return.
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
Create an ExpressionEvaluatingMessageProcessor for the given expression.
ExpressionEvaluatingMessageProcessor(Expression, Class<T>) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
Create an ExpressionEvaluatingMessageProcessor for the given expression and expected type for its evaluation result.
ExpressionEvaluatingMessageSource<T> - Class in org.springframework.integration.endpoint
 
ExpressionEvaluatingMessageSource(Expression, Class<T>) - Constructor for class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
 
ExpressionEvaluatingReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that evaluates an expression.
ExpressionEvaluatingReleaseStrategy(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingReleaseStrategy
 
ExpressionEvaluatingRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
Used to advise MessageHandlers.
ExpressionEvaluatingRequestHandlerAdvice() - Constructor for class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
 
ExpressionEvaluatingRequestHandlerAdvice.MessageHandlingExpressionEvaluatingAdviceException - Exception in org.springframework.integration.handler.advice
 
ExpressionEvaluatingRouter - Class in org.springframework.integration.router
A Message Router implementation that evaluates the specified SpEL expression.
ExpressionEvaluatingRouter(Expression) - Constructor for class org.springframework.integration.router.ExpressionEvaluatingRouter
 
ExpressionEvaluatingRoutingSlipRouteStrategy - Class in org.springframework.integration.routingslip
The Expression based RoutingSlipRouteStrategy implementation.
ExpressionEvaluatingRoutingSlipRouteStrategy(String) - Constructor for class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
ExpressionEvaluatingRoutingSlipRouteStrategy(Expression) - Constructor for class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
ExpressionEvaluatingRoutingSlipRouteStrategy.RequestAndReply - Class in org.springframework.integration.routingslip
 
ExpressionEvaluatingSelector - Class in org.springframework.integration.filter
A MessageSelector implementation that evaluates a SpEL expression.
ExpressionEvaluatingSelector(String) - Constructor for class org.springframework.integration.filter.ExpressionEvaluatingSelector
 
ExpressionEvaluatingSelector(Expression) - Constructor for class org.springframework.integration.filter.ExpressionEvaluatingSelector
 
ExpressionEvaluatingSplitter - Class in org.springframework.integration.splitter
A Message Splitter implementation that evaluates the specified SpEL expression.
ExpressionEvaluatingSplitter(Expression) - Constructor for class org.springframework.integration.splitter.ExpressionEvaluatingSplitter
 
ExpressionEvaluatingTransactionSynchronizationProcessor - Class in org.springframework.integration.transaction
This implementation of TransactionSynchronizationFactory allows you to configure SpEL expressions, with their execution being coordinated (synchronized) with a transaction - see TransactionSynchronization.
ExpressionEvaluatingTransactionSynchronizationProcessor() - Constructor for class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
ExpressionEvaluatingTransformer - Class in org.springframework.integration.transformer
A Message Transformer implementation that evaluates the specified SpEL expression.
ExpressionEvaluatingTransformer(Expression) - Constructor for class org.springframework.integration.transformer.ExpressionEvaluatingTransformer
 
ExpressionFactoryBean - Class in org.springframework.integration.config
FactoryBean for creating Expression instances.
ExpressionFactoryBean(String) - Constructor for class org.springframework.integration.config.ExpressionFactoryBean
 
ExpressionMessageProducerSupport - Class in org.springframework.integration.endpoint
A MessageProducerSupport sub-class that provides ExpressionMessageProducerSupport.payloadExpression evaluation with result as a payload for Message to send.
ExpressionMessageProducerSupport() - Constructor for class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
ExpressionSource - Interface in org.springframework.integration.expression
Strategy interface for retrieving Expressions.
ExpressionUtils - Class in org.springframework.integration.expression
Utility class with static methods for helping with establishing environments for SpEL expressions.
ExpressionUtils() - Constructor for class org.springframework.integration.expression.ExpressionUtils
 
extractAdviceChain(String, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
extractJavaType(Map<String, Object>) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
extractJavaType(Map<String, Object>) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
extractStandardHeaders(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Extract the standard headers from the specified source.
extractTypeIfPossible(Object, Class<T>) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
extractTypeIfPossible(Object, Class<H>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
extractTypeIfPossible(Object, Class<T>) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
extractUserDefinedHeaders(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Extract the user-defined headers from the specified source.

F

FACILITY - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
FACTORY_BEAN_OBJECT_TYPE - Static variable in class org.springframework.integration.config.IntegrationConfigUtils
 
FAILED_MESSAGE_CONTEXT_KEY - Static variable in class org.springframework.integration.support.ErrorMessageUtils
The context key for the message object.
failure() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
Add a new event with failed outcome.
failure(long) - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
Add a new event with failed outcome at time t.
fatalWhenNoBeanFactory - Static variable in class org.springframework.integration.support.utils.IntegrationUtils
Should be set to TRUE on CI plans and framework developer systems.
FileKryoRegistrar - Class in org.springframework.integration.codec.kryo
A KryoRegistrar used to validateRegistration a File serializer.
FileKryoRegistrar() - Constructor for class org.springframework.integration.codec.kryo.FileKryoRegistrar
 
FileKryoRegistrar(int) - Constructor for class org.springframework.integration.codec.kryo.FileKryoRegistrar
 
FileSerializer - Class in org.springframework.integration.codec.kryo
A custom Kryo Serializer for serializing File payloads.
FileSerializer() - Constructor for class org.springframework.integration.codec.kryo.FileSerializer
 
Filter - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of playing the role of a Message Filter.
filter(List<Method>) - Method in class org.springframework.integration.expression.ControlBusMethodFilter
 
filter(Collection<T>) - Method in class org.springframework.integration.util.AcceptOnceCollectionFilter
 
filter(List<Method>) - Method in class org.springframework.integration.util.AnnotatedMethodFilter
 
filter(Collection<T>) - Method in interface org.springframework.integration.util.CollectionFilter
 
filter(List<Method>) - Method in class org.springframework.integration.util.FixedMethodFilter
 
FilterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @Filter.
FilterAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.FilterAnnotationPostProcessor
 
FilterFactoryBean - Class in org.springframework.integration.config
Factory bean for creating a Message Filter.
FilterFactoryBean() - Constructor for class org.springframework.integration.config.FilterFactoryBean
 
FilterParser - Class in org.springframework.integration.config.xml
Parser for the <filter/> element.
FilterParser() - Constructor for class org.springframework.integration.config.xml.FilterParser
 
findAnnotatedMethod(Object, Class<? extends Annotation>) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
 
findClosestMatch(Class<?>, Set<Class<?>>, boolean) - Static method in class org.springframework.integration.util.ClassUtils
 
findLastReleasedSequenceNumber(Object, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
findMessagePartAnnotation(Annotation[], boolean) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
Find the one of Payload, Header or Headers annotation from the provided annotations array.
firstId() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
FixedMethodFilter - Class in org.springframework.integration.util
A MethodFilter implementation that will always return the same Method instance within a single-element list if it is present in the candidate list.
FixedMethodFilter(Method) - Constructor for class org.springframework.integration.util.FixedMethodFilter
 
FixedSubscriberChannel - Class in org.springframework.integration.channel
Specialized SubscribableChannel for a single final subscriber set up during bean instantiation (unlike other SubscribableChannels where the MessageHandler is subscribed when the endpoint is started).
FixedSubscriberChannel() - Constructor for class org.springframework.integration.channel.FixedSubscriberChannel
 
FixedSubscriberChannel(MessageHandler) - Constructor for class org.springframework.integration.channel.FixedSubscriberChannel
 
FixedSubscriberChannelBeanFactoryPostProcessor - Class in org.springframework.integration.config
Used to post process candidates for FixedSubscriberChannel MessageHandlers.
flush() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
forceComplete(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
from(Map<String, ?>) - Static method in class org.springframework.integration.expression.ExpressionEvalMap
 
fromHeaders(MessageHeaders, T) - Method in interface org.springframework.integration.mapping.HeaderMapper
 
fromHeadersToReply(MessageHeaders, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
fromHeadersToReply(MessageHeaders, T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
Map from the given MessageHeaders to the specified reply target.
fromHeadersToRequest(MessageHeaders, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
fromHeadersToRequest(MessageHeaders, T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
Map from the given MessageHeaders to the specified request target.
fromJson(Object, Class<T>) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
fromJson(Object, Map<String, Object>) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
fromJson(Object, J) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
fromJson(Object, Class<T>) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
fromJson(Object, Map<String, Object>) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
fromJson(Object, Type) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
fromJson(Object, JavaType) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
fromJson(JsonParser, Type) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
fromJson(Object, Class<T>) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
fromJson(Object, Map<String, Object>) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
fromJson(P, Type) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
fromJson(Object, Class<T>) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
fromJson(P, Type) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
fromJson(Object, Map<String, Object>) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.codec.CodecMessageConverter
 
fromMessage(Message<?>) - Method in interface org.springframework.integration.mapping.OutboundMessageMapper
 
fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
 
fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.support.converter.MapMessageConverter
 
fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.support.converter.PassThruMessageConverter
 
fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
fromMessage(Message<T>) - Method in class org.springframework.integration.support.DefaultMessageBuilderFactory
 
fromMessage(Message<?>) - Method in class org.springframework.integration.support.json.JsonOutboundMessageMapper
 
fromMessage(Message<T>) - Static method in class org.springframework.integration.support.MessageBuilder
Create a builder for a new Message instance pre-populated with all of the headers copied from the provided message.
fromMessage(Message<T>) - Method in interface org.springframework.integration.support.MessageBuilderFactory
 
fromMessage(Message<T>) - Static method in class org.springframework.integration.support.MutableMessageBuilder
Create a builder for a new Message instance pre-populated with all of the headers copied from the provided message.
fromMessage(Message<T>) - Method in class org.springframework.integration.support.MutableMessageBuilderFactory
 
Function<T,R> - Interface in org.springframework.integration.util
Implementations of this class perform work on the given parameter and return a result of an optionally different type.
FunctionIterator<T,V> - Class in org.springframework.integration.util
An Iterator implementation to convert each item from the target FunctionIterator.iterator to a new object applying the FunctionIterator.function on FunctionIterator.next().
FunctionIterator(Iterable<T>, Function<? super T, ? extends V>) - Constructor for class org.springframework.integration.util.FunctionIterator
 
FunctionIterator(Iterator<T>, Function<? super T, ? extends V>) - Constructor for class org.springframework.integration.util.FunctionIterator
 

G

Gateway - Annotation Type in org.springframework.integration.annotation
Indicates that an interface method is capable of mapping its parameters to a message or message payload.
GATEWAY_CONVERT_RECEIVE_MESSAGE - Static variable in class org.springframework.integration.context.IntegrationProperties
GatewayCompletableFutureProxyFactoryBean - Class in org.springframework.integration.gateway
A gateway proxy factory that can handle JDK8 CompletableFutures.
GatewayCompletableFutureProxyFactoryBean() - Constructor for class org.springframework.integration.gateway.GatewayCompletableFutureProxyFactoryBean
 
GatewayCompletableFutureProxyFactoryBean(Class<?>) - Constructor for class org.springframework.integration.gateway.GatewayCompletableFutureProxyFactoryBean
 
GatewayHeader - Annotation Type in org.springframework.integration.annotation
Provides the message header value or expression.
GatewayMethodMetadata - Class in org.springframework.integration.gateway
Represents the metadata associated with a Gateway method.
GatewayMethodMetadata() - Constructor for class org.springframework.integration.gateway.GatewayMethodMetadata
 
GatewayParser - Class in org.springframework.integration.config.xml
Parser for the <gateway/> element.
GatewayParser() - Constructor for class org.springframework.integration.config.xml.GatewayParser
 
GatewayProxyFactoryBean - Class in org.springframework.integration.gateway
Generates a proxy for the provided service interface to enable interaction with messaging components without application code being aware of them allowing for POJO-style interaction.
GatewayProxyFactoryBean() - Constructor for class org.springframework.integration.gateway.GatewayProxyFactoryBean
Create a Factory whose service interface type can be configured by setter injection.
GatewayProxyFactoryBean(Class<?>) - Constructor for class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
generateAlias(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
generateBeanName(String, Method, Class<? extends Annotation>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
generateHandlerBeanName(String, Method) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
generateHandlerBeanName(String, Method) - Method in class org.springframework.integration.config.annotation.InboundChannelAdapterAnnotationPostProcessor
 
generateId() - Method in class org.springframework.integration.support.IdGenerators.JdkIdGenerator
 
generateId() - Method in class org.springframework.integration.support.IdGenerators.SimpleIncrementingIdGenerator
 
GenericMessageJacksonDeserializer - Class in org.springframework.integration.support.json
The MessageJacksonDeserializer implementation for the GenericMessage.
GenericMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.GenericMessageJacksonDeserializer
 
GenericSelector<S> - Interface in org.springframework.integration.core
Generic (lambda) strategy interface for selector.
GenericTransformer<S,T> - Interface in org.springframework.integration.transformer
Generic (lambda) strategy interface for transformer.
get(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
Gets the value(Expression) for the provided key from ExpressionEvalMap.original and returns the result of evaluation using ExpressionEvalMap.evaluationCallback.
get(int) - Method in class org.springframework.integration.history.MessageHistory
 
get(String) - Method in interface org.springframework.integration.metadata.MetadataStore
Reads a value for the given key from this MetadataStore.
get(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
get(String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
 
getActiveCount() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getActiveCount() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getActiveCount() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getActiveCount() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getActiveCount() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getActiveCount() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getActiveCount() - Method in interface org.springframework.integration.util.Pool
Returns the number of allocated items that are currently checked out of the pool.
getActiveCount() - Method in class org.springframework.integration.util.SimplePool
 
getActiveCountLong() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getActiveCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getActiveCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getActiveCountLong() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getActiveCountLong() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getAdvice() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
getAdviceChain() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getAdvisedHandler() - Method in interface org.springframework.integration.handler.AbstractReplyProducingMessageHandler.RequestHandler
Utility method, intended for use in message handler advice classes to get information about the advised object.
getAggregatedExceptions() - Method in exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
Obtain a list aggregated target exceptions.
getAllocatedCount() - Method in interface org.springframework.integration.util.Pool
Returns the current count of allocated items (in use and idle).
getAllocatedCount() - Method in class org.springframework.integration.util.SimplePool
 
getAnnotationChain(Method, Class<? extends Annotation>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
getApplicationContext() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getApplicationContext() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getApplicationContextId() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Returns the ApplicationContext.getId() if the ApplicationContext is available.
getArgs() - Method in class org.springframework.integration.gateway.MethodArgsHolder
 
getAsyncExecutor() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getAttributeAccessor(Message<?>, Message<?>) - Static method in class org.springframework.integration.support.ErrorMessageUtils
Return a AttributeAccessor for the provided arguments.
getAttributes() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
Will return an immutable Map of current attributes.
getBeanClass(Object) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
getBeanClass(Element) - Method in class org.springframework.integration.config.xml.SpelFunctionParser
 
getBeanClassLoader() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.SelectorChainParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.SelectorParser
 
getBeanDefinitionBuilderConstructorValue(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
getBeanDefinitionBuilderConstructorValue(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalWireTapParser
 
getBeanFactory() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
getBeanFactory() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
getBeanFactory() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getBeanFactory() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
getCause() - Method in class org.springframework.integration.event.IntegrationEvent
 
getChannel() - Method in class org.springframework.integration.router.RecipientListRouter.Recipient
 
getChannel() - Method in class org.springframework.integration.support.ErrorMessagePublisher
 
getChannelInterceptor() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
getChannelInterceptors() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Return a read-only list of the configured interceptors.
getChannelInterceptors() - Method in interface org.springframework.integration.channel.ChannelInterceptorAware
return the ChannelInterceptor list.
getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Subclasses must implement this method to return the channel keys.
getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.HeaderValueRouter
 
getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.PayloadTypeRouter
Selects the most appropriate channel name matching channel identifiers which are the fully qualified class names encountered while traversing the payload type hierarchy.
getChannelMappings() - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Returns an unmodifiable version of the channel mappings.
getChannelMappings() - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
 
getChannelMappings() - Method in class org.springframework.integration.support.management.RouterMetrics
 
getChannelMetrics(String) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
getChannelName(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
getChannelName(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
getChannelName(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
getChannelNames() - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
getChannelResolver() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getCloseableResource() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
If the payload was created by a Closeable that needs to remain open until the payload is consumed, the resource will be added to this header.
getComponentName() - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
getComponentName() - Method in class org.springframework.integration.channel.NullChannel
 
getComponentName() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Will return the name of this component identified by IntegrationObjectSupport.componentName field.
getComponentName() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getComponentName() - Method in interface org.springframework.integration.support.context.NamedComponent
 
getComponentName() - Method in class org.springframework.integration.support.management.LifecycleTrackableMessageHandlerMetrics
 
getComponentName() - Method in class org.springframework.integration.support.management.LifecycleTrackableMessageSourceMetrics
 
getComponentName() - Method in class org.springframework.integration.support.management.TrackableRouterMetrics
 
getComponentNamePatternsString() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
getComponentType() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
 
getComponentType() - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getComponentType() - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
getComponentType() - Method in class org.springframework.integration.channel.NullChannel
 
getComponentType() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
 
getComponentType() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Subclasses may implement this method to provide component type information.
getComponentType() - Method in class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
 
getComponentType() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
getComponentType() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.filter.MessageFilter
 
getComponentType() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getComponentType() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getComponentType() - Method in class org.springframework.integration.handler.BridgeHandler
 
getComponentType() - Method in class org.springframework.integration.handler.DelayHandler
 
getComponentType() - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.handler.LoggingHandler
 
getComponentType() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
getComponentType() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
getComponentType() - Method in class org.springframework.integration.json.JsonToObjectTransformer
 
getComponentType() - Method in class org.springframework.integration.json.ObjectToJsonTransformer
 
getComponentType() - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
getComponentType() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
getComponentType() - Method in class org.springframework.integration.router.RecipientListRouter
 
getComponentType() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
getComponentType() - Method in interface org.springframework.integration.support.context.NamedComponent
 
getComponentType() - Method in class org.springframework.integration.support.management.graph.IntegrationNode
 
getComponentType() - Method in class org.springframework.integration.support.management.LifecycleTrackableMessageHandlerMetrics
 
getComponentType() - Method in class org.springframework.integration.support.management.LifecycleTrackableMessageSourceMetrics
 
getComponentType() - Method in class org.springframework.integration.support.management.TrackableRouterMetrics
 
getComponentType() - Method in class org.springframework.integration.transformer.ClaimCheckInTransformer
 
getComponentType() - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
 
getComponentType() - Method in class org.springframework.integration.transformer.ContentEnricher
 
getComponentType() - Method in class org.springframework.integration.transformer.HeaderEnricher
 
getComponentType() - Method in class org.springframework.integration.transformer.HeaderFilter
 
getComponentType() - Method in class org.springframework.integration.transformer.MapToObjectTransformer
 
getComponentType() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
getComponentType() - Method in class org.springframework.integration.transformer.ObjectToMapTransformer
 
getComponentType() - Method in class org.springframework.integration.transformer.ObjectToStringTransformer
 
getContentDescriptor() - Method in class org.springframework.integration.support.management.graph.Graph
 
getContext() - Method in class org.springframework.integration.leader.event.AbstractLeaderEvent
Get the Context associated with this event.
getContext() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
getConversionService() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getConversionService(BeanFactory) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
 
getCorrelationId() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getCorrelationId() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getCorrelationId() - Method in class org.springframework.integration.support.MessageBuilder
 
getCorrelationId() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getCorrelationKey(Message<?>) - Method in interface org.springframework.integration.aggregator.CorrelationStrategy
Find the correlation key for the given message.
getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
 
getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.HeaderAttributeCorrelationStrategy
 
getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
getCorrelationStrategy() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getCount() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
getCount() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getCount() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getCount() - Method in class org.springframework.integration.support.management.Statistics
 
getCountLong() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
getCountLong() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getCountLong() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getCountLong() - Method in class org.springframework.integration.support.management.Statistics
 
getDefaultCountsEnabled() - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
getDefaultErrorChannel() - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
Return the default error channel for this error handler.
getDefaultErrorChannel() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Return the default error channel if the error handler is explicitly provided and it is a MessagePublishingErrorHandler.
getDefaultOutputChannel() - Method in class org.springframework.integration.router.AbstractMessageRouter
Get the default output channel.
getDefaultOutputChannel() - Method in interface org.springframework.integration.router.MessageRouter
Get the default output channel.
getDefaultPollerMetadata(BeanFactory) - Static method in class org.springframework.integration.scheduling.PollerMetadata
Return the default PollerMetadata bean if available.
getDefaultStatsEnabled() - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
getDelayedMessageCount() - Method in class org.springframework.integration.handler.DelayHandler
 
getDelayedMessageCount() - Method in interface org.springframework.integration.handler.DelayHandlerManagement
 
getDelegate() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getDelegate() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
getDerivedInput() - Method in exception org.springframework.integration.support.PartialSuccessException
getDerivedInput(Class<T>) - Method in exception org.springframework.integration.support.PartialSuccessException
Convenience version of PartialSuccessException.getDerivedInput() to avoid casting
getDiscardChannel() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getDiscardChannel() - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
 
getDiscardChannel() - Method in class org.springframework.integration.filter.MessageFilter
 
getDiscardChannel() - Method in interface org.springframework.integration.handler.DiscardingMessageHandler
Return the discard channel.
getDiscardChannelName() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getDiscards() - Method in class org.springframework.integration.support.management.graph.DiscardingMessageHandlerNode
 
getDispatcher() - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
getDispatcher() - Method in class org.springframework.integration.channel.DirectChannel
 
getDispatcher() - Method in class org.springframework.integration.channel.ExecutorChannel
 
getDispatcher() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
 
getDuration() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getDuration() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getDuration() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getDuration() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getDuration() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getDuration() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getDynamicChannelNames() - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
 
getDynamicChannelNames() - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
Provide a collection of channel names to which we have routed messages where the channel was not explicitly mapped.
getDynamicChannelNames() - Method in class org.springframework.integration.support.management.RouterMetrics
 
getEndpointsRunningStatus(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Return the running status of each endpoint in the role.
getErrorChannel(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getErrorChannel() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Return the error channel (if provided) to which error messages will be routed.
getErrorChannel() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Return the error channel (if provided) to which error messages will be routed.
getErrorCount() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getErrorCount() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getErrorCount() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getErrorCount() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getErrorCount() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getErrorCount() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getErrorCountLong() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getErrorCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getErrorCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getErrorCountLong() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getErrorCountLong() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getErrorHandler() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Populate an AttributeAccessor to be used when building an error message with the errorMessageStrategy.
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Populate an AttributeAccessor to be used when building an error message with the errorMessageStrategy.
getErrorMessageStrategy() - Method in class org.springframework.integration.support.ErrorMessagePublisher
 
getErrorRate() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getErrorRate() - Method in class org.springframework.integration.channel.NullChannel
 
getErrorRate() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getErrorRate() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getErrorRate() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getErrorRate() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getErrors() - Method in class org.springframework.integration.support.management.graph.ErrorCapableCompositeMessageHandlerNode
 
getErrors() - Method in class org.springframework.integration.support.management.graph.ErrorCapableDiscardingMessageHandlerNode
 
getErrors() - Method in class org.springframework.integration.support.management.graph.ErrorCapableEndpointNode
 
getErrors() - Method in class org.springframework.integration.support.management.graph.ErrorCapableMessageHandlerNode
 
getErrors() - Method in interface org.springframework.integration.support.management.graph.ErrorCapableNode
 
getErrors() - Method in class org.springframework.integration.support.management.graph.ErrorCapableRoutingNode
 
getEvaluationContext() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getEvaluationContext() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
getEvaluationContext(boolean) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
Emits a WARN log if the beanFactory field is null, unless the argument is false.
getEvaluationResult() - Method in exception org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice.MessageHandlingExpressionEvaluatingAdviceException
 
getExpirationDate() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getExpired() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
getExpireGroupScheduledFutures() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getExpression() - Method in interface org.springframework.integration.context.ExpressionCapable
Return the primary SpEL expression if this component is expression-based.
getExpression() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getExpression() - Method in class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
 
getExpression(String, Locale) - Method in interface org.springframework.integration.expression.ExpressionSource
 
getExpression(String, Locale) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Resolves the given key in the retrieved bundle files to an Expression.
getExpressionFor(String) - Static method in class org.springframework.integration.context.IntegrationProperties
Build the bean property definition expression to resolve the value from Integration properties within the bean building phase.
getExpressionString() - Method in class org.springframework.integration.expression.DynamicExpression
 
getExpressionString() - Method in class org.springframework.integration.expression.ValueExpression
 
getExpressionString() - Method in class org.springframework.integration.filter.ExpressionEvaluatingSelector
 
getFirstParameterType() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
getFrom() - Method in class org.springframework.integration.support.management.graph.LinkNode
 
getFullChannelName() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Returns the fully qualified channel name including the application context id, if available.
getFunctionName() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
 
getFunctions() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getGatewayClassName(Element) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
getGateways() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Return the Map of Method to MessagingGatewaySupport generated by this factory bean.
getGraph() - Method in class org.springframework.integration.support.management.graph.IntegrationGraphServer
Return the cached graph.
getGroupId() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
getGroupId() - Method in interface org.springframework.integration.store.MessageGroup
 
getGroupId() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getGroupMetadata(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getGroupMetadata(Object) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getGroupMetadata(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Obtain the group metadata without fetching any messages; must supply all other group properties; may include the id of the first message.
getGroupMetadata(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getGroupPrefix() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Return the configured prefix for message group keys to distinguish between different store instances in the same target key-value data base.
getGroupTimeoutExpression() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getHandleCount() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getHandleCount() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getHandleCount() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getHandleCount() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getHandleCount() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getHandleCount() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getHandleCountLong() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getHandleCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getHandleCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getHandleCountLong() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getHandleCountLong() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getHandler() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
 
getHandler() - Method in interface org.springframework.integration.endpoint.IntegrationConsumer
Return the consumer's handler.
getHandler() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getHandlerCount() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
 
getHandlerIterator(Message<?>, Collection<MessageHandler>) - Method in interface org.springframework.integration.dispatcher.LoadBalancingStrategy
 
getHandlerIterator(Message<?>, Collection<MessageHandler>) - Method in class org.springframework.integration.dispatcher.RoundRobinLoadBalancingStrategy
Returns an iterator that starts at a new point in the collection every time the first part of the list that is skipped will be used at the end of the iteration, so it guarantees all handlers are returned once on subsequent next() invocations.
getHandlerMetrics(String) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
getHandlerNames() - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
getHandlers() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
Returns an unmodifiable Set of this dispatcher's handlers.
getHandlers() - Method in interface org.springframework.integration.handler.CompositeMessageHandler
Return an unmodifiable list of handlers.
getHandlers() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
getHandlers() - Method in class org.springframework.integration.support.management.graph.CompositeMessageHandlerNode
 
getHeader(String, Class<T>) - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getHeader(Map<?, ?>, String) - Static method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
SpEL Function to retrieve a required header.
getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
getHeaderExpressions() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getHeaderIfAvailable(Map<String, Object>, String, Class<V>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
getHeaders() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getHeaders() - Method in class org.springframework.integration.support.MessageBuilder
 
getHeaders() - Method in class org.springframework.integration.support.MutableMessage
 
getHeaders() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getHeaders() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
getHeaderTypes() - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
getId() - Method in class org.springframework.integration.leader.AbstractCandidate
 
getId() - Method in interface org.springframework.integration.leader.Candidate
Gets the identifier.
getIdleCount() - Method in interface org.springframework.integration.util.Pool
Returns the number of items that have been allocated but are not currently in use.
getIdleCount() - Method in class org.springframework.integration.util.SimplePool
 
getInitialDelay() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
getInput() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode
 
getInputChannel() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
 
getInputChannel() - Method in interface org.springframework.integration.endpoint.IntegrationConsumer
Return the input channel.
getInputChannel() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getInputChannelAttribute() - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
getInputChannelAttribute() - Method in class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
 
getInputChannelAttribute() - Method in class org.springframework.integration.config.annotation.InboundChannelAdapterAnnotationPostProcessor
 
getInputChannelAttributeName() - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
getInputMessage() - Method in class org.springframework.integration.message.AdviceMessage
 
getIntegrationProperties(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getIntegrationProperties() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getIntegrationProperty(String, Class<T>) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getInterceptors() - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
getInterceptors() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Exposes the interceptor list for subclasses.
getItem() - Method in interface org.springframework.integration.util.Pool
Obtains an item from the pool.
getItem() - Method in class org.springframework.integration.util.SimplePool
Obtains an item from the pool; waits up to waitTime milliseconds (default infinity).
getLastModified() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
getLastModified() - Method in interface org.springframework.integration.store.MessageGroup
 
getLastModified() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
getLastModified() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getLastReleasedMessageSequenceNumber() - Method in interface org.springframework.integration.store.MessageGroup
 
getLastReleasedMessageSequenceNumber() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
getLastReleasedMessageSequenceNumber() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getLazyLifecycleRoles() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
getLevel() - Method in class org.springframework.integration.handler.LoggingHandler
 
getLinks() - Method in class org.springframework.integration.support.management.graph.Graph
 
getLockRegistry() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getManagedName() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getManagedName() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getManagedName() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getManagedName() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getManagedName() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
getManagedName() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getManagedName() - Method in interface org.springframework.integration.support.management.MessageSourceMetrics
 
getManagedType() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getManagedType() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getManagedType() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getManagedType() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getManagedType() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
getManagedType() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getManagedType() - Method in interface org.springframework.integration.support.management.MessageSourceMetrics
 
getMapper() - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
 
getMappingKeyAttributeName() - Method in class org.springframework.integration.config.xml.AbstractRouterParser
Returns the name of the attribute that provides a key for the channel mappings.
getMappingKeyAttributeName() - Method in class org.springframework.integration.config.xml.ErrorMessageExceptionTypeRouterParser
 
getMappingKeyAttributeName() - Method in class org.springframework.integration.config.xml.PayloadTypeRouterParser
 
getMax() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
getMax() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getMax() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getMax() - Method in class org.springframework.integration.support.management.Statistics
 
getMaxDuration() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getMaxDuration() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getMaxDuration() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getMaxDuration() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getMaxDuration() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getMaxDuration() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getMaxMessagesPerPoll() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getMaxSendDuration() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMaxSendDuration() - Method in class org.springframework.integration.channel.NullChannel
 
getMaxSendDuration() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getMaxSendDuration() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getMaxSendDuration() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getMaxSendDuration() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getMean() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
getMean() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getMean() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getMean() - Method in class org.springframework.integration.support.management.Statistics
 
getMeanDuration() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getMeanDuration() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getMeanDuration() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getMeanDuration() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getMeanDuration() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getMeanDuration() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getMeanErrorRate() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMeanErrorRate() - Method in class org.springframework.integration.channel.NullChannel
 
getMeanErrorRate() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getMeanErrorRate() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getMeanErrorRate() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getMeanErrorRate() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getMeanErrorRatio() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMeanErrorRatio() - Method in class org.springframework.integration.channel.NullChannel
 
getMeanErrorRatio() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getMeanErrorRatio() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getMeanErrorRatio() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getMeanErrorRatio() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getMeanSendDuration() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMeanSendDuration() - Method in class org.springframework.integration.channel.NullChannel
 
getMeanSendDuration() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getMeanSendDuration() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getMeanSendDuration() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getMeanSendDuration() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getMeanSendRate() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMeanSendRate() - Method in class org.springframework.integration.channel.NullChannel
 
getMeanSendRate() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getMeanSendRate() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getMeanSendRate() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getMeanSendRate() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getMessage() - Method in exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
 
getMessage(UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessage(UUID) - Method in interface org.springframework.integration.store.MessageStore
 
getMessage(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessage() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
 
getMessage() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
getMessageBuilderFactory() - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
getMessageBuilderFactory() - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
getMessageBuilderFactory() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getMessageBuilderFactory() - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
getMessageBuilderFactory() - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
 
getMessageBuilderFactory() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getMessageBuilderFactory() - Method in class org.springframework.integration.support.converter.MapMessageConverter
 
getMessageBuilderFactory() - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
getMessageBuilderFactory(BeanFactory) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
Returns the context-wide `messageBuilderFactory` bean from the beanFactory, or a DefaultMessageBuilderFactory if not found or the beanFactory is null.
getMessageBuilderFactory() - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
getMessageBuilderFactory() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
getMessageCount() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
getMessageCount() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getMessageCount() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getMessageCount() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessageCount() - Method in interface org.springframework.integration.store.MessageStore
Optional attribute giving the number of messages in the store.
getMessageCount() - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessageCount() - Method in class org.springframework.integration.support.management.graph.MessageSourceNode.Stats
 
getMessageCount() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
getMessageCount() - Method in interface org.springframework.integration.support.management.MessageSourceMetrics
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getMessageCountForAllMessageGroups() - Method in interface org.springframework.integration.store.MessageGroupStore
Optional attribute giving the number of messages in the store over all groups.
getMessageCountLong() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getMessageCountLong() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getMessageCountLong() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
getMessageCountLong() - Method in interface org.springframework.integration.support.management.MessageSourceMetrics
 
getMessageGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Will create a new instance of SimpleMessageGroup if necessary.
getMessageGroup(Object) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
Return all Messages currently in the MessageStore that were stored using BasicMessageGroupStore.addMessageToGroup(Object, Message) with this group id.
getMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getMessageGroupCount() - Method in interface org.springframework.integration.store.MessageGroupStore
Optional attribute giving the number of message groups.
getMessageGroupFactory() - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
 
getMessageGroupFactory() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getMessageIds() - Method in class org.springframework.integration.store.MessageGroupMetadata
Obtain a LinkedList copy of the MessageGroupMetadata.messageIds stored in the group.
getMessagePrefix() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Return the configured prefix for message keys to distinguish between different store instances in the same target key-value data base.
getMessages() - Method in interface org.springframework.integration.store.MessageGroup
Returns all available Messages from the group at the time of invocation
getMessages() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getMessages() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
getMessagesForGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessagesForGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Retrieve messages for the provided group id.
getMessagesForGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessageSource() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Return this endpoint's source.
getMessageStore() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getMessagingTemplate() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
getMessagingTemplate() - Method in class org.springframework.integration.router.AbstractMessageRouter
Provides MessagingTemplate access for subclasses
getMetadataStore(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getMethod() - Method in class org.springframework.integration.gateway.MethodArgsHolder
 
getMetrics() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMin() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
getMin() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getMin() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getMin() - Method in class org.springframework.integration.support.management.Statistics
 
getMinDuration() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getMinDuration() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getMinDuration() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getMinDuration() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getMinDuration() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getMinDuration() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getMinimumTimeoutForEmptyGroups() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getMinSendDuration() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMinSendDuration() - Method in class org.springframework.integration.channel.NullChannel
 
getMinSendDuration() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getMinSendDuration() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getMinSendDuration() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getMinSendDuration() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getName() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
getName() - Method in class org.springframework.integration.support.management.graph.CompositeMessageHandlerNode.InnerHandler
 
getName() - Method in class org.springframework.integration.support.management.graph.IntegrationNode
 
getNextPath(Message<?>, Object) - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
getNextPath(Message<?>, Object) - Method in interface org.springframework.integration.routingslip.RoutingSlipRouteStrategy
Get the next path for this routing slip.
getNodeId() - Method in class org.springframework.integration.support.management.graph.IntegrationNode
 
getNodes() - Method in class org.springframework.integration.support.management.graph.Graph
 
getNotPropagatedHeaders() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Get the header names this handler doesn't propagate.
getNotPropagatedHeaders() - Method in interface org.springframework.integration.handler.HeaderPropagationAware
Get the header names this handler doesn't propagate.
getObject() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
getObject() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
getObject() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
getObject() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
 
getObject() - Method in class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
 
getObject() - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
getObject() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
getObject() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
 
getObject() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getObject() - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.ExpressionFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
 
getObjectType() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getObjectType() - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
getOne() - Method in interface org.springframework.integration.store.MessageGroup
 
getOne() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getOneMessageFromGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Return the one Message from MessageGroup.
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getOrder() - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
getOrder() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
getOrder() - Method in class org.springframework.integration.expression.IntegrationEvaluationContextAwareBeanPostProcessor
Deprecated.
 
getOrder() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getOriginal() - Method in class org.springframework.integration.handler.DelayHandler.DelayedMessageWrapper
 
getOriginalMessage() - Method in class org.springframework.integration.message.EnhancedErrorMessage
Deprecated.
 
getOutput() - Method in class org.springframework.integration.support.management.graph.EndpointNode
 
getOutputChannel() - Method in interface org.springframework.integration.core.MessageProducer
Return the the output channel.
getOutputChannel() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
 
getOutputChannel() - Method in interface org.springframework.integration.endpoint.IntegrationConsumer
Return the output channel (may be null).
getOutputChannel() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
getOutputChannel() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getOutputChannel() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getOutputChannel() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
getOutputProcessor() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getPartialResults() - Method in exception org.springframework.integration.support.PartialSuccessException
getPartialResults(Class<T>) - Method in exception org.springframework.integration.support.PartialSuccessException
Convenience version of PartialSuccessException.getPartialResults() to avoid casting
getPatterns() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
getPayload() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getPayload() - Method in class org.springframework.integration.support.MessageBuilder
 
getPayload() - Method in class org.springframework.integration.support.MutableMessage
 
getPayload() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getPayload() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
getPayloadExpression(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
getPayloadExpression(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
getPayloadExpression(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
getPayloadExpression() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getPayloadType() - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
getPeriod() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
getPhase() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
getPhase() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
getPhase() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
getPhase() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
getPhase() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
getPhase() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
getPointcut() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
getPoolSize() - Method in interface org.springframework.integration.util.Pool
Returns the current size (limit) of the pool.
getPoolSize() - Method in class org.springframework.integration.util.SimplePool
Returns the current size of the pool; may be greater than the target pool size if it was recently reduced and too many items were in use to allow the new size to be set.
getPostProcessors() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Subclasses can override this to return a more specific type before handler creation.
getPreCreationHandlerType() - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.FilterFactoryBean
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.RouterFactoryBean
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.SplitterFactoryBean
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.TransformerFactoryBean
 
getPriority() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getProperties() - Method in class org.springframework.integration.support.management.graph.IntegrationNode
 
getPropertyAccessors() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getPropertyAccessors() - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
Return the registered accessors.
getQueueSize() - Method in class org.springframework.integration.channel.QueueChannel
 
getQueueSize() - Method in interface org.springframework.integration.channel.QueueChannelOperations
 
getQueueSize() - Method in interface org.springframework.integration.support.management.QueueChannelManagement
 
getRawHeaders() - Method in class org.springframework.integration.support.MutableMessageHeaders
 
getReaperDelay() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
getReceiveCount() - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
getReceiveCount() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getReceiveCount() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getReceiveCount() - Method in interface org.springframework.integration.support.management.PollableChannelManagement
 
getReceiveCountLong() - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
getReceiveCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getReceiveCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getReceiveCountLong() - Method in interface org.springframework.integration.support.management.PollableChannelManagement
 
getReceiveErrorCount() - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
getReceiveErrorCount() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getReceiveErrorCount() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getReceiveErrorCount() - Method in interface org.springframework.integration.support.management.PollableChannelManagement
 
getReceiveErrorCountLong() - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
getReceiveErrorCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getReceiveErrorCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getReceiveErrorCountLong() - Method in interface org.springframework.integration.support.management.PollableChannelManagement
 
getReceiveTimeout() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getRecipients() - Method in class org.springframework.integration.router.RecipientListRouter
 
getRecipients() - Method in interface org.springframework.integration.router.RecipientListRouterManagement
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
Subclasses implement this to get provided registrations.
getRegistrations() - Method in class org.springframework.integration.codec.kryo.CompositeKryoRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.FileKryoRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.KryoClassListRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.KryoClassMapRegistrar
 
getRegistrations() - Method in interface org.springframework.integration.codec.kryo.KryoRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.KryoRegistrationRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
 
getReleaseStrategy() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getRemainingCapacity() - Method in class org.springframework.integration.channel.PriorityChannel
 
getRemainingCapacity() - Method in class org.springframework.integration.channel.QueueChannel
 
getRemainingCapacity() - Method in interface org.springframework.integration.channel.QueueChannelOperations
 
getRemainingCapacity() - Method in interface org.springframework.integration.support.management.QueueChannelManagement
 
getRemoveBatchSize() - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
 
getReply() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy.RequestAndReply
 
getReplyChannel() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getReplyChannelName() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getReplyTimeout() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getRequest() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy.RequestAndReply
 
getRequestChannel() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Return this gateway's request channel.
getRequestChannelName() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getRequestDate() - Method in class org.springframework.integration.handler.DelayHandler.DelayedMessageWrapper
 
getRequestTimeout() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getRequiredConversionService() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
getRequiredTaskScheduler(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getRequiresReply() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
getResourceHolder() - Method in class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
 
getResourceKey() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Return the key under which the resource will be made available as an attribute on the IntegrationResourceHolder.
getResourceKey() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getResourceKey() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getResourceToBind() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Return a resource (MessageSource etc) to bind when using transaction synchronization.
getResourceToBind() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getResourceToBind() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getRole() - Method in class org.springframework.integration.leader.AbstractCandidate
 
getRole() - Method in interface org.springframework.integration.leader.Candidate
Gets the role.
getRole() - Method in class org.springframework.integration.leader.event.AbstractLeaderEvent
Get the role of the leader.
getRoles() - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Return a collection of the roles currently managed by this controller.
getRoutes() - Method in class org.springframework.integration.support.management.graph.RoutingMessageHandlerNode
 
getSendCount() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getSendCount() - Method in class org.springframework.integration.channel.NullChannel
 
getSendCount() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getSendCount() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getSendCount() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getSendCount() - Method in class org.springframework.integration.support.management.graph.MessageGatewayNode.Stats
 
getSendCount() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getSendCountLong() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getSendCountLong() - Method in class org.springframework.integration.channel.NullChannel
 
getSendCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getSendCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getSendCountLong() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getSendDuration() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getSendDuration() - Method in class org.springframework.integration.channel.NullChannel
 
getSendDuration() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getSendDuration() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getSendDuration() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getSendDuration() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getSendErrorCount() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getSendErrorCount() - Method in class org.springframework.integration.channel.NullChannel
 
getSendErrorCount() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getSendErrorCount() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getSendErrorCount() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getSendErrorCount() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getSendErrorCountLong() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getSendErrorCountLong() - Method in class org.springframework.integration.channel.NullChannel
 
getSendErrorCountLong() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getSendErrorCountLong() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getSendErrorCountLong() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getSendRate() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getSendRate() - Method in class org.springframework.integration.channel.NullChannel
 
getSendRate() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getSendRate() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getSendRate() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getSendRate() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getSendTimeout() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getSequenceDetails() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getSequenceDetails() - Method in class org.springframework.integration.support.MessageBuilder
 
getSequenceDetails() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getSequenceNumber() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getSequenceNumber() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getSequenceNumber() - Method in class org.springframework.integration.support.MessageBuilder
 
getSequenceNumber() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getSequenceSize() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getSequenceSize() - Method in interface org.springframework.integration.store.MessageGroup
 
getSequenceSize() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getSequenceSize() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getSequenceSize() - Method in class org.springframework.integration.support.MessageBuilder
 
getSequenceSize() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getSimpleEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getSize() - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
getSourceMetrics(String) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
getSourceNames() - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
getSpecificTargetClasses() - Method in class org.springframework.integration.json.JsonPropertyAccessor
 
getStandardDeviation() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
getStandardDeviation() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getStandardDeviation() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getStandardDeviation() - Method in class org.springframework.integration.support.management.Statistics
 
getStandardDeviationDuration() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getStandardDeviationDuration() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
getStandardDeviationDuration() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
getStandardDeviationDuration() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
getStandardDeviationDuration() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
getStandardDeviationDuration() - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
getStandardDeviationSendDuration() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getStandardDeviationSendDuration() - Method in class org.springframework.integration.channel.NullChannel
 
getStandardDeviationSendDuration() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getStandardDeviationSendDuration() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getStandardDeviationSendDuration() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getStandardDeviationSendDuration() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getStatistics() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
getStatistics() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getStatistics() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getStats() - Method in class org.springframework.integration.support.management.graph.IntegrationNode
 
getSubscriberCount() - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
getSubscriberCount() - Method in interface org.springframework.integration.support.management.SubscribableChannelManagement
The number of message handlers currently subscribed to this channel.
getTaskExecutor() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getTaskScheduler(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getTaskScheduler() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getTextFromAttributeOrNestedElement(Element, String, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Get a text value from a named attribute if it exists, otherwise check for a nested element of the same name.
getTimeSinceLastMeasurement() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
getTimeSinceLastMeasurement() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
getTimeSinceLastSend() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getTimeSinceLastSend() - Method in class org.springframework.integration.channel.NullChannel
 
getTimeSinceLastSend() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
getTimeSinceLastSend() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
getTimeSinceLastSend() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
getTimeSinceLastSend() - Method in interface org.springframework.integration.support.management.MessageChannelMetrics
 
getTimestamp() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
getTimestamp() - Method in interface org.springframework.integration.store.MessageGroup
 
getTimestamp() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
getTimestamp() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getTimeUnit() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
getTo() - Method in class org.springframework.integration.support.management.graph.LinkNode
 
getTransactionSynchronizationFactory() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.AbstractTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ClaimCheckInParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ClaimCheckOutParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.HeaderFilterParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.JsonToObjectTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.MapToObjectTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ObjectToMapTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ObjectToStringTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.PayloadDeserializingTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.PayloadSerializingTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.StreamTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.SyslogToMapTransformerParser
 
getTransformOnSend() - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
Deprecated.
 
getTransientHeaderNames() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Return the transient header names.
getTrigger() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getType() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
getType() - Method in class org.springframework.integration.support.management.graph.CompositeMessageHandlerNode.InnerHandler
 
getType() - Method in class org.springframework.integration.support.management.graph.LinkNode
 
getTypeConverter() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getUUID(Object) - Static method in class org.springframework.integration.util.UUIDConverter
Convenient utility to convert an object to a UUID.
getValue() - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(Object, Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(EvaluationContext, Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(EvaluationContext, Object, Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue() - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(EvaluationContext) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(Object, Class<T>) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(Class<T>) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(EvaluationContext, Object, Class<T>) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(EvaluationContext, Class<T>) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueType() - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueType(Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueType(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueType(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueType() - Method in class org.springframework.integration.expression.ValueExpression
 
getValueType(Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueType(EvaluationContext) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueType(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueTypeDescriptor() - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueTypeDescriptor(Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueTypeDescriptor() - Method in class org.springframework.integration.expression.ValueExpression
 
getValueTypeDescriptor(Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
GLOBAL_CHANNEL_INTERCEPTOR_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
GlobalChannelInterceptor - Annotation Type in org.springframework.integration.config
ChannelInterceptor components with this annotation will be applied as global channel interceptors using the provided patterns to match channel names.
GlobalChannelInterceptorInitializer - Class in org.springframework.integration.config
The IntegrationConfigurationInitializer to populate GlobalChannelInterceptorWrapper for ChannelInterceptors marked with GlobalChannelInterceptor annotation.
GlobalChannelInterceptorInitializer() - Constructor for class org.springframework.integration.config.GlobalChannelInterceptorInitializer
 
GlobalChannelInterceptorParser - Class in org.springframework.integration.config.xml
Parser for 'channel-interceptor' elements.
GlobalChannelInterceptorParser() - Constructor for class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
GlobalChannelInterceptorProcessor - Class in org.springframework.integration.config
This class applies global interceptors (<channel-interceptor> or @GlobalChannelInterceptor) to message channels beans.
GlobalChannelInterceptorProcessor() - Constructor for class org.springframework.integration.config.GlobalChannelInterceptorProcessor
 
GlobalChannelInterceptorWrapper - Class in org.springframework.integration.channel.interceptor
 
GlobalChannelInterceptorWrapper(ChannelInterceptor) - Constructor for class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
GlobalWireTapParser - Class in org.springframework.integration.config.xml
Parser for the top level 'wire-tap' element
GlobalWireTapParser() - Constructor for class org.springframework.integration.config.xml.GlobalWireTapParser
 
Graph - Class in org.springframework.integration.support.management.graph
This object can be exposed, for example, as a JSON object over HTTP.
Graph(Map<String, Object>, Collection<IntegrationNode>, Collection<LinkNode>) - Constructor for class org.springframework.integration.support.management.graph.Graph
 

H

handleCount - Variable in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
handleError(Throwable) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
handleMessage(Message<?>) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Handle a message.
handleMessage(Message<?>) - Method in class org.springframework.integration.endpoint.PollingConsumer
 
handleMessage(Message<?>) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
handleMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
HandleMessageAdvice - Interface in org.springframework.integration.handler.advice
The marker MethodInterceptor interface extension to distinguish advices for some reason.
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.LoggingHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
handleMessageInternal(Message<?>) - Method in class org.springframework.integration.router.AbstractMessageRouter
 
HANDLER_ALIAS_SUFFIX - Static variable in class org.springframework.integration.config.IntegrationConfigUtils
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
Subclasses must implement this method to handle the request Message.
handleRequestMessage(Message<?>) - Method in interface org.springframework.integration.handler.AbstractReplyProducingMessageHandler.RequestHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.BridgeHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.DelayHandler
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.transformer.ContentEnricher
 
handleRequestMessage(Message<?>) - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
hasAdviceChain() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
hasExecutorInterceptors() - Method in class org.springframework.integration.channel.AbstractExecutorChannel
 
hasExecutorInterceptors() - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
hasExecutorInterceptors() - Method in interface org.springframework.integration.channel.ExecutorChannelInterceptorAware
 
hashCode() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
hashCode() - Method in class org.springframework.integration.handler.DelayHandler.DelayedMessageWrapper
 
hashCode() - Method in class org.springframework.integration.json.JsonPropertyAccessor.ToStringFriendlyJsonNode
 
hashCode() - Method in class org.springframework.integration.support.MutableMessage
 
hashCode() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
hasNext() - Method in class org.springframework.integration.util.FunctionIterator
 
hasValue(Object) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
 
Header - Annotation Type in org.springframework.integration.annotation
Deprecated.
since 4.1 in favor of Header. Will be removed in a future release.
HEADER_NAME - Static variable in class org.springframework.integration.history.MessageHistory
 
HeaderAttributeCorrelationStrategy - Class in org.springframework.integration.aggregator
Default implementation of CorrelationStrategy.
HeaderAttributeCorrelationStrategy(String) - Constructor for class org.springframework.integration.aggregator.HeaderAttributeCorrelationStrategy
 
HeaderChannelRegistry - Interface in org.springframework.integration.support.channel
Implementations convert a channel to a name, retaining a reference to the channel keyed by the name.
HeaderEnricher - Class in org.springframework.integration.transformer
A Transformer that adds statically configured header values to a Message.
HeaderEnricher() - Constructor for class org.springframework.integration.transformer.HeaderEnricher
 
HeaderEnricher(Map<String, ? extends HeaderValueMessageProcessor<?>>) - Constructor for class org.springframework.integration.transformer.HeaderEnricher
Create a HeaderEnricher with the given map of headers.
HeaderEnricherParserSupport - Class in org.springframework.integration.config.xml
Base support class for 'header-enricher' parsers.
HeaderEnricherParserSupport() - Constructor for class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
HeaderFilter - Class in org.springframework.integration.transformer
Transformer that removes Message headers.
HeaderFilter(String...) - Constructor for class org.springframework.integration.transformer.HeaderFilter
 
HeaderFilterParser - Class in org.springframework.integration.config.xml
Parser for the 'header-filter' element.
HeaderFilterParser() - Constructor for class org.springframework.integration.config.xml.HeaderFilterParser
 
HeaderMapper<T> - Interface in org.springframework.integration.mapping
Generic strategy interface for mapping MessageHeaders to and from other types of objects.
HeaderPropagationAware - Interface in org.springframework.integration.handler
MessageHandlers implementing this interface can propagate headers from an input message to an output message.
Headers - Annotation Type in org.springframework.integration.annotation
Deprecated.
since 4.1 in favor of Headers. Will be removed in a future release.
HEADERS - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
 
headerTypes - Variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
HeaderValueMessageProcessor<T> - Interface in org.springframework.integration.transformer.support
 
HeaderValueRouter - Class in org.springframework.integration.router
A Message Router that resolves the MessageChannel from a header value.
HeaderValueRouter(String) - Constructor for class org.springframework.integration.router.HeaderValueRouter
Create a router that uses the provided header name to lookup a channel.
HeaderValueRouterParser - Class in org.springframework.integration.config.xml
Parser for the <header-value-router/> element.
HeaderValueRouterParser() - Constructor for class org.springframework.integration.config.xml.HeaderValueRouterParser
 
HistoryWritingMessagePostProcessor - Class in org.springframework.integration.history
 
HistoryWritingMessagePostProcessor() - Constructor for class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
HistoryWritingMessagePostProcessor(TrackableComponent) - Constructor for class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
HOST - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 

I

id - Static variable in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
IDEMPOTENT_ENDPOINTS_MAPPING - Static variable in class org.springframework.integration.config.IdempotentReceiverAutoProxyCreatorInitializer
 
IdempotentReceiver - Annotation Type in org.springframework.integration.annotation
A method that has a MessagingAnnotation (@code @ServiceActivator, @Router etc.) that also has this annotation, has an IdempotentReceiverInterceptor applied to the associated MessageHandler.handleMessage(org.springframework.messaging.Message<?>) method.
IdempotentReceiverAutoProxyCreatorInitializer - Class in org.springframework.integration.config
The IntegrationConfigurationInitializer that populates the ConfigurableListableBeanFactory with an IdempotentReceiverAutoProxyCreator when IdempotentReceiverInterceptor BeanDefinitions and their mapping to Consumer Endpoints are present.
IdempotentReceiverAutoProxyCreatorInitializer() - Constructor for class org.springframework.integration.config.IdempotentReceiverAutoProxyCreatorInitializer
 
IdempotentReceiverInterceptor - Class in org.springframework.integration.handler.advice
The MethodInterceptor implementation for the Idempotent Receiver E.I.
IdempotentReceiverInterceptor(MessageSelector) - Constructor for class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
 
IdempotentReceiverInterceptorParser - Class in org.springframework.integration.config.xml
Parser for the <idempotent-receiver/> element.
IdempotentReceiverInterceptorParser() - Constructor for class org.springframework.integration.config.xml.IdempotentReceiverInterceptorParser
 
IdGeneratorConfigurer - Class in org.springframework.integration.config
 
IdGeneratorConfigurer() - Constructor for class org.springframework.integration.config.IdGeneratorConfigurer
 
IdGenerators - Class in org.springframework.integration.support
Alternative IdGenerator implementations.
IdGenerators() - Constructor for class org.springframework.integration.support.IdGenerators
 
IdGenerators.JdkIdGenerator - Class in org.springframework.integration.support
UUID.randomUUID()
IdGenerators.SimpleIncrementingIdGenerator - Class in org.springframework.integration.support
Based on the two AtomicLongs, for topBits and bottomBits, respectively.
InboundChannelAdapter - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of producing a Message or Message payload.
InboundChannelAdapterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @InboundChannelAdapter.
InboundChannelAdapterAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.InboundChannelAdapterAnnotationPostProcessor
 
InboundMessageMapper<T> - Interface in org.springframework.integration.mapping
Strategy interface for mapping from an Object to aMessage.
increment() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
Add a new event to the series.
increment(long) - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
Add a new event to the series at time t.
indexOf(Object) - Method in class org.springframework.integration.history.MessageHistory
 
init() - Method in class org.springframework.integration.config.xml.IntegrationNamespaceHandler
 
initialize(String) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.GlobalChannelInterceptorInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.IdempotentReceiverAutoProxyCreatorInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in interface org.springframework.integration.config.IntegrationConfigurationInitializer
 
initialize(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.IntegrationConverterInitializer
 
injectConstructorWithAdapter(String, String, String, String, Element, BeanDefinitionBuilder, BeanMetadataElement, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
injectPropertyWithAdapter(String, String, String, String, String, Element, BeanDefinitionBuilder, BeanMetadataElement, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
InnerHandler(String, String) - Constructor for class org.springframework.integration.support.management.graph.CompositeMessageHandlerNode.InnerHandler
 
INPUT_CHANNEL - Static variable in class org.springframework.integration.transaction.IntegrationResourceHolder
 
INPUT_MESSAGE_CONTEXT_KEY - Static variable in class org.springframework.integration.support.ErrorMessageUtils
The context key for the message object.
INTEGRATION_CONFIGURATION_POST_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_CONVERSION_SERVICE_BEAN_NAME - Static variable in class org.springframework.integration.support.utils.IntegrationUtils
 
INTEGRATION_DATATYPE_CHANNEL_MESSAGE_CONVERTER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_EVALUATION_CONTEXT_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_FIXED_SUBSCRIBER_CHANNEL_BPP_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_GLOBAL_PROPERTIES_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_GRAPH_SERVER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_HEADER_CHANNEL_REGISTRY_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_LIFECYCLE_ROLE_CONTROLLER - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_MESSAGE_BUILDER_FACTORY_BEAN_NAME - Static variable in class org.springframework.integration.support.utils.IntegrationUtils
 
INTEGRATION_MESSAGE_HISTORY_CONFIGURER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
INTEGRATION_PROPERTIES_PREFIX - Static variable in class org.springframework.integration.context.IntegrationProperties
 
INTEGRATION_SIMPLE_EVALUATION_CONTEXT_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
IntegrationComponentScan - Annotation Type in org.springframework.integration.annotation
Configures component scanning directives for use with Configuration classes.
IntegrationComponentScanRegistrar - Class in org.springframework.integration.config
ImportBeanDefinitionRegistrar implementation to scan and register Integration specific components.
IntegrationComponentScanRegistrar() - Constructor for class org.springframework.integration.config.IntegrationComponentScanRegistrar
 
IntegrationConfigurationBeanFactoryPostProcessor - Class in org.springframework.integration.config
BeanFactoryPostProcessor to apply external Integration infrastructure configurations via loading IntegrationConfigurationInitializer implementations using SpringFactoriesLoader.
IntegrationConfigurationBeanFactoryPostProcessor() - Constructor for class org.springframework.integration.config.IntegrationConfigurationBeanFactoryPostProcessor
 
IntegrationConfigurationInitializer - Interface in org.springframework.integration.config
The strategy to initialize the external Integration infrastructure (@{code BeanFactoryPostProcessor}s, global beans etc.) in the provided beanFactory.
IntegrationConfigUtils - Class in org.springframework.integration.config
Shared utility methods for Integration configuration.
IntegrationConsumer - Interface in org.springframework.integration.endpoint
Message consumers implement this interface, the message handler within a consumer may or may not emit output messages.
IntegrationContextUtils - Class in org.springframework.integration.context
Utility methods for accessing common integration components from the BeanFactory.
IntegrationContextUtils() - Constructor for class org.springframework.integration.context.IntegrationContextUtils
 
IntegrationConverter - Annotation Type in org.springframework.integration.config
A marker annotation (an analogue of <int:converter/>) to register Converter, GenericConverter or ConverterFactory beans for the integrationConversionService.
IntegrationConverterInitializer - Class in org.springframework.integration.config
 
IntegrationConverterInitializer() - Constructor for class org.springframework.integration.config.IntegrationConverterInitializer
 
IntegrationEvaluationContextAware - Interface in org.springframework.integration.expression
Deprecated.
since 4.2 in favor of IntegrationContextUtils.getEvaluationContext(org.springframework.beans.factory.BeanFactory) direct usage from the afterPropertiesSet implementation. Will be removed in the next release.
IntegrationEvaluationContextAwareBeanPostProcessor - Class in org.springframework.integration.expression
Deprecated.
since 4.2 in favor of IntegrationContextUtils.getEvaluationContext(org.springframework.beans.factory.BeanFactory) direct usage from the afterPropertiesSet implementation. Will be removed in the next release.
IntegrationEvaluationContextAwareBeanPostProcessor() - Constructor for class org.springframework.integration.expression.IntegrationEvaluationContextAwareBeanPostProcessor
Deprecated.
 
IntegrationEvaluationContextFactoryBean - Class in org.springframework.integration.config
FactoryBean to populate StandardEvaluationContext instances enhanced with: a BeanFactoryResolver.
IntegrationEvaluationContextFactoryBean() - Constructor for class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
 
IntegrationEvent - Class in org.springframework.integration.event
Base class for all ApplicationEvents generated by the framework.
IntegrationEvent(Object) - Constructor for class org.springframework.integration.event.IntegrationEvent
 
IntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.event.IntegrationEvent
 
IntegrationGraphServer - Class in org.springframework.integration.support.management.graph
Builds the runtime object model graph.
IntegrationGraphServer() - Constructor for class org.springframework.integration.support.management.graph.IntegrationGraphServer
 
IntegrationManagedResource - Annotation Type in org.springframework.integration.support.management
Clone of ManagedResource limiting beans thus annotated so that they will only be exported by the IntegrationMBeanExporter and prevented from being exported by other MBeanExporters (if present).
IntegrationManagement - Interface in org.springframework.integration.support.management
Base interface for Integration managed components.
IntegrationManagementConfiguration - Class in org.springframework.integration.config
@Configuration class that registers a IntegrationManagementConfigurer bean.
IntegrationManagementConfiguration() - Constructor for class org.springframework.integration.config.IntegrationManagementConfiguration
 
IntegrationManagementConfigurer - Class in org.springframework.integration.support.management
Configures beans that implement IntegrationManagement.
IntegrationManagementConfigurer() - Constructor for class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
IntegrationManagementParser - Class in org.springframework.integration.config.xml
Parser for the <management/> element.
IntegrationManagementParser() - Constructor for class org.springframework.integration.config.xml.IntegrationManagementParser
 
IntegrationMessageHeaderAccessor - Class in org.springframework.integration
Adds standard SI Headers.
IntegrationMessageHeaderAccessor(Message<?>) - Constructor for class org.springframework.integration.IntegrationMessageHeaderAccessor
 
IntegrationNamespaceHandler - Class in org.springframework.integration.config.xml
Namespace handler for the integration namespace.
IntegrationNamespaceHandler() - Constructor for class org.springframework.integration.config.xml.IntegrationNamespaceHandler
 
IntegrationNamespaceUtils - Class in org.springframework.integration.config.xml
Shared utility methods for integration namespace parsers.
IntegrationNamespaceUtils() - Constructor for class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
IntegrationNode - Class in org.springframework.integration.support.management.graph
Base class for all nodes.
IntegrationNode(int, String, Object, IntegrationNode.Stats) - Constructor for class org.springframework.integration.support.management.graph.IntegrationNode
 
IntegrationNode.Stats - Class in org.springframework.integration.support.management.graph
 
IntegrationObjectSupport - Class in org.springframework.integration.context
A base class that provides convenient access to the bean factory as well as TaskScheduler and ConversionService instances.
IntegrationObjectSupport() - Constructor for class org.springframework.integration.context.IntegrationObjectSupport
 
IntegrationProperties - Class in org.springframework.integration.context
Utility class to encapsulate infrastructure Integration properties constants and their default values from resources 'META-INF/spring.integration.default.properties'.
IntegrationRegistrar - Class in org.springframework.integration.config
ImportBeanDefinitionRegistrar implementation that configures integration infrastructure.
IntegrationRegistrar() - Constructor for class org.springframework.integration.config.IntegrationRegistrar
 
IntegrationResourceHolder - Class in org.springframework.integration.transaction
An implementation of the ResourceHolder which holds an instance of the current Message and the synchronization resource
IntegrationResourceHolder() - Constructor for class org.springframework.integration.transaction.IntegrationResourceHolder
 
IntegrationResourceHolderSynchronization - Class in org.springframework.integration.transaction
The base ResourceHolderSynchronization for IntegrationResourceHolder.
IntegrationResourceHolderSynchronization(IntegrationResourceHolder, Object) - Constructor for class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
 
IntegrationSimpleEvaluationContextFactoryBean - Class in org.springframework.integration.config
FactoryBean to populate SimpleEvaluationContext instances enhanced with: a TypeConverter based on the ConversionService from the application context.
IntegrationSimpleEvaluationContextFactoryBean() - Constructor for class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
 
IntegrationStatsManagement - Interface in org.springframework.integration.support.management
Base interface containing methods to control complete statistics gathering.
IntegrationUtils - Class in org.springframework.integration.support.utils
General utility methods.
interceptors - Variable in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
interceptors - Variable in class org.springframework.integration.channel.AbstractMessageChannel
 
invoke(MethodInvocation) - Method in class org.springframework.integration.aop.AbstractMessageSourceAdvice
 
invoke(MethodInvocation) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
invoke(MethodInvocation) - Method in class org.springframework.integration.gateway.GatewayCompletableFutureProxyFactoryBean
 
invoke(MethodInvocation) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
invoke(MethodInvocation) - Method in class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
 
invoke(MethodInvocation) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
 
invoke(MethodInvocation) - Method in class org.springframework.integration.scheduling.PollSkipAdvice
 
isAsync() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
isAutoStartup() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
isAutoStartup() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
isAutoStartup() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
isAutoStartup() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
isAutoStartup() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
isAvailable() - Method in class org.springframework.integration.support.management.graph.IntegrationNode.Stats
 
isAvailable() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
isAvailable() - Method in class org.springframework.integration.support.management.graph.MessageGatewayNode.Stats
 
isAvailable() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
isAvailable() - Method in class org.springframework.integration.support.management.graph.MessageSourceNode.Stats
 
isComplete() - Method in interface org.springframework.integration.store.MessageGroup
 
isComplete() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
isComplete() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
isCountsEnabled() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
isCountsEnabled() - Method in class org.springframework.integration.channel.NullChannel
 
isCountsEnabled() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
isCountsEnabled() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
isCountsEnabled() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
isCountsEnabled() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
isCountsEnabled() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
isCountsEnabled() - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
isCountsEnabled() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
isCountsEnabled() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
isDiscarded() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
isEligibleAttribute(String) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
 
isEmpty() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
isEmpty() - Method in class org.springframework.integration.history.MessageHistory
 
isFixedRate() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
isFrameContainingXBeforeFrameContainingY(String, String, StackTraceElement[]) - Static method in class org.springframework.integration.util.StackTraceUtils
Traverses the stack trace element array looking for instances that contain the first or second Strings in the className property.
isFullStatsEnabled() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
isFullStatsEnabled() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
isJackson2Present() - Static method in class org.springframework.integration.support.json.JacksonJsonUtils
Deprecated.
since 4.3.10 in favor of JacksonPresent
isJackson2Present() - Static method in class org.springframework.integration.support.json.JacksonPresent
 
isJacksonPresent() - Static method in class org.springframework.integration.support.json.JacksonJsonUtils
Deprecated.
since 4.3.10 in favor of JacksonPresent
isJacksonPresent() - Static method in class org.springframework.integration.support.json.JacksonPresent
 
isLeader() - Method in interface org.springframework.integration.leader.Context
Checks if the Candidate this context was passed to is the leader.
isLeader() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator.LeaderSelector
 
isLockRegistrySet() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
isLoggingEnabled() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
isLoggingEnabled() - Method in class org.springframework.integration.channel.NullChannel
 
isLoggingEnabled() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
isLoggingEnabled() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
isLoggingEnabled() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
isLoggingEnabled() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
isLoggingEnabled() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
isLoggingEnabled() - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
isLoggingEnabled() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
isLoggingEnabled() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
isMapToPayload() - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
isNegated() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.CompositeHeaderMatcher
 
isNegated() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.ContentBasedHeaderMatcher
 
isNegated() - Method in interface org.springframework.integration.mapping.AbstractHeaderMapper.HeaderMatcher
Return true if this match should be explicitly excluded from the mapping.
isNegated() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.PatternBasedHeaderMatcher
 
isNegated() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.PrefixBasedMatcher
 
isNegated() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
 
isOverwrite() - Method in class org.springframework.integration.transformer.support.AbstractHeaderValueMessageProcessor
 
isOverwrite() - Method in interface org.springframework.integration.transformer.support.HeaderValueMessageProcessor
 
isPriorityEnabled() - Method in interface org.springframework.integration.store.PriorityCapableChannelMessageStore
 
isReadOnly(String) - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
isReceiveOnlyAdvice(Advice) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Return true if this advice should be applied only to the AbstractPollingEndpoint.receiveMessage() operation rather than the whole poll.
isReceiveOnlyAdvice(Advice) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
isReleasePartialSequences() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
isRequiresReply() - Method in class org.springframework.integration.config.SplitterFactoryBean
 
isRunning() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
isRunning() - Method in class org.springframework.integration.channel.interceptor.WireTap
Check whether the wire tap is currently running.
isRunning() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
isRunning() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
isRunning() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
isRunning() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
isRunning() - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
isRunning() - Method in class org.springframework.integration.filter.MessageFilter
 
isRunning() - Method in class org.springframework.integration.handler.MessageHandlerChain
SmartLifecycle implementation (delegates to the MessageHandlerChain.handlers)
isRunning() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
isRunning() - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
isRunning() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
isRunning() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
isRunning() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
isRunning() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
isRunning() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
isRunning() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
isRunning() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
isRunning() - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
isRunning() - Method in class org.springframework.integration.transformer.ContentEnricher
Lifecycle implementation.
isRunning() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
isRunning() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper
 
isSendPartialResultOnExpiry() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
isSequenceAware() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
isSingleton() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
isSingleton() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
 
isSingleton() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
isSingleton() - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
isStale(T) - Method in interface org.springframework.integration.util.SimplePool.PoolItemCallback
Called by the pool when an idle item is retrieved from the pool.
isStatsEnabled() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
isStatsEnabled() - Method in class org.springframework.integration.channel.NullChannel
 
isStatsEnabled() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
isStatsEnabled() - Method in class org.springframework.integration.support.management.graph.MessageChannelNode.Stats
 
isStatsEnabled() - Method in class org.springframework.integration.support.management.graph.MessageHandlerNode.Stats
 
isStatsEnabled() - Method in interface org.springframework.integration.support.management.IntegrationStatsManagement
 
isStatsEnabled() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
isTimeoutOnIdle() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
isUsingReplyProducer() - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
Override this to signal that this channel adapter is actually using a AbstractReplyProducingMessageHandler while it is not possible for this parser to determine that because, say, a FactoryBean is being used.
isVoid() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
 
isWritable(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
 
isWritable(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
isWritable(Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
isWritable(EvaluationContext) - Method in class org.springframework.integration.expression.ValueExpression
 
isWritable(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
isWritable(Object) - Method in class org.springframework.integration.expression.ValueExpression
 
iterator() - Method in class org.springframework.integration.history.MessageHistory
 
iterator() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
iterator() - Method in class org.springframework.integration.store.MessageGroupQueue
 
iterator() - Method in interface org.springframework.integration.store.MessageGroupStore
 
iterator() - Method in class org.springframework.integration.store.SimpleMessageStore
 

J

Jackson2JsonMessageParser - Class in org.springframework.integration.support.json
JsonInboundMessageMapper.JsonMessageParser implementation that parses JSON messages and builds a Message with the specified payload type from provided JsonInboundMessageMapper.
Jackson2JsonMessageParser() - Constructor for class org.springframework.integration.support.json.Jackson2JsonMessageParser
 
Jackson2JsonMessageParser(Jackson2JsonObjectMapper) - Constructor for class org.springframework.integration.support.json.Jackson2JsonMessageParser
 
Jackson2JsonObjectMapper - Class in org.springframework.integration.support.json
Jackson 2 JSON-processor (@link https://github.com/FasterXML) JsonObjectMapper implementation.
Jackson2JsonObjectMapper() - Constructor for class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
Jackson2JsonObjectMapper(ObjectMapper) - Constructor for class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
JacksonJsonUtils - Class in org.springframework.integration.support.json
Utility methods for Jackson.
JacksonPresent - Class in org.springframework.integration.support.json
The utility to check if Jackson JSON processor is present in the classpath.
JdkIdGenerator() - Constructor for class org.springframework.integration.support.IdGenerators.JdkIdGenerator
 
JSON_CONTENT_TYPE - Static variable in class org.springframework.integration.json.ObjectToJsonTransformer
 
jsonAvailable() - Static method in class org.springframework.integration.support.json.JsonObjectMapperProvider
Returns true if a supported JSON implementation is on the class path.
JsonHeaders - Class in org.springframework.integration.mapping.support
Pre-defined names and prefixes to be used for setting and/or retrieving JSON entries from/to Message Headers and other adapter, e.g.
JsonInboundMessageMapper - Class in org.springframework.integration.support.json
InboundMessageMapper implementation that maps incoming JSON messages to a Message with the specified payload type.
JsonInboundMessageMapper(Class<?>, JsonInboundMessageMapper.JsonMessageParser<?>) - Constructor for class org.springframework.integration.support.json.JsonInboundMessageMapper
 
JsonInboundMessageMapper(Type, JsonInboundMessageMapper.JsonMessageParser<?>) - Constructor for class org.springframework.integration.support.json.JsonInboundMessageMapper
 
JsonInboundMessageMapper.JsonMessageParser<P> - Interface in org.springframework.integration.support.json
 
JsonObjectMapper<N,P> - Interface in org.springframework.integration.support.json
Strategy interface to convert an Object to/from the JSON representation.
JsonObjectMapperAdapter<N,P> - Class in org.springframework.integration.support.json
Simple JsonObjectMapper adapter implementation, if there is no need to provide entire operations implementation.
JsonObjectMapperAdapter() - Constructor for class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
JsonObjectMapperProvider - Class in org.springframework.integration.support.json
Simple factory to provide JsonObjectMapper instances dependently of jackson-databind or boon libs in the classpath.
JsonOutboundMessageMapper - Class in org.springframework.integration.support.json
OutboundMessageMapper implementation the converts a Message to a JSON string representation.
JsonOutboundMessageMapper() - Constructor for class org.springframework.integration.support.json.JsonOutboundMessageMapper
 
JsonOutboundMessageMapper(JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.support.json.JsonOutboundMessageMapper
 
JsonPathUtils - Class in org.springframework.integration.json
JsonPropertyAccessor - Class in org.springframework.integration.json
A SpEL PropertyAccessor that knows how to read on Jackson JSON objects.
JsonPropertyAccessor() - Constructor for class org.springframework.integration.json.JsonPropertyAccessor
 
JsonPropertyAccessor.ToStringFriendlyJsonNode - Class in org.springframework.integration.json
 
JsonToObjectTransformer - Class in org.springframework.integration.json
Transformer implementation that converts a JSON string payload into an instance of the provided target Class.
JsonToObjectTransformer() - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
 
JsonToObjectTransformer(Class<?>) - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
 
JsonToObjectTransformer(JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
 
JsonToObjectTransformer(Class<?>, JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.json.JsonToObjectTransformer
 
JsonToObjectTransformerParser - Class in org.springframework.integration.config.xml
 
JsonToObjectTransformerParser() - Constructor for class org.springframework.integration.config.xml.JsonToObjectTransformerParser
 

K

KEY_TYPE_ID - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
 
keySet() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
kryo - Static variable in class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
 
KryoClassListRegistrar - Class in org.springframework.integration.codec.kryo
A KryoRegistrar used to validateRegistration a list of Java classes.
KryoClassListRegistrar(Class<?>...) - Constructor for class org.springframework.integration.codec.kryo.KryoClassListRegistrar
 
KryoClassListRegistrar(List<Class<?>>) - Constructor for class org.springframework.integration.codec.kryo.KryoClassListRegistrar
 
KryoClassMapRegistrar - Class in org.springframework.integration.codec.kryo
A KryoRegistrar implementation backed by a Map used to explicitly set the registration ID for each class.
KryoClassMapRegistrar(Map<Integer, Class<?>>) - Constructor for class org.springframework.integration.codec.kryo.KryoClassMapRegistrar
 
KryoRegistrar - Interface in org.springframework.integration.codec.kryo
Strategy interface used by PojoCodec to configure registrations classes consistently across Kryo instances.
KryoRegistrationRegistrar - Class in org.springframework.integration.codec.kryo
A KryoRegistrar implementation backed by a List of Registration.
KryoRegistrationRegistrar(List<Registration>) - Constructor for class org.springframework.integration.codec.kryo.KryoRegistrationRegistrar
 

L

lastIndexOf(Object) - Method in class org.springframework.integration.history.MessageHistory
 
LeaderEventPublisher - Interface in org.springframework.integration.leader.event
Interface for publishing leader based application events.
lifecycleCondition - Variable in class org.springframework.integration.endpoint.AbstractEndpoint
 
lifecycleLock - Variable in class org.springframework.integration.endpoint.AbstractEndpoint
 
LifecycleMessageHandlerMetrics - Class in org.springframework.integration.support.management
A MessageHandlerMetrics that exposes in addition the Lifecycle interface.
LifecycleMessageHandlerMetrics(Lifecycle, MessageHandlerMetrics) - Constructor for class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
LifecycleMessageSourceMetrics - Class in org.springframework.integration.support.management
A MessageSourceMetrics that exposes in addition the Lifecycle interface.
LifecycleMessageSourceMetrics(Lifecycle, MessageSourceMetrics) - Constructor for class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
LifecycleTrackableMessageHandlerMetrics - Class in org.springframework.integration.support.management
LifecycleTrackableMessageHandlerMetrics(Lifecycle, MessageHandlerMetrics) - Constructor for class org.springframework.integration.support.management.LifecycleTrackableMessageHandlerMetrics
 
LifecycleTrackableMessageSourceMetrics - Class in org.springframework.integration.support.management
LifecycleTrackableMessageSourceMetrics(Lifecycle, MessageSourceMetrics) - Constructor for class org.springframework.integration.support.management.LifecycleTrackableMessageSourceMetrics
 
LinkNode - Class in org.springframework.integration.support.management.graph
Represents a link between nodes.
LinkNode(int, int, LinkNode.Type) - Constructor for class org.springframework.integration.support.management.graph.LinkNode
 
LinkNode.Type - Enum in org.springframework.integration.support.management.graph
 
ListenableMetadataStore - Interface in org.springframework.integration.metadata
ConcurrentMetadataStore with the ability of registering MetadataStoreListener callbacks, to be invoked when changes occur in the metadata store.
listIterator() - Method in class org.springframework.integration.history.MessageHistory
 
listIterator(int) - Method in class org.springframework.integration.history.MessageHistory
 
LoadBalancingStrategy - Interface in org.springframework.integration.dispatcher
Strategy for determining the iteration order of a MessageHandler list.
LockRegistry - Interface in org.springframework.integration.support.locks
Strategy for maintaining a registry of shared locks
LockRegistryLeaderInitiator - Class in org.springframework.integration.support.leader
Component that initiates leader election based on holding a lock.
LockRegistryLeaderInitiator(LockRegistry) - Constructor for class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
Create a new leader initiator with the provided lock registry and a default candidate (which just logs the leadership events).
LockRegistryLeaderInitiator(LockRegistry, Candidate) - Constructor for class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
Create a new leader initiator.
LockRegistryLeaderInitiator.LeaderSelector - Class in org.springframework.integration.support.leader
 
log - Variable in class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
 
logger - Variable in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
logger - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
logger - Variable in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
logger - Variable in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
logger - Variable in class org.springframework.integration.context.IntegrationObjectSupport
Logger that is available to subclasses
logger - Variable in class org.springframework.integration.dispatcher.AbstractDispatcher
 
logger - Variable in class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
 
logger - Variable in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
 
logger - Variable in class org.springframework.integration.mapping.AbstractHeaderMapper
 
logger - Variable in class org.springframework.integration.store.AbstractMessageGroupStore
 
logger - Variable in class org.springframework.integration.support.ErrorMessagePublisher
 
logger - Variable in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
logger - Variable in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
logger - Variable in class org.springframework.integration.util.AbstractExpressionEvaluator
 
logger - Variable in class org.springframework.integration.util.SimplePool
 
LoggingChannelAdapterParser - Class in org.springframework.integration.config.xml
Parser for the 'logging-channel-adapter' element.
LoggingChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.LoggingChannelAdapterParser
 
LoggingHandler - Class in org.springframework.integration.handler
MessageHandler implementation that simply logs the Message or its payload depending on the value of the 'shouldLogFullMessage' or SpEL 'logExpression' property.
LoggingHandler(String) - Constructor for class org.springframework.integration.handler.LoggingHandler
Create a LoggingHandler with the given log level (case-insensitive).
LoggingHandler(LoggingHandler.Level) - Constructor for class org.springframework.integration.handler.LoggingHandler
Create a LoggingHandler with the given log LoggingHandler.Level.
LoggingHandler.Level - Enum in org.springframework.integration.handler
 

M

MANAGEMENT_CONFIGURER_NAME - Static variable in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
managementConfigurer() - Method in class org.springframework.integration.config.IntegrationManagementConfiguration
 
MapMessageConverter - Class in org.springframework.integration.support.converter
Converts to/from a Map with 2 keys ('headers' and 'payload').
MapMessageConverter() - Constructor for class org.springframework.integration.support.converter.MapMessageConverter
 
MappingMessageRouterManagement - Interface in org.springframework.integration.support.management
Exposes channel mapping operations when the router is proxied.
MapToObjectTransformer - Class in org.springframework.integration.transformer
Will transform Map to an instance of Object.
MapToObjectTransformer(Class<?>) - Constructor for class org.springframework.integration.transformer.MapToObjectTransformer
 
MapToObjectTransformer(String) - Constructor for class org.springframework.integration.transformer.MapToObjectTransformer
 
MapToObjectTransformerParser - Class in org.springframework.integration.config.xml
 
MapToObjectTransformerParser() - Constructor for class org.springframework.integration.config.xml.MapToObjectTransformerParser
 
mapToPayload - Variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
matches(Method) - Method in class org.springframework.integration.util.UniqueMethodFilter
 
matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.CompositeHeaderMatcher
 
matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.ContentBasedHeaderMatcher
 
matchHeader(String) - Method in interface org.springframework.integration.mapping.AbstractHeaderMapper.HeaderMatcher
Specify if the given headerName matches.
matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.PatternBasedHeaderMatcher
 
matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.PrefixBasedMatcher
 
matchHeader(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
 
MAX_MESSAGES_UNBOUNDED - Static variable in class org.springframework.integration.scheduling.PollerMetadata
 
maxSubscribers - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
 
MESSAGE - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
MESSAGE_FORMAT_ERROR - Static variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
MESSAGE_GROUP_KEY_PREFIX - Static variable in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
MESSAGE_KEY_PREFIX - Static variable in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
MESSAGE_SOURCE - Static variable in class org.springframework.integration.transaction.IntegrationResourceHolder
 
MessageBuilder<T> - Class in org.springframework.integration.support
The default message builder; creates immutable GenericMessages.
MessageBuilderFactory - Interface in org.springframework.integration.support
 
MessageChannelMetrics - Interface in org.springframework.integration.support.management
Interface for all message channel monitors containing accessors for various useful metrics that are generic for all channel types.
MessageChannelNode - Class in org.springframework.integration.support.management.graph
Represents a message channel.
MessageChannelNode(int, String, MessageChannel) - Constructor for class org.springframework.integration.support.management.graph.MessageChannelNode
 
MessageChannelNode.Stats - Class in org.springframework.integration.support.management.graph
 
MessageCodec - Class in org.springframework.integration.codec.kryo
PojoCodec configured to encode/decode Message<?>s.
MessageCodec() - Constructor for class org.springframework.integration.codec.kryo.MessageCodec
Construct an instance using the default registration ids for messsage headers.
MessageCodec(MessageKryoRegistrar) - Constructor for class org.springframework.integration.codec.kryo.MessageCodec
Construct an instance using a custom registrar - usually used if different registration ids are required for message headers.
MessageCountReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that releases only the first n messages, where n is a threshold.
MessageCountReleaseStrategy(int) - Constructor for class org.springframework.integration.aggregator.MessageCountReleaseStrategy
 
MessageCountReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.MessageCountReleaseStrategy
Convenient constructor is only one message is required (threshold=1).
MessageDecorator - Interface in org.springframework.integration.support
The Message decoration contract.
MessageDispatcher - Interface in org.springframework.integration.dispatcher
Strategy interface for dispatching messages to handlers.
MessageDispatchingException - Exception in org.springframework.integration
Exception that indicates an internal error occurred within a MessageDispatcher preventing message delivery.
MessageDispatchingException(String) - Constructor for exception org.springframework.integration.MessageDispatchingException
 
MessageDispatchingException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageDispatchingException
 
MessageDispatchingException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageDispatchingException
 
MessageDispatchingException(Message<?>) - Constructor for exception org.springframework.integration.MessageDispatchingException
 
MessageEndpoint - Annotation Type in org.springframework.integration.annotation
Stereotype annotation indicating that a class is capable of serving as a Message Endpoint.
MessageFilter - Class in org.springframework.integration.filter
Message Handler that delegates to a MessageSelector.
MessageFilter(MessageSelector) - Constructor for class org.springframework.integration.filter.MessageFilter
Create a MessageFilter that will delegate to the given MessageSelector.
MessageGatewayNode - Class in org.springframework.integration.support.management.graph
Represents an inbound gateway.
MessageGatewayNode(int, String, MessagingGatewaySupport, String, String) - Constructor for class org.springframework.integration.support.management.graph.MessageGatewayNode
 
MessageGatewayNode.Stats - Class in org.springframework.integration.support.management.graph
 
MessageGroup - Interface in org.springframework.integration.store
A group of messages that are correlated with each other and should be processed in the same context.
MessageGroupExpiredEvent - Class in org.springframework.integration.aggregator
Event representing the expiration of a message group.
MessageGroupExpiredEvent(Object, Object, int, Date, Date, boolean) - Constructor for class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
MessageGroupFactory - Interface in org.springframework.integration.store
The MessageGroup factory strategy.
MessageGroupMetadata - Class in org.springframework.integration.store
Value Object holding metadata about a MessageGroup in the MessageGroupStore.
MessageGroupMetadata(MessageGroup) - Constructor for class org.springframework.integration.store.MessageGroupMetadata
 
MessageGroupProcessor - Interface in org.springframework.integration.aggregator
A processor for correlated groups of messages.
MessageGroupQueue - Class in org.springframework.integration.store
A BlockingQueue that is backed by a MessageGroupStore.
MessageGroupQueue(BasicMessageGroupStore, Object) - Constructor for class org.springframework.integration.store.MessageGroupQueue
 
MessageGroupQueue(BasicMessageGroupStore, Object, int) - Constructor for class org.springframework.integration.store.MessageGroupQueue
 
MessageGroupQueue(BasicMessageGroupStore, Object, Lock) - Constructor for class org.springframework.integration.store.MessageGroupQueue
 
MessageGroupQueue(BasicMessageGroupStore, Object, int, Lock) - Constructor for class org.springframework.integration.store.MessageGroupQueue
 
messageGroupSize(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
messageGroupSize(Object) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
Returns the size of this MessageGroup.
messageGroupSize(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
MessageGroupStore - Interface in org.springframework.integration.store
Defines additional storage operations on groups of messages linked by a group id.
MessageGroupStore.MessageGroupCallback - Interface in org.springframework.integration.store
Invoked when a MessageGroupStore expires a group.
MessageGroupStoreReaper - Class in org.springframework.integration.store
Convenient configurable component to allow explicit timed expiry of MessageGroup instances in a MessageGroupStore.
MessageGroupStoreReaper(MessageGroupStore) - Constructor for class org.springframework.integration.store.MessageGroupStoreReaper
 
MessageGroupStoreReaper() - Constructor for class org.springframework.integration.store.MessageGroupStoreReaper
 
messageHandlerAttributes - Variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
MessageHandlerChain - Class in org.springframework.integration.handler
A composite MessageHandler implementation that invokes a chain of MessageHandler instances in order.
MessageHandlerChain() - Constructor for class org.springframework.integration.handler.MessageHandlerChain
 
MessageHandlerMetrics - Interface in org.springframework.integration.support.management
 
MessageHandlerNode - Class in org.springframework.integration.support.management.graph
Represents a message handler.
MessageHandlerNode(int, String, MessageHandler, String, String) - Constructor for class org.springframework.integration.support.management.graph.MessageHandlerNode
 
MessageHandlerNode.Stats - Class in org.springframework.integration.support.management.graph
 
MessageHandlingExpressionEvaluatingAdviceException(Message<?>, String, Throwable, Object) - Constructor for exception org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice.MessageHandlingExpressionEvaluatingAdviceException
 
MessageHandlingTask(MessageHandlingRunnable) - Constructor for class org.springframework.integration.channel.AbstractExecutorChannel.MessageHandlingTask
 
MessageHandlingTaskDecorator - Interface in org.springframework.integration.dispatcher
The strategy to decorate MessageHandlingRunnable tasks to be used with the Executor.
MessageHeadersJacksonSerializer - Class in org.springframework.integration.support.json
A Jackson StdSerializer implementation to serialize MessageHeaders as a HashMap.
MessageHeadersJacksonSerializer() - Constructor for class org.springframework.integration.support.json.MessageHeadersJacksonSerializer
 
MessageHistory - Class in org.springframework.integration.history
 
MessageHistory.Entry - Class in org.springframework.integration.history
Inner class for each Entry in the history.
MessageHistoryConfigurer - Class in org.springframework.integration.history
 
MessageHistoryConfigurer() - Constructor for class org.springframework.integration.history.MessageHistoryConfigurer
 
MessageHistoryParser - Class in org.springframework.integration.config.xml
The <message-history/> parser.
MessageHistoryParser() - Constructor for class org.springframework.integration.config.xml.MessageHistoryParser
 
MessageHistoryRegistrar - Class in org.springframework.integration.config
Registers the MessageHistoryConfigurer BeanDefinition for MessageHistory.
MessageHistoryRegistrar() - Constructor for class org.springframework.integration.config.MessageHistoryRegistrar
 
messageIdIterator() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
MessageJacksonDeserializer<T extends org.springframework.messaging.Message<?>> - Class in org.springframework.integration.support.json
A Jackson StdNodeBasedDeserializer extension for Message implementations.
MessageJacksonDeserializer(Class<T>) - Constructor for class org.springframework.integration.support.json.MessageJacksonDeserializer
 
MessageKryoRegistrar - Class in org.springframework.integration.codec.kryo
Registers common MessageHeader types and Serializers.
MessageKryoRegistrar() - Constructor for class org.springframework.integration.codec.kryo.MessageKryoRegistrar
 
MessageListProcessor - Interface in org.springframework.integration.aggregator
 
MessageMappingException - Exception in org.springframework.integration.mapping
Exception that indicates an error during message mapping.
MessageMappingException(String) - Constructor for exception org.springframework.integration.mapping.MessageMappingException
 
MessageMappingException(String, Throwable) - Constructor for exception org.springframework.integration.mapping.MessageMappingException
 
MessageMappingException(Message<?>, String) - Constructor for exception org.springframework.integration.mapping.MessageMappingException
 
MessageMappingException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.mapping.MessageMappingException
 
MessageProcessingHeaderValueMessageProcessor - Class in org.springframework.integration.transformer.support
 
MessageProcessingHeaderValueMessageProcessor(MessageProcessor<T>) - Constructor for class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
 
MessageProcessingHeaderValueMessageProcessor(Object) - Constructor for class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
 
MessageProcessingHeaderValueMessageProcessor(Object, String) - Constructor for class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
 
MessageProcessor<T> - Interface in org.springframework.integration.handler
This defines the lowest-level strategy of processing a Message and returning some Object (or null).
MessageProducer - Interface in org.springframework.integration.core
Base interface for any component that is capable of sending Messages to a MessageChannel.
MessageProducerNode - Class in org.springframework.integration.support.management.graph
Represents an inbound message producer.
MessageProducerNode(int, String, MessageProducerSupport, String, String) - Constructor for class org.springframework.integration.support.management.graph.MessageProducerNode
 
MessageProducerSupport - Class in org.springframework.integration.endpoint
A support class for producer endpoints that provides a setter for the output channel and a convenience method for sending Messages.
MessageProducerSupport() - Constructor for class org.springframework.integration.endpoint.MessageProducerSupport
 
MessagePublishingErrorHandler - Class in org.springframework.integration.channel
ErrorHandler implementation that sends an ErrorMessage to a MessageChannel.
MessagePublishingErrorHandler() - Constructor for class org.springframework.integration.channel.MessagePublishingErrorHandler
 
MessagePublishingErrorHandler(DestinationResolver<MessageChannel>) - Constructor for class org.springframework.integration.channel.MessagePublishingErrorHandler
 
MessagePublishingInterceptor - Class in org.springframework.integration.aop
A MethodInterceptor that publishes Messages to a channel.
MessagePublishingInterceptor(PublisherMetadataSource) - Constructor for class org.springframework.integration.aop.MessagePublishingInterceptor
 
MessageRejectedException - Exception in org.springframework.integration
Exception that indicates a message has been rejected by a selector.
MessageRejectedException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageRejectedException
 
MessageRejectedException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageRejectedException
 
MessageRouter - Interface in org.springframework.integration.router
Routers implementing this interface have a default output channel.
MessageSelectingInterceptor - Class in org.springframework.integration.channel.interceptor
A ChannelInterceptor that delegates to a list of MessageSelectors to decide whether a Message should be accepted on the MessageChannel.
MessageSelectingInterceptor(MessageSelector...) - Constructor for class org.springframework.integration.channel.interceptor.MessageSelectingInterceptor
 
MessageSelector - Interface in org.springframework.integration.core
Strategy interface for message selection.
MessageSelectorChain - Class in org.springframework.integration.selector
A message selector implementation that passes incoming messages through a chain of selectors.
MessageSelectorChain() - Constructor for class org.springframework.integration.selector.MessageSelectorChain
 
MessageSelectorChain.VotingStrategy - Enum in org.springframework.integration.selector
 
MessageSequenceComparator - Class in org.springframework.integration.aggregator
A Comparator implementation based on the 'sequence number' property of a Message's header.
MessageSequenceComparator() - Constructor for class org.springframework.integration.aggregator.MessageSequenceComparator
 
MessageSource<T> - Interface in org.springframework.integration.core
Base interface for any source of Messages that can be polled.
MessageSourceMetrics - Interface in org.springframework.integration.support.management
 
MessageSourceNode - Class in org.springframework.integration.support.management.graph
Represents a message source.
MessageSourceNode(int, String, MessageSource<?>, String, String) - Constructor for class org.springframework.integration.support.management.graph.MessageSourceNode
 
MessageSourceNode.Stats - Class in org.springframework.integration.support.management.graph
 
MessageStore - Interface in org.springframework.integration.store
Strategy interface for storing and retrieving messages.
MessageStoreException - Exception in org.springframework.integration.store
Exception for problems that occur when using a MessageStore implementation.
MessageStoreException(Message<?>) - Constructor for exception org.springframework.integration.store.MessageStoreException
 
MessageStoreException(String) - Constructor for exception org.springframework.integration.store.MessageStoreException
 
MessageStoreException(String, Throwable) - Constructor for exception org.springframework.integration.store.MessageStoreException
 
MessageStoreException(Message<?>, String) - Constructor for exception org.springframework.integration.store.MessageStoreException
 
MessageStoreException(Message<?>, Throwable) - Constructor for exception org.springframework.integration.store.MessageStoreException
 
MessageStoreException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.store.MessageStoreException
 
MessageTimeoutException - Exception in org.springframework.integration
Exception that indicates a timeout elapsed prior to successful message delivery.
MessageTimeoutException(String) - Constructor for exception org.springframework.integration.MessageTimeoutException
 
MessageTimeoutException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.MessageTimeoutException
 
MessageTimeoutException(Message<?>, String) - Constructor for exception org.springframework.integration.MessageTimeoutException
 
MessageTimeoutException(Message<?>) - Constructor for exception org.springframework.integration.MessageTimeoutException
 
MessageTransformationException - Exception in org.springframework.integration.transformer
Base Exception type for Message transformation errors.
MessageTransformationException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformationException(Message<?>, String) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformationException(String, Throwable) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformationException(String) - Constructor for exception org.springframework.integration.transformer.MessageTransformationException
 
MessageTransformingChannelInterceptor - Class in org.springframework.integration.transformer
Deprecated.
It is not generally recommended to perform functions such as transformation in a channel interceptor.
MessageTransformingChannelInterceptor(Transformer) - Constructor for class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
Deprecated.
 
MessageTransformingHandler - Class in org.springframework.integration.transformer
A reply-producing MessageHandler that delegates to a Transformer instance to modify the received Message and sends the result to its output channel.
MessageTransformingHandler(Transformer) - Constructor for class org.springframework.integration.transformer.MessageTransformingHandler
Create a MessageTransformingHandler instance that delegates to the provided Transformer.
MessageTriggerAction - Interface in org.springframework.integration.handler
Classes implementing this interface can take some action when a trigger Message is received.
MESSAGING_ANNOTATION_POSTPROCESSOR_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
MessagingAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
A BeanPostProcessor implementation that processes method-level messaging annotations such as @Transformer, @Splitter, @Router, and @Filter.
MessagingAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
MessagingAnnotationUtils - Class in org.springframework.integration.util
Utility methods to support annotation processing.
messagingAwareMapper(String...) - Static method in class org.springframework.integration.support.json.JacksonJsonUtils
Return an ObjectMapper if available, supplied with Message specific serializers and deserializers.
MessagingGateway - Annotation Type in org.springframework.integration.annotation
A stereotype annotation to provide an Integration Messaging Gateway Proxy (<gateway/>) as an abstraction over the messaging API.
MessagingGatewayRegistrar - Class in org.springframework.integration.config
The ImportBeanDefinitionRegistrar to parse MessagingGateway and its service-interface and to register BeanDefinition GatewayProxyFactoryBean.
MessagingGatewayRegistrar() - Constructor for class org.springframework.integration.config.MessagingGatewayRegistrar
 
MessagingGatewaySupport - Class in org.springframework.integration.gateway
A convenient base class for connecting application code to MessageChannels for sending, receiving, or request-reply operations.
MessagingGatewaySupport() - Constructor for class org.springframework.integration.gateway.MessagingGatewaySupport
Construct an instance that will return null if no reply is received.
MessagingGatewaySupport(boolean) - Constructor for class org.springframework.integration.gateway.MessagingGatewaySupport
If errorOnTimeout is true, construct an instance that will send an ErrorMessage with a MessageTimeoutException payload to the error channel if a reply is expected but none is received.
MessagingMethodInvokerHelper<T> - Class in org.springframework.integration.util
A helper class for processors that invoke a method on a target Object using a combination of message payload(s) and headers as arguments.
MessagingMethodInvokerHelper(Object, Method, Class<?>, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, Method, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, String, Class<?>, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, String, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, Class<? extends Annotation>, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper(Object, Class<? extends Annotation>, Class<?>, boolean) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper
 
MessagingMethodInvokerHelper.ParametersWrapper - Class in org.springframework.integration.util
 
MessagingTemplate - Class in org.springframework.integration.core
 
MessagingTemplate() - Constructor for class org.springframework.integration.core.MessagingTemplate
Create a MessagingTemplate with no default channel.
MessagingTemplate(MessageChannel) - Constructor for class org.springframework.integration.core.MessagingTemplate
Create a MessagingTemplate with the given default channel.
messagingTemplate - Variable in class org.springframework.integration.gateway.MessagingGatewaySupport
 
messagingTemplate - Variable in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
messagingTemplate - Variable in class org.springframework.integration.support.ErrorMessagePublisher
 
METADATA_STORE_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
MetadataStore - Interface in org.springframework.integration.metadata
Strategy interface for storing metadata from certain adapters to avoid duplicate delivery of messages, for example.
MetadataStoreListener - Interface in org.springframework.integration.metadata
A callback to be invoked whenever a value changes in the data store.
MetadataStoreListenerAdapter - Class in org.springframework.integration.metadata
Base implementation for a MetadataStoreListener.
MetadataStoreListenerAdapter() - Constructor for class org.springframework.integration.metadata.MetadataStoreListenerAdapter
 
MetadataStoreSelector - Class in org.springframework.integration.selector
MetadataStoreSelector(MessageProcessor<String>) - Constructor for class org.springframework.integration.selector.MetadataStoreSelector
 
MetadataStoreSelector(MessageProcessor<String>, MessageProcessor<String>) - Constructor for class org.springframework.integration.selector.MetadataStoreSelector
 
MetadataStoreSelector(MessageProcessor<String>, ConcurrentMetadataStore) - Constructor for class org.springframework.integration.selector.MetadataStoreSelector
 
MetadataStoreSelector(MessageProcessor<String>, MessageProcessor<String>, ConcurrentMetadataStore) - Constructor for class org.springframework.integration.selector.MetadataStoreSelector
 
METHOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
METHOD_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
MethodAnnotationPostProcessor<T extends java.lang.annotation.Annotation> - Interface in org.springframework.integration.config.annotation
Strategy interface for post-processing annotated methods.
MethodAnnotationPublisherMetadataSource - Class in org.springframework.integration.aop
An PublisherMetadataSource implementation that retrieves the channel name and expression strings from an annotation.
MethodAnnotationPublisherMetadataSource() - Constructor for class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
MethodAnnotationPublisherMetadataSource(Set<Class<? extends Annotation>>) - Constructor for class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
MethodArgsHolder - Class in org.springframework.integration.gateway
Simple wrapper class containing a Method and an object array containing the arguments for an invocation of that method.
MethodArgsHolder(Method, Object[]) - Constructor for class org.springframework.integration.gateway.MethodArgsHolder
 
MethodArgsMessageMapper - Interface in org.springframework.integration.gateway
Implementations of this interface are InboundMessageMappers that map a MethodArgsHolder to a Message.
MethodInvokingCorrelationStrategy - Class in org.springframework.integration.aggregator
CorrelationStrategy implementation that works as an adapter to another bean.
MethodInvokingCorrelationStrategy(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
MethodInvokingCorrelationStrategy(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
MethodInvokingMessageGroupProcessor - Class in org.springframework.integration.aggregator
MessageGroupProcessor that serves as an adapter for the invocation of a POJO method.
MethodInvokingMessageGroupProcessor(Object) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
Creates a wrapper around the object passed in.
MethodInvokingMessageGroupProcessor(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
Creates a wrapper around the object passed in.
MethodInvokingMessageGroupProcessor(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
Creates a wrapper around the object passed in.
MethodInvokingMessageHandler - Class in org.springframework.integration.handler
A MessageHandler that invokes the specified method on the provided object.
MethodInvokingMessageHandler(Object, Method) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageHandler
 
MethodInvokingMessageHandler(Object, String) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageHandler
 
MethodInvokingMessageListProcessor<T> - Class in org.springframework.integration.aggregator
A MessageListProcessor implementation that invokes a method on a target POJO.
MethodInvokingMessageListProcessor(Object, Method, Class<T>) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageListProcessor(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageListProcessor(Object, String, Class<T>) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageListProcessor(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageListProcessor(Object, Class<? extends Annotation>) - Constructor for class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
MethodInvokingMessageProcessor<T> - Class in org.springframework.integration.handler
A MessageProcessor implementation that invokes a method on a target Object.
MethodInvokingMessageProcessor(Object, Method) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
MethodInvokingMessageProcessor(Object, String) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
MethodInvokingMessageProcessor(Object, String, boolean) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
MethodInvokingMessageProcessor(Object, Class<? extends Annotation>) - Constructor for class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
MethodInvokingMessageSource - Class in org.springframework.integration.endpoint
A MessageSource implementation that invokes a no-argument method so that its return value may be sent to a channel.
MethodInvokingMessageSource() - Constructor for class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
MethodInvokingReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that invokes a method on a plain old Java object.
MethodInvokingReleaseStrategy(Object, Method) - Constructor for class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
MethodInvokingReleaseStrategy(Object, String) - Constructor for class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
MethodInvokingRouter - Class in org.springframework.integration.router
A Message Router that invokes the specified method on the given object.
MethodInvokingRouter(Object, Method) - Constructor for class org.springframework.integration.router.MethodInvokingRouter
 
MethodInvokingRouter(Object, String) - Constructor for class org.springframework.integration.router.MethodInvokingRouter
 
MethodInvokingRouter(Object) - Constructor for class org.springframework.integration.router.MethodInvokingRouter
 
MethodInvokingSelector - Class in org.springframework.integration.filter
A method-invoking implementation of MessageSelector.
MethodInvokingSelector(Object, Method) - Constructor for class org.springframework.integration.filter.MethodInvokingSelector
 
MethodInvokingSelector(Object, String) - Constructor for class org.springframework.integration.filter.MethodInvokingSelector
 
MethodInvokingSelector(Object) - Constructor for class org.springframework.integration.filter.MethodInvokingSelector
 
MethodInvokingSplitter - Class in org.springframework.integration.splitter
A Message Splitter implementation that invokes the specified method on the given object.
MethodInvokingSplitter(Object, Method) - Constructor for class org.springframework.integration.splitter.MethodInvokingSplitter
 
MethodInvokingSplitter(Object, String) - Constructor for class org.springframework.integration.splitter.MethodInvokingSplitter
 
MethodInvokingSplitter(Object) - Constructor for class org.springframework.integration.splitter.MethodInvokingSplitter
 
MethodInvokingTransformer - Class in org.springframework.integration.transformer
A Message Transformer implementation that invokes the specified method on the given object.
MethodInvokingTransformer(Object, Method) - Constructor for class org.springframework.integration.transformer.MethodInvokingTransformer
 
MethodInvokingTransformer(Object, String) - Constructor for class org.springframework.integration.transformer.MethodInvokingTransformer
 
MethodInvokingTransformer(Object) - Constructor for class org.springframework.integration.transformer.MethodInvokingTransformer
 
methodIsHandleMessageOrEmpty(String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
MethodNameMappingPublisherMetadataSource - Class in org.springframework.integration.aop
 
MethodNameMappingPublisherMetadataSource(Map<String, String>) - Constructor for class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
MetricsContext - Interface in org.springframework.integration.support.management
Interface representing an opaque object containing state between initiating an event and concluding it.
MetricsFactory - Interface in org.springframework.integration.support.management
Factories implementing this interface provide metric objects for message channels and message handlers.
MIN_REGISTRATION_VALUE - Static variable in interface org.springframework.integration.codec.kryo.KryoRegistrar
 
MutableMessage<T> - Class in org.springframework.integration.support
An implementation of Message with a generic payload.
MutableMessage(T) - Constructor for class org.springframework.integration.support.MutableMessage
 
MutableMessage(T, Map<String, Object>) - Constructor for class org.springframework.integration.support.MutableMessage
 
MutableMessageBuilder<T> - Class in org.springframework.integration.support
 
MutableMessageBuilderFactory - Class in org.springframework.integration.support
 
MutableMessageBuilderFactory() - Constructor for class org.springframework.integration.support.MutableMessageBuilderFactory
 
MutableMessageHeaders - Class in org.springframework.integration.support
A MessageHeaders that permits direct access to and modification of the header map.
MutableMessageHeaders(Map<String, Object>) - Constructor for class org.springframework.integration.support.MutableMessageHeaders
 
MutableMessageJacksonDeserializer - Class in org.springframework.integration.support.json
The MessageJacksonDeserializer implementation for the MutableMessage.
MutableMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.MutableMessageJacksonDeserializer
 

N

name - Variable in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
 
name - Variable in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
NAME_PROPERTY - Static variable in class org.springframework.integration.history.MessageHistory
 
NamedComponent - Interface in org.springframework.integration.support.context
 
newCount - Variable in class org.springframework.integration.support.management.AggregatingMessageChannelMetrics.AggregatingChannelMetricsContext
 
newCount - Variable in class org.springframework.integration.support.management.AggregatingMessageHandlerMetrics.AggregatingHandlerMetricsContext
 
newInstance() - Static method in class org.springframework.integration.support.json.JsonObjectMapperProvider
Return an object mapper if available.
next() - Method in class org.springframework.integration.util.FunctionIterator
 
nextExecutionTime(TriggerContext) - Method in class org.springframework.integration.util.CompoundTrigger
 
nextExecutionTime(TriggerContext) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Return the time after which a task should run again.
noEndpointsRunning(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Return true if none of the endpoints in the role are running or if there are no endpoints in the role.
NON_STANDARD_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.mapping.AbstractHeaderMapper
A special pattern that matches any header that is not a standard header (i.e.
noRouterAttributesProvided() - Method in class org.springframework.integration.config.RouterFactoryBean
 
NULL - Static variable in class org.springframework.integration.annotation.AnnotationConstants
Constant defining a value as a replacement for null which we cannot use in annotation attributes.
NULL_CHANNEL_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
NullChannel - Class in org.springframework.integration.channel
A channel implementation that essentially behaves like "/dev/null".
NullChannel() - Constructor for class org.springframework.integration.channel.NullChannel
 

O

ObjectToJsonTransformer - Class in org.springframework.integration.json
Transformer implementation that converts a payload instance into a JSON string representation.
ObjectToJsonTransformer() - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
 
ObjectToJsonTransformer(JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
 
ObjectToJsonTransformer(ObjectToJsonTransformer.ResultType) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
 
ObjectToJsonTransformer(JsonObjectMapper<?, ?>, ObjectToJsonTransformer.ResultType) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
 
ObjectToJsonTransformer.ResultType - Enum in org.springframework.integration.json
 
ObjectToJsonTransformerParser - Class in org.springframework.integration.config.xml
 
ObjectToJsonTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
 
ObjectToMapTransformer - Class in org.springframework.integration.transformer
Will transform an object graph into a Map.
ObjectToMapTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToMapTransformer
 
ObjectToMapTransformerParser - Class in org.springframework.integration.config.xml
 
ObjectToMapTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToMapTransformerParser
 
ObjectToStringTransformer - Class in org.springframework.integration.transformer
A simple transformer that creates an outbound payload by invoking the inbound payload Object's toString() method.
ObjectToStringTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToStringTransformer
 
ObjectToStringTransformer(String) - Constructor for class org.springframework.integration.transformer.ObjectToStringTransformer
 
ObjectToStringTransformerParser - Class in org.springframework.integration.config.xml
Parser for the 'object-to-string-transformer' element.
ObjectToStringTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToStringTransformerParser
 
obtain(Object) - Method in class org.springframework.integration.support.locks.DefaultLockRegistry
Obtains a lock by masking the lockKey's hashCode() with the mask and using the result as an index to the lock table.
obtain(Object) - Method in interface org.springframework.integration.support.locks.LockRegistry
Obtains the lock associated with the parameter object.
obtain(Object) - Method in class org.springframework.integration.support.locks.PassThruLockRegistry
 
obtainGroupTimeout(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
obtainPropagatingContext(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
offer(Message<?>) - Method in class org.springframework.integration.store.MessageGroupQueue
 
offer(Message<?>, long, TimeUnit) - Method in class org.springframework.integration.store.MessageGroupQueue
 
onAdd(String, String) - Method in interface org.springframework.integration.metadata.MetadataStoreListener
Invoked when a key is added to the store
onAdd(String, String) - Method in class org.springframework.integration.metadata.MetadataStoreListenerAdapter
 
onApplicationEvent(ApplicationContextEvent) - Method in class org.springframework.integration.config.IdGeneratorConfigurer
 
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.handler.DelayHandler
Handles ContextRefreshedEvent to invoke DelayHandler.reschedulePersistedMessages() as late as possible after application context startup.
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.support.management.graph.IntegrationGraphServer
 
onApplicationEvent(AbstractLeaderEvent) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
 
ONE_MINUTE_SECONDS - Static variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
ONE_SECOND_SECONDS - Static variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
onError(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
onGranted(Context) - Method in class org.springframework.integration.leader.AbstractCandidate
 
onGranted(Context) - Method in interface org.springframework.integration.leader.Candidate
Callback method invoked when this candidate is elected leader.
onGranted(Context) - Method in class org.springframework.integration.leader.DefaultCandidate
 
OnGrantedEvent - Class in org.springframework.integration.leader.event
Generic event representing that leader has been granted.
OnGrantedEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.OnGrantedEvent
Instantiates a new granted event.
onInit() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
onInit() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
onInit() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
onInit() - Method in class org.springframework.integration.channel.DirectChannel
 
onInit() - Method in class org.springframework.integration.channel.ExecutorChannel
 
onInit() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
Callback method for initialization.
onInit() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Subclasses may implement this for initialization logic.
onInit() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
onInit() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
onInit() - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
onInit() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
onInit() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
onInit() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
onInit() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
onInit() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
onInit() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
onInit() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
onInit() - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
 
onInit() - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
onInit() - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
 
onInit() - Method in class org.springframework.integration.handler.LoggingHandler
 
onInit() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
onInit() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
onInit() - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
onInit() - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
onInit() - Method in class org.springframework.integration.transformer.DecodingTransformer
 
onInit() - Method in class org.springframework.integration.transformer.HeaderEnricher
 
onInit() - Method in class org.springframework.integration.transformer.HeaderFilter
 
onInit() - Method in class org.springframework.integration.transformer.MapToObjectTransformer
 
onRemove(String, String) - Method in interface org.springframework.integration.metadata.MetadataStoreListener
Invoked when a key is removed from the store
onRemove(String, String) - Method in class org.springframework.integration.metadata.MetadataStoreListenerAdapter
 
onRevoked(Context) - Method in class org.springframework.integration.leader.AbstractCandidate
 
onRevoked(Context) - Method in interface org.springframework.integration.leader.Candidate
Callback method invoked when this candidate is no longer leader.
onRevoked(Context) - Method in class org.springframework.integration.leader.DefaultCandidate
 
OnRevokedEvent - Class in org.springframework.integration.leader.event
Generic event representing that leader has been revoked.
OnRevokedEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.OnRevokedEvent
Instantiates a new revoked event.
onUpdate(String, String) - Method in interface org.springframework.integration.metadata.MetadataStoreListener
Invoked when a key is updated into the store
onUpdate(String, String) - Method in class org.springframework.integration.metadata.MetadataStoreListenerAdapter
 
open(RetryContext, RetryCallback<T, E>) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
ORDER - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
Orderable - Interface in org.springframework.integration.context
Interface that extends Ordered while also exposing the Orderable.setOrder(int) as an interface-level so that it is avaiable on AOP proxies, etc.
OrderlyShutdownCapable - Interface in org.springframework.integration.context
Interface for components that wish to be considered for an orderly shutdown using management interfaces.
org.springframework.integration - package org.springframework.integration
Base package for Spring Integration Core.
org.springframework.integration.aggregator - package org.springframework.integration.aggregator
Provides classes related to message aggregation.
org.springframework.integration.annotation - package org.springframework.integration.annotation
Provides annotations for annotation-based configuration.
org.springframework.integration.aop - package org.springframework.integration.aop
Provides classes to support message publication using AOP.
org.springframework.integration.channel - package org.springframework.integration.channel
Provides classes representing various channel types.
org.springframework.integration.channel.interceptor - package org.springframework.integration.channel.interceptor
Provides classes related to channel interception.
org.springframework.integration.codec - package org.springframework.integration.codec
Provides base classes for the Codec abstraction.
org.springframework.integration.codec.kryo - package org.springframework.integration.codec.kryo
The Kryo specific Codec classes.
org.springframework.integration.config - package org.springframework.integration.config
Base package for configuration.
org.springframework.integration.config.annotation - package org.springframework.integration.config.annotation
Provides classes supporting annotation-based configuration.
org.springframework.integration.config.xml - package org.springframework.integration.config.xml
Provides supporting XML-based configuration - parsers, namespace handlers.
org.springframework.integration.context - package org.springframework.integration.context
Provides classes relating to application context configuration.
org.springframework.integration.core - package org.springframework.integration.core
Provides core classes.
org.springframework.integration.dispatcher - package org.springframework.integration.dispatcher
Provides classes related to dispatching messages.
org.springframework.integration.endpoint - package org.springframework.integration.endpoint
Provides core classes related to Endpoints.
org.springframework.integration.event - package org.springframework.integration.event
ApplicationEvents generated by the Spring Integration framework.
org.springframework.integration.expression - package org.springframework.integration.expression
Provides classes supporting SpEL expressions.
org.springframework.integration.filter - package org.springframework.integration.filter
Provides classes supporting the filter pattern.
org.springframework.integration.gateway - package org.springframework.integration.gateway
Provides classes supporting messaging gateways.
org.springframework.integration.handler - package org.springframework.integration.handler
Provides classes implementing various types of message handler.
org.springframework.integration.handler.advice - package org.springframework.integration.handler.advice
Provides classes that are used to advise MessageHandlers with cross-cutting concerns.
org.springframework.integration.history - package org.springframework.integration.history
Provides classes supporting the capture of message history.
org.springframework.integration.json - package org.springframework.integration.json
Provides classes supporting JSON in Spring Integration.
org.springframework.integration.leader - package org.springframework.integration.leader
Temporary package until s-c-c-core is released.
org.springframework.integration.leader.event - package org.springframework.integration.leader.event
Temporary package until s-c-c-core is released.
org.springframework.integration.mapping - package org.springframework.integration.mapping
Provides classes related to mapping to/from message headers.
org.springframework.integration.mapping.support - package org.springframework.integration.mapping.support
Support classes for mapping.
org.springframework.integration.message - package org.springframework.integration.message
Provides concrete Message implementations.
org.springframework.integration.metadata - package org.springframework.integration.metadata
Provides classes supporting metadata stores.
org.springframework.integration.resource - package org.springframework.integration.resource
Provides classes related to messaging using Spring Resources
org.springframework.integration.router - package org.springframework.integration.router
Provides classes supporting the router pattern.
org.springframework.integration.routingslip - package org.springframework.integration.routingslip
Provides classes supporting the RoutingSlip pattern.
org.springframework.integration.scattergather - package org.springframework.integration.scattergather
Provides classes supporting the Scatter-Gather pattern.
org.springframework.integration.scheduling - package org.springframework.integration.scheduling
Provides classes related to task scheduling.
org.springframework.integration.selector - package org.springframework.integration.selector
Provides classes related to message selection.
org.springframework.integration.splitter - package org.springframework.integration.splitter
Provides classes supporting the splitter pattern.
org.springframework.integration.store - package org.springframework.integration.store
Provides classes releated to storing messages.
org.springframework.integration.support - package org.springframework.integration.support
Base core support package.
org.springframework.integration.support.channel - package org.springframework.integration.support.channel
 
org.springframework.integration.support.context - package org.springframework.integration.support.context
Provides classes supporting use of the application context.
org.springframework.integration.support.converter - package org.springframework.integration.support.converter
Provides classes supporting message conversion.
org.springframework.integration.support.json - package org.springframework.integration.support.json
Provides classes supporting json.
org.springframework.integration.support.leader - package org.springframework.integration.support.leader
 
org.springframework.integration.support.locks - package org.springframework.integration.support.locks
Provides classes related to locking resources.
org.springframework.integration.support.management - package org.springframework.integration.support.management
Provides classes related to management support.
org.springframework.integration.support.management.graph - package org.springframework.integration.support.management.graph
Provides classes related to the runtime object graph.
org.springframework.integration.support.utils - package org.springframework.integration.support.utils
Provides global utility support classes for the runtime system.
org.springframework.integration.transaction - package org.springframework.integration.transaction
Provides classes supporting the use of transactions and pseudo transactions in Spring Integration applications.
org.springframework.integration.transformer - package org.springframework.integration.transformer
Contains core-implementation of various Transformers which includes Enrichers and Filters.
org.springframework.integration.transformer.support - package org.springframework.integration.transformer.support
Contains support classes for Transformers.
org.springframework.integration.util - package org.springframework.integration.util
Provides core utility classes.
OutboundMessageMapper<T> - Interface in org.springframework.integration.mapping
Strategy interface for mapping from a Message to an Object.

P

ParametersWrapper(Message<?>) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
ParametersWrapper(Collection<Message<?>>, Map<String, ?>) - Constructor for class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
 
parse(Map<String, Object>) - Method in class org.springframework.integration.config.MessagingGatewayRegistrar
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AnnotationConfigParser
 
parse(Element, ParserContext) - Method in interface org.springframework.integration.config.xml.BeanDefinitionRegisteringParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GatewayParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.MessageHistoryParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.SpelPropertyAccessorsParser
 
parse(Element, ParserContext) - Method in class org.springframework.integration.config.xml.WireTapParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
Override this method to return the BeanDefinition for the MessageConsumer.
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.DefaultOutboundChannelAdapterParser
 
parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.LoggingChannelAdapterParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
Parse the MessageHandler.
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractRouterParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractTransformerParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AggregatorParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.BarrierParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.BridgeParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ChainParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ControlBusParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.DelayerParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.EnricherParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ResequencerParser
 
parseHandler(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ScatterGatherParser
 
parseInnerHandlerDefinition(Element, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
parseInterceptors(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ChannelInterceptorParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ConverterParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.IdempotentReceiverInterceptorParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.IntegrationManagementParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PollerParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PublishingInterceptorParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.RetryAdviceParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.integration.config.xml.TransactionSynchronizationFactoryParser
 
parseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractRouterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractPollingInboundChannelAdapterParser
Subclasses must implement this method to parse the PollableSource instance which the created Channel Adapter will poll.
parseSource(Element, ParserContext) - Method in class org.springframework.integration.config.xml.DefaultInboundChannelAdapterParser
 
parseSource(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ResourceInboundChannelAdapterParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.AbstractTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ClaimCheckInParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ClaimCheckOutParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.HeaderFilterParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.JsonToObjectTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.MapToObjectTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ObjectToMapTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ObjectToStringTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.PayloadDeserializingTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.PayloadSerializingTransformerParser
 
parseTransformer(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.SyslogToMapTransformerParser
 
parseUrl(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
parseWithHeaders(JsonParser, String) - Method in class org.springframework.integration.support.json.Jackson2JsonMessageParser
 
PartialSuccessException - Exception in org.springframework.integration.support
A MessagingException thrown when a non-transactional operation is performing multiple updates from a single message, e.g.
PartialSuccessException(Message<?>, String, Throwable, Collection<?>, Collection<?>) - Constructor for exception org.springframework.integration.support.PartialSuccessException
 
PassThroughMessageGroupProcessor - Class in org.springframework.integration.aggregator
Deprecated.
PassThroughMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.PassThroughMessageGroupProcessor
Deprecated.
 
PassThruLockRegistry - Class in org.springframework.integration.support.locks
The LockRegistry implementation which has no effect.
PassThruLockRegistry() - Constructor for class org.springframework.integration.support.locks.PassThruLockRegistry
 
PassThruMessageConverter - Class in org.springframework.integration.support.converter
The simple MessageConverter implementation which contract is to return Message as is for both from/to operations.
PassThruMessageConverter() - Constructor for class org.springframework.integration.support.converter.PassThruMessageConverter
 
PatternBasedHeaderMatcher(Collection<String>) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.PatternBasedHeaderMatcher
 
Payload - Annotation Type in org.springframework.integration.annotation
Deprecated.
since 4.1 in favor of Payload. Will be removed in a future release.
PayloadDeserializingTransformer - Class in org.springframework.integration.transformer
Transformer that deserializes the inbound byte array payload to an object by delegating to a Converter<byte[], Object>.
PayloadDeserializingTransformer() - Constructor for class org.springframework.integration.transformer.PayloadDeserializingTransformer
 
PayloadDeserializingTransformerParser - Class in org.springframework.integration.config.xml
Parser for the 'payload-deserializing-transformer' element.
PayloadDeserializingTransformerParser() - Constructor for class org.springframework.integration.config.xml.PayloadDeserializingTransformerParser
 
Payloads - Annotation Type in org.springframework.integration.annotation
This annotation marks a method parameter as being a list of message payloads, for POJO handlers that deal with lists of messages (e.g.
PayloadSerializingTransformer - Class in org.springframework.integration.transformer
Transformer that serializes the inbound payload into a byte array by delegating to a Converter<Object, byte[]>.
PayloadSerializingTransformer() - Constructor for class org.springframework.integration.transformer.PayloadSerializingTransformer
 
PayloadSerializingTransformerParser - Class in org.springframework.integration.config.xml
Parser for the 'payload-serializing-transformer' element.
PayloadSerializingTransformerParser() - Constructor for class org.springframework.integration.config.xml.PayloadSerializingTransformerParser
 
payloadType - Variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
PayloadTypeConvertingTransformer<T,U> - Class in org.springframework.integration.transformer
Transformer that converts the inbound payload to an object by delegating to a Converter<Object, Object>.
PayloadTypeConvertingTransformer() - Constructor for class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
 
PayloadTypeRouter - Class in org.springframework.integration.router
A Message Router that resolves the MessageChannel based on the Message's payload type.
PayloadTypeRouter() - Constructor for class org.springframework.integration.router.PayloadTypeRouter
 
PayloadTypeRouterParser - Class in org.springframework.integration.config.xml
Parser for the <payload-type-router/> element.
PayloadTypeRouterParser() - Constructor for class org.springframework.integration.config.xml.PayloadTypeRouterParser
 
PayloadTypeSelector - Class in org.springframework.integration.selector
A MessageSelector implementation that checks the type of the Message payload.
PayloadTypeSelector(Class<?>...) - Constructor for class org.springframework.integration.selector.PayloadTypeSelector
Create a selector for the provided types.
payloadWhenNull(AttributeAccessor) - Method in class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
 
payloadWhenNull(AttributeAccessor) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Build a Throwable payload based on the provided context for future ErrorMessage when there is original Throwable.
peek() - Method in class org.springframework.integration.store.MessageGroupQueue
 
PHASE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
PointToPointChannelParser - Class in org.springframework.integration.config.xml
Parser for the <channel> element.
PointToPointChannelParser() - Constructor for class org.springframework.integration.config.xml.PointToPointChannelParser
 
PojoCodec - Class in org.springframework.integration.codec.kryo
Kryo Codec that can encode and decode arbitrary types.
PojoCodec() - Constructor for class org.springframework.integration.codec.kryo.PojoCodec
 
PojoCodec(KryoRegistrar) - Constructor for class org.springframework.integration.codec.kryo.PojoCodec
Create an instance with a single KryoRegistrar.
PojoCodec(List<KryoRegistrar>) - Constructor for class org.springframework.integration.codec.kryo.PojoCodec
Create an instance with zero to many KryoRegistrars.
PojoCodec(KryoRegistrar, boolean) - Constructor for class org.springframework.integration.codec.kryo.PojoCodec
Create an instance with a single KryoRegistrar.
PojoCodec(List<KryoRegistrar>, boolean) - Constructor for class org.springframework.integration.codec.kryo.PojoCodec
Create an instance with zero to many KryoRegistrars.
poll(long, TimeUnit) - Method in class org.springframework.integration.store.MessageGroupQueue
 
poll() - Method in class org.springframework.integration.store.MessageGroupQueue
 
PollableChannelManagement - Interface in org.springframework.integration.support.management
Metrics for pollable channels.
Poller - Annotation Type in org.springframework.integration.annotation
Provides the PollerMetadata options for the Messaging annotations for polled endpoints.
PollerMetadata - Class in org.springframework.integration.scheduling
 
PollerMetadata() - Constructor for class org.springframework.integration.scheduling.PollerMetadata
 
PollerParser - Class in org.springframework.integration.config.xml
Parser for the <poller> element.
PollerParser() - Constructor for class org.springframework.integration.config.xml.PollerParser
 
PollingConsumer - Class in org.springframework.integration.endpoint
Message Endpoint that connects any MessageHandler implementation to a PollableChannel.
PollingConsumer(PollableChannel, MessageHandler) - Constructor for class org.springframework.integration.endpoint.PollingConsumer
 
pollMessageFromGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
pollMessageFromGroup(Object) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
Polls Message from this MessageGroup (in FIFO style if supported by the implementation) while also removing the polled Message
pollMessageFromGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
PollSkipAdvice - Class in org.springframework.integration.scheduling
An advice that can be added to a poller's advice chain that determines whether a poll should be skipped or not.
PollSkipAdvice() - Constructor for class org.springframework.integration.scheduling.PollSkipAdvice
 
PollSkipAdvice(PollSkipStrategy) - Constructor for class org.springframework.integration.scheduling.PollSkipAdvice
 
PollSkipStrategy - Interface in org.springframework.integration.scheduling
Implementations determine whether a particular poll should be skipped.
pool - Variable in class org.springframework.integration.codec.kryo.AbstractKryoCodec
 
Pool<T> - Interface in org.springframework.integration.util
Represents a pool of items.
popSequenceDetails() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
popSequenceDetails() - Method in class org.springframework.integration.support.MessageBuilder
 
populateJavaTypes(Map<String, Object>, Object) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
populateJavaTypes(Map<String, Object>, Object) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
populatePropagatedContext(S, Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
populateStandardHeaders(Map<String, Object>, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Populate the specified standard headers to the specified source.
populateUserDefinedHeader(String, Object, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Populate the specified user-defined headers to the specified source.
POST_PROCESS_DYNAMIC_BEANS - Static variable in class org.springframework.integration.context.IntegrationProperties
Whether BeanPostProcessors should process beans registered at runtime.
postProcess(Object, String, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
postProcess(Object, String, Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.InboundChannelAdapterAnnotationPostProcessor
 
postProcess(Object, String, Method, List<Annotation>) - Method in interface org.springframework.integration.config.annotation.MethodAnnotationPostProcessor
 
postProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
 
postProcess(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.config.xml.DefaultRouterParser
 
postProcess(Message<?>, Object) - Method in class org.springframework.integration.filter.MessageFilter
 
postProcess(Message<?>, Object) - Method in interface org.springframework.integration.handler.PostProcessingMessageHandler
Take some further action on the result and/or message.
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.integration.expression.IntegrationEvaluationContextAwareBeanPostProcessor
Deprecated.
 
postProcessBeanDefinitionRegistry(BeanDefinitionRegistry) - Method in class org.springframework.integration.config.IntegrationConfigurationBeanFactoryPostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.FixedSubscriberChannelBeanFactoryPostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.integration.config.IntegrationConfigurationBeanFactoryPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.integration.expression.IntegrationEvaluationContextAwareBeanPostProcessor
Deprecated.
 
postProcessFilter(MessageFilter) - Method in class org.springframework.integration.config.FilterFactoryBean
 
postProcessGateway(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
Subclasses may override this method for additional configuration.
postProcessHeaderEnricher(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
Subclasses may override this method to provide any additional processing.
postProcessHeaderEnricher(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.springframework.integration.config.xml.StandardHeaderEnricherParser
 
PostProcessingMessageHandler - Interface in org.springframework.integration.handler
Implementations of this interface are subclasses of AbstractMessageHandler that perform post processing after the AbstractMessageHandler.handleMessageInternal(org.springframework.messaging.Message) call.
postProcessMessage(Message<?>) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
postProcessReplyProducer(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
postProcessReplyProducer(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.FilterFactoryBean
 
postProcessReplyProducer(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
postProcessReplyProducer(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
postProcessReplyProducer(AbstractMessageProducingHandler) - Method in class org.springframework.integration.config.TransformerFactoryBean
 
postReceive(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
postReceive(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
postReceive(Message<?>, MessageChannel) - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
Deprecated.
 
postSend(Message<?>, MessageChannel, boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
PREFIX - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
 
PrefixBasedMatcher(boolean, String) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.PrefixBasedMatcher
 
preReceive(MessageChannel, Deque<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
preSend(Message<?>, MessageChannel, Deque<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.MessageSelectingInterceptor
 
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.WireTap
Intercept the Message and, if accepted by the MessageSelector, send it to the secondary target.
preSend(Message<?>, MessageChannel) - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
Deprecated.
 
PRIORITY - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
PriorityCapableChannelMessageStore - Interface in org.springframework.integration.store
A ChannelMessageStore that supports the notion of message priority.
PriorityChannel - Class in org.springframework.integration.channel
A message channel that prioritizes messages based on a Comparator.
PriorityChannel(int, Comparator<Message<?>>) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with the specified queue capacity.
PriorityChannel(int) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with the specified queue capacity.
PriorityChannel(Comparator<Message<?>>) - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with an unbounded queue.
PriorityChannel() - Constructor for class org.springframework.integration.channel.PriorityChannel
Create a channel with an unbounded queue.
process(Collection<? extends Message<?>>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Processes the Message by evaluating the expression with that Message as the root object.
process(Collection<? extends Message<?>>) - Method in interface org.springframework.integration.aggregator.MessageListProcessor
 
process(Collection<Message<?>>, Map<String, Object>) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
process(Message<?>) - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper
 
process(Collection<Message<?>>, Map<String, ?>) - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper
 
processAfterCommit(IntegrationResourceHolder) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
processAfterCommit(IntegrationResourceHolder) - Method in interface org.springframework.integration.transaction.TransactionSynchronizationProcessor
 
processAfterRollback(IntegrationResourceHolder) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
processAfterRollback(IntegrationResourceHolder) - Method in interface org.springframework.integration.transaction.TransactionSynchronizationProcessor
 
processAnnotationTypeOnMethod(Object, String, Method, Class<? extends Annotation>, List<Annotation>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
processBeforeCommit(IntegrationResourceHolder) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
processBeforeCommit(IntegrationResourceHolder) - Method in interface org.springframework.integration.transaction.TransactionSynchronizationProcessor
 
processHeaders(Element, ManagedMap<String, Object>, ParserContext) - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
processMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.handler.ExpressionCommandMessageProcessor
Evaluates the Message payload expression as a command.
processMessage(Message<?>) - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
Processes the Message by evaluating the expression with that Message as the root object.
processMessage(Message<?>) - Method in interface org.springframework.integration.handler.MessageProcessor
Process the Message and return a value (or null).
processMessage(Message<?>) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.transformer.support.ExpressionEvaluatingHeaderValueMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.transformer.support.RoutingSlipHeaderValueMessageProcessor
 
processMessage(Message<?>) - Method in class org.springframework.integration.transformer.support.StaticHeaderValueMessageProcessor
 
processMessageGroup(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
processMessageGroup(MessageGroup) - Method in interface org.springframework.integration.aggregator.MessageGroupProcessor
Process the given MessageGroup.
processMessageGroup(MessageGroup) - Method in class org.springframework.integration.aggregator.PassThroughMessageGroupProcessor
Deprecated.
 
processMessageGroup(MessageGroup) - Method in class org.springframework.integration.aggregator.ResequencingMessageGroupProcessor
 
processMessageGroup(MessageGroup) - Method in class org.springframework.integration.aggregator.SimpleMessageGroupProcessor
 
produceOutput(Object, Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
produceOutput(Object, Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
PropertiesPersistingMetadataStore - Class in org.springframework.integration.metadata
Properties file-based implementation of MetadataStore.
PropertiesPersistingMetadataStore() - Constructor for class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
PseudoTransactionManager - Class in org.springframework.integration.transaction
An implementation of PlatformTransactionManager that provides transaction-like semantics to MessageSources that are not inherently transactional.
PseudoTransactionManager() - Constructor for class org.springframework.integration.transaction.PseudoTransactionManager
 
publish(MessagingException) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Publish an error message for the supplied exception.
publish(Message<?>, Throwable) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Publish an error message for the supplied message and throwable.
publish(Message<?>, MessagingException) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Publish an error message for the supplied exception.
publish(Message<?>, Message<?>, Throwable) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Publish an error message for the supplied message and throwable.
publish(Throwable, AttributeAccessor) - Method in class org.springframework.integration.support.ErrorMessagePublisher
Publish an error message for the supplied throwable and context.
Publisher - Annotation Type in org.springframework.integration.annotation
Annotation to indicate that a method, or all public methods if applied at class-level, should publish Messages.
PUBLISHER_ANNOTATION_POSTPROCESSOR_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
PublisherAnnotationAdvisor - Class in org.springframework.integration.aop
An advisor that will apply the MessagePublishingInterceptor to any methods containing the provided annotations.
PublisherAnnotationAdvisor(Class<? extends Annotation>...) - Constructor for class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
PublisherAnnotationAdvisor() - Constructor for class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
PublisherAnnotationBeanPostProcessor - Class in org.springframework.integration.aop
Post-processes beans that contain the method-level @Publisher annotation.
PublisherAnnotationBeanPostProcessor() - Constructor for class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
PublisherRegistrar - Class in org.springframework.integration.config
 
PublisherRegistrar() - Constructor for class org.springframework.integration.config.PublisherRegistrar
 
PublishingInterceptorParser - Class in org.springframework.integration.config.xml
Parser for the <publishing-interceptor> element.
PublishingInterceptorParser() - Constructor for class org.springframework.integration.config.xml.PublishingInterceptorParser
 
publishOnGranted(Object, Context, String) - Method in class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
 
publishOnGranted(Object, Context, String) - Method in interface org.springframework.integration.leader.event.LeaderEventPublisher
Publish a granted event.
publishOnRevoked(Object, Context, String) - Method in class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
 
publishOnRevoked(Object, Context, String) - Method in interface org.springframework.integration.leader.event.LeaderEventPublisher
Publish a revoked event.
PublishSubscribeChannel - Class in org.springframework.integration.channel
A channel that sends Messages to each of its subscribers.
PublishSubscribeChannel(Executor) - Constructor for class org.springframework.integration.channel.PublishSubscribeChannel
Create a PublishSubscribeChannel that will use an Executor to invoke the handlers.
PublishSubscribeChannel() - Constructor for class org.springframework.integration.channel.PublishSubscribeChannel
Create a PublishSubscribeChannel that will invoke the handlers in the message sender's thread.
PublishSubscribeChannelParser - Class in org.springframework.integration.config.xml
Parser for the <publish-subscribe-channel> element.
PublishSubscribeChannelParser() - Constructor for class org.springframework.integration.config.xml.PublishSubscribeChannelParser
 
purge() - Method in class org.springframework.integration.channel.ChannelPurger
 
purge(MessageSelector) - Method in class org.springframework.integration.channel.QueueChannel
 
purge(MessageSelector) - Method in interface org.springframework.integration.channel.QueueChannelOperations
Remove any Messages that are not accepted by the provided selector.
pushSequenceDetails(Object, int, int) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
pushSequenceDetails(Object, int, int) - Method in class org.springframework.integration.support.MessageBuilder
 
put(String, Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
put(String, String) - Method in interface org.springframework.integration.metadata.MetadataStore
Writes a key value pair to this MetadataStore.
put(String, String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
put(String, String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
 
put(Message<?>) - Method in class org.springframework.integration.store.MessageGroupQueue
 
put(String, Object) - Method in class org.springframework.integration.support.MutableMessageHeaders
 
putAll(Map<? extends String, ?>) - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
putAll(Map<? extends String, ? extends Object>) - Method in class org.springframework.integration.support.MutableMessageHeaders
 
putIfAbsent(String, String) - Method in interface org.springframework.integration.metadata.ConcurrentMetadataStore
Atomically insert the key into the store.
putIfAbsent(String, String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
putIfAbsent(String, String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
 
putLifecycleInRole(String, String, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 

Q

QueueChannel - Class in org.springframework.integration.channel
Simple implementation of a message channel.
QueueChannel(Queue<Message<?>>) - Constructor for class org.springframework.integration.channel.QueueChannel
Create a channel with the specified queue.
QueueChannel(int) - Constructor for class org.springframework.integration.channel.QueueChannel
Create a channel with the specified queue capacity.
QueueChannel() - Constructor for class org.springframework.integration.channel.QueueChannel
Create a channel with "unbounded" queue capacity.
QueueChannelManagement - Interface in org.springframework.integration.support.management
 
QueueChannelOperations - Interface in org.springframework.integration.channel
Operations available on a channel that has queuing semantics.
queueSemaphore - Variable in class org.springframework.integration.channel.QueueChannel
 

R

read(Kryo, Input, Class<File>) - Method in class org.springframework.integration.codec.kryo.FileSerializer
 
read(Message<?>) - Static method in class org.springframework.integration.history.MessageHistory
 
read(EvaluationContext, Object, String) - Method in class org.springframework.integration.json.JsonPropertyAccessor
 
READ_ONLY_HEADERS - Static variable in class org.springframework.integration.context.IntegrationProperties
readHeaders(P, String) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
readHeaders(JsonInboundMessageMapper.JsonMessageParser<?>, String) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
readOnlyHeaders(String...) - Method in class org.springframework.integration.support.MessageBuilder
 
readPayload(P, String) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
readPayload(JsonInboundMessageMapper.JsonMessageParser<?>, String) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
rebuild() - Method in class org.springframework.integration.support.management.graph.IntegrationGraphServer
Rebuild the graph, re-cache it, and return it.
receive() - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
 
receive() - Method in class org.springframework.integration.channel.AbstractPollableChannel
Receive the first available message from this channel.
receive(long) - Method in class org.springframework.integration.channel.AbstractPollableChannel
Receive the first available message from this channel.
receive() - Method in class org.springframework.integration.channel.NullChannel
 
receive(long) - Method in class org.springframework.integration.channel.NullChannel
 
receive() - Method in interface org.springframework.integration.core.MessageSource
Retrieve the next available message from this source.
receive() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
receive() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
receiveCount - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
receiveErrorCount - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
receiveMessage() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Obtain the next message (if one is available).
receiveMessage() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
receiveMessage() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
receiveMessage() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
Recipient(MessageChannel) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
 
Recipient(MessageChannel, MessageSelector) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
 
RecipientListRouter - Class in org.springframework.integration.router
 <recipient-list-router id="simpleRouter" input-channel="routingChannelA">
     <recipient channel="channel1"/>
     <recipient channel="channel2"/>
 </recipient-list-router>
 
RecipientListRouter() - Constructor for class org.springframework.integration.router.RecipientListRouter
 
RecipientListRouter.Recipient - Class in org.springframework.integration.router
 
RecipientListRouterManagement - Interface in org.springframework.integration.router
Exposes adding/removing individual recipients operations for RecipientListRouter.
RecipientListRouterParser - Class in org.springframework.integration.config.xml
Parser for the <recipient-list-router/> element.
RecipientListRouterParser() - Constructor for class org.springframework.integration.config.xml.RecipientListRouterParser
 
recover(RetryContext) - Method in class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
 
recursiveFindAnnotation(Class<? extends Annotation>, Annotation, List<Annotation>, Set<Annotation>) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
registerBeanDefinition(BeanDefinitionHolder, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
 
registerBeanDefinitionDecorator(String, BeanDefinitionDecorator) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
registerBeanDefinitionDecoratorForAttribute(String, BeanDefinitionDecorator) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
registerBeanDefinitionParser(String, BeanDefinitionParser) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.IntegrationComponentScanRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.IntegrationRegistrar
Invoked by the framework when an @EnableIntegration annotation is encountered.
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.MessageHistoryRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.MessagingGatewayRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.PublisherRegistrar
 
registerConverter(BeanDefinitionRegistry, BeanMetadataElement) - Method in class org.springframework.integration.config.IntegrationConverterInitializer
 
registerMessageGroupExpiryCallback(MessageGroupStore.MessageGroupCallback) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
registerMessageGroupExpiryCallback(MessageGroupStore.MessageGroupCallback) - Method in interface org.springframework.integration.store.MessageGroupStore
Register a callback for when a message group is expired through MessageGroupStore.expireMessageGroups(long).
registerRoleControllerDefinitionIfNecessary(BeanDefinitionRegistry) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
 
registerSpelFunctionBean(BeanDefinitionRegistry, String, String, String) - Static method in class org.springframework.integration.config.IntegrationConfigUtils
 
registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
 
registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.CompositeKryoRegistrar
 
registerTypes(Kryo) - Method in interface org.springframework.integration.codec.kryo.KryoRegistrar
This method is invoked by the PojoCodec and applied to the Kryo instance whenever a new instance is created.
registerTypes(Kryo) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
 
RegistrationIds - Class in org.springframework.integration.codec.kryo
Default registration ids for serializers provided by the framework.
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.springframework.integration.util.CallerBlocksPolicy
 
release() - Method in class org.springframework.integration.util.UpperBound
Releases one lock on the underlying semaphore.
release(int) - Method in class org.springframework.integration.util.UpperBound
Releases several locks on the underlying semaphore.
releaseItem(T) - Method in interface org.springframework.integration.util.Pool
Releases an item back into the pool.
releaseItem(T) - Method in class org.springframework.integration.util.SimplePool
Returns an item to the pool.
ReleaseStrategy - Interface in org.springframework.integration.aggregator
Strategy for determining when a group of messages reaches a state of completion (i.e.
ReleaseStrategy - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of asserting if a list of messages or payload objects is complete.
ReleaseStrategyFactoryBean - Class in org.springframework.integration.config
Convenience factory for XML configuration of a ReleaseStrategy.
ReleaseStrategyFactoryBean() - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
ReleaseStrategyFactoryBean(Object) - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
Deprecated.
since 4.2.5 in favor of appropriate setters to avoid BeanCurrentlyInCreationException during AbstractAutowireCapableBeanFactory.getSingletonFactoryBeanForTypeCheck()
ReleaseStrategyFactoryBean(Object, String) - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
Deprecated.
since 4.2.5 in favor of appropriate setters to avoid BeanCurrentlyInCreationException during AbstractAutowireCapableBeanFactory.getSingletonFactoryBeanForTypeCheck()
ReloadableResourceBundleExpressionSource - Class in org.springframework.integration.expression
ExpressionSource implementation that accesses resource bundles using specified basenames.
ReloadableResourceBundleExpressionSource() - Constructor for class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
 
remainingCapacity() - Method in class org.springframework.integration.store.MessageGroupQueue
 
remove(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
remove(int) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
remove(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
remove(int) - Method in class org.springframework.integration.history.MessageHistory
 
remove(Object) - Method in class org.springframework.integration.history.MessageHistory
 
remove(String) - Method in interface org.springframework.integration.metadata.MetadataStore
Remove a value for the given key from this MetadataStore.
remove(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
remove(String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
 
remove(Message<?>) - Method in interface org.springframework.integration.store.MessageGroup
Remove the message from this group.
remove(UUID) - Method in class org.springframework.integration.store.MessageGroupMetadata
 
remove(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
 
remove(Object) - Method in class org.springframework.integration.support.MutableMessageHeaders
 
remove() - Method in class org.springframework.integration.util.FunctionIterator
 
removeAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
 
removeAllIdleItems() - Method in interface org.springframework.integration.util.Pool
Removes all idle items from the pool.
removeAllIdleItems() - Method in class org.springframework.integration.util.SimplePool
 
removeChannelMapping(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Remove a channel mapping for the given key if present.
removeChannelMapping(String) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
removeChannelMapping(String) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
Remove a channel mapping for the given key if present.
removeChannelMapping(String) - Method in class org.springframework.integration.support.management.RouterMetrics
 
removedFromPool(T) - Method in interface org.springframework.integration.util.SimplePool.PoolItemCallback
Called by the pool when an item is forcibly removed from the pool - for example when the pool size is reduced.
removeHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
Remove the handler from the internal handler Set.
removeHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
 
removeHeader(String) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
Remove the value for the given header name.
removeHeader(String) - Method in class org.springframework.integration.support.MessageBuilder
Remove the value for the given header name.
removeHeader(String) - Method in class org.springframework.integration.support.MutableMessageBuilder
 
removeHeaders(String...) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
Removes all headers provided via array of 'headerPatterns'.
removeHeaders(String...) - Method in class org.springframework.integration.support.MessageBuilder
Removes all headers provided via array of 'headerPatterns'.
removeHeaders(String...) - Method in class org.springframework.integration.support.MutableMessageBuilder
 
removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
 
removeInterceptor(int) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
 
removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
removeInterceptor(int) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
removeInterceptor(int) - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
removeInterceptor(ChannelInterceptor) - Method in interface org.springframework.integration.channel.ChannelInterceptorAware
Remove the provided ChannelInterceptor from the target implementation.
removeInterceptor(int) - Method in interface org.springframework.integration.channel.ChannelInterceptorAware
Remove a ChannelInterceptor from the target implementation for specific index.
removeListener(MetadataStoreListener) - Method in interface org.springframework.integration.metadata.ListenableMetadataStore
Unregisters a listener
removeMessage(UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
removeMessage(UUID) - Method in interface org.springframework.integration.store.MessageStore
Remove the Message with the given id from the MessageStore, if present, and return it.
removeMessage(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
 
removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Deprecated.
removeMessageFromGroup(Object, Message<?>) - Method in interface org.springframework.integration.store.MessageGroupStore
removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.store.SimpleMessageStore
Deprecated.
removeMessageGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Remove the MessageGroup with the provided group ID.
removeMessageGroup(Object) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
Remove the message group with this id.
removeMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
removeMessagesFromGroup(Object, Message<?>...) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in interface org.springframework.integration.store.MessageGroupStore
Persist the deletion of messages from the group.
removeMessagesFromGroup(Object, Message<?>...) - Method in interface org.springframework.integration.store.MessageGroupStore
Persist the deletion of messages from the group.
removeMessagesFromGroup(Object, Collection<Message<?>>) - Method in class org.springframework.integration.store.SimpleMessageStore
 
removeRecipient(String) - Method in class org.springframework.integration.router.RecipientListRouter
 
removeRecipient(String, String) - Method in class org.springframework.integration.router.RecipientListRouter
 
removeRecipient(String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
Remove all recipients that match the channelName.
removeRecipient(String, String) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
Remove all recipients that match the channelName and expression.
RendezvousChannel - Class in org.springframework.integration.channel
A zero-capacity version of QueueChannel that delegates to a SynchronousQueue internally.
RendezvousChannel() - Constructor for class org.springframework.integration.channel.RendezvousChannel
 
replace(String, String, String) - Method in interface org.springframework.integration.metadata.ConcurrentMetadataStore
Atomically replace the value for the key in the store if the old value matches the oldValue argument.
replace(String, String, String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
 
replace(String, String, String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
 
replaceChannelMappings(Properties) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Convenience method allowing conversion of a list of mappings in a control-bus message.
replaceChannelMappings(Properties) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
replaceChannelMappings(Properties) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
Provide mappings from channel keys to channel names.
replaceChannelMappings(Properties) - Method in class org.springframework.integration.support.management.RouterMetrics
 
replaceRecipients(Properties) - Method in class org.springframework.integration.router.RecipientListRouter
 
replaceRecipients(Properties) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
Replace recipient.
replyChannelInChainAllowed(Element) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
Override to allow 'reply-channel' within a chain, for components where it makes sense (e.g.
replyChannelInChainAllowed(Element) - Method in class org.springframework.integration.config.xml.EnricherParser
 
ReplyRequiredException - Exception in org.springframework.integration.handler
Exception that indicates no reply message is produced by a handler that does have a value of true for the 'requiresReply' property.
ReplyRequiredException(Message<?>, String) - Constructor for exception org.springframework.integration.handler.ReplyRequiredException
 
ReplyRequiredException(Message<?>, String, Throwable) - Constructor for exception org.springframework.integration.handler.ReplyRequiredException
 
REQUEST_HANDLER_ADVICE_CHAIN - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
RequestHandlerCircuitBreakerAdvice - Class in org.springframework.integration.handler.advice
A circuit breaker that stops calling a failing service after threshold failures, until halfOpenAfter milliseconds has elapsed.
RequestHandlerCircuitBreakerAdvice() - Constructor for class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
 
RequestHandlerCircuitBreakerAdvice.CircuitBreakerOpenException - Exception in org.springframework.integration.handler.advice
An exception thrown when the circuit breaker is in an open state.
RequestHandlerRetryAdvice - Class in org.springframework.integration.handler.advice
Uses spring-retry to perform stateless or stateful retry.
RequestHandlerRetryAdvice() - Constructor for class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
RequestReplyExchanger - Interface in org.springframework.integration.gateway
Interface for a request/reply Message exchange.
RequestReplyHeaderMapper<T> - Interface in org.springframework.integration.mapping
Request/Reply strategy interface for mapping MessageHeaders to and from other types of objects.
REQUIRE_COMPONENT_ANNOTATION - Static variable in class org.springframework.integration.context.IntegrationProperties
reschedulePersistedMessages() - Method in class org.springframework.integration.handler.DelayHandler
Used for reading persisted Messages in the 'messageStore' to reschedule them e.g.
reschedulePersistedMessages() - Method in interface org.springframework.integration.handler.DelayHandlerManagement
 
ResequencerParser - Class in org.springframework.integration.config.xml
Parser for the <resequencer> element.
ResequencerParser() - Constructor for class org.springframework.integration.config.xml.ResequencerParser
 
ResequencingMessageGroupProcessor - Class in org.springframework.integration.aggregator
This class implements all the strategy interfaces needed for a default resequencer.
ResequencingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.ResequencingMessageGroupProcessor
 
ResequencingMessageHandler - Class in org.springframework.integration.aggregator
Resequencer specific implementation of AbstractCorrelatingMessageHandler.
ResequencingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
 
ResequencingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
 
ResequencingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
 
reset() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
reset() - Method in class org.springframework.integration.channel.NullChannel
 
reset() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
reset() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
reset() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
reset() - Method in class org.springframework.integration.scheduling.SimplePollSkipStrategy
Resume polling at the next Trigger event.
reset() - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
Reset all counters/statistics.
reset() - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
 
reset() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
reset() - Method in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics
 
reset() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
reset() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
reset() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
reset() - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
reset() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
reset() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
reset() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
 
resolveAttribute(List<Annotation>, String, Class<T>) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
Get the attribute value from the annotation hierarchy, returning the first non-empty value closest to the annotated method.
resolveDestination(String) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
 
resolveErrorChannel(MessageHeaders) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.ChainParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalWireTapParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.IntegrationManagementParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.PollerParser
 
resolvePrimitiveType(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
Resolve the given class if it is a primitive wrapper class, returning the corresponding primitive type instead.
resolveTargetBeanFromMethodWithBeanAnnotation(Method) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
resolveTargetBeanName(Method) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
resourceHolder - Variable in class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
 
ResourceInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
Parser for 'resource-inbound-channel-adapter'
ResourceInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.ResourceInboundChannelAdapterParser
 
ResourceRetrievingMessageSource - Class in org.springframework.integration.resource
Implementation of MessageSource based on ResourcePatternResolver which will attempt to resolve Resources based on the pattern specified.
ResourceRetrievingMessageSource(String) - Constructor for class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
retainAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
 
RetryAdviceParser - Class in org.springframework.integration.config.xml
 
RetryAdviceParser() - Constructor for class org.springframework.integration.config.xml.RetryAdviceParser
 
RetryExceptionNotAvailableException(Message<?>, String) - Constructor for exception org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer.RetryExceptionNotAvailableException
 
RetryStateGenerator - Interface in org.springframework.integration.handler.advice
Strategy interface for generating a RetryState instance based on a message.
Role - Annotation Type in org.springframework.integration.annotation
Annotate endpoints to assign them to a role.
ROLE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
RoundRobinLoadBalancingStrategy - Class in org.springframework.integration.dispatcher
Round-robin implementation of LoadBalancingStrategy.
RoundRobinLoadBalancingStrategy() - Constructor for class org.springframework.integration.dispatcher.RoundRobinLoadBalancingStrategy
 
Router - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of resolving to a channel or channel name based on a message, message header(s), or both.
RouterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @Router.
RouterAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.RouterAnnotationPostProcessor
 
RouterFactoryBean - Class in org.springframework.integration.config
Factory bean for creating a Message Router.
RouterFactoryBean() - Constructor for class org.springframework.integration.config.RouterFactoryBean
 
RouterMetrics - Class in org.springframework.integration.support.management
Allows Router operations to appear in the same MBean as statistics.
RouterMetrics(Lifecycle, MappingMessageRouterManagement) - Constructor for class org.springframework.integration.support.management.RouterMetrics
 
ROUTING_SLIP - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
RoutingMessageHandlerNode - Class in org.springframework.integration.support.management.graph
Represents an endpoint that can route to multiple channels.
RoutingMessageHandlerNode(int, String, MessageHandler, String, String, Collection<String>) - Constructor for class org.springframework.integration.support.management.graph.RoutingMessageHandlerNode
 
RoutingSlipHeaderValueMessageProcessor - Class in org.springframework.integration.transformer.support
The RoutingSlip HeaderValueMessageProcessor specific implementation.
RoutingSlipHeaderValueMessageProcessor(Object...) - Constructor for class org.springframework.integration.transformer.support.RoutingSlipHeaderValueMessageProcessor
 
RoutingSlipRouteStrategy - Interface in org.springframework.integration.routingslip
The RoutingSlip strategy to determine the next replyChannel.
run() - Method in class org.springframework.integration.channel.AbstractExecutorChannel.MessageHandlingTask
 
run() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
run() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
Expire all message groups older than the timeout provided.
runReaper() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
Cancel the scheduled reap task and run immediately; then reschedule.
runReaper() - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
Cancel the scheduled reap task and run immediately; then reschedule.

S

ScatterGatherHandler - Class in org.springframework.integration.scattergather
The MessageHandler implementation for the Scatter-Gather EIP pattern.
ScatterGatherHandler(MessageChannel, MessageHandler) - Constructor for class org.springframework.integration.scattergather.ScatterGatherHandler
 
ScatterGatherHandler(MessageHandler, MessageHandler) - Constructor for class org.springframework.integration.scattergather.ScatterGatherHandler
 
ScatterGatherParser - Class in org.springframework.integration.config.xml
Parser for the <scatter-gather> element.
ScatterGatherParser() - Constructor for class org.springframework.integration.config.xml.ScatterGatherParser
 
SelectorChainParser - Class in org.springframework.integration.config.xml
Parser for the <selector-chain/> element.
SelectorChainParser() - Constructor for class org.springframework.integration.config.xml.SelectorChainParser
 
SelectorParser - Class in org.springframework.integration.config.xml
Parser for a top-level <selector/> element.
SelectorParser() - Constructor for class org.springframework.integration.config.xml.SelectorParser
 
semaphore - Variable in class org.springframework.integration.util.UpperBound
 
send(Message<?>) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Send a message on this channel.
send(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Send a message on this channel.
send(Message<?>) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
send(Message<?>, long) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
send(Message<?>) - Method in class org.springframework.integration.channel.NullChannel
 
send(Message<?>, long) - Method in class org.springframework.integration.channel.NullChannel
 
send(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
SEND_TIMEOUT_ATTRIBUTE - Static variable in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
sendAndReceive(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.MessagingTemplate
 
sendAndReceive(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
sendAndReceiveMessage(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
sendCount - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
sendDuration - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
sendErrorCount - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
sendErrorMessage(Message<?>, Throwable) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
sendErrorMessageIfNecessary(Message<?>, RuntimeException) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Send an error message based on the exception and message.
sendErrorRate - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
sendMessage(Message<?>) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
sendOutput(Object, Object, boolean) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Send an output Message.
sendOutputs(Object, Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
sendRate - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
sendSuccessRatio - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
SEQUENCE_DETAILS - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
SEQUENCE_NUMBER - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
SEQUENCE_SIZE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
SequenceAwareMessageGroup(MessageGroup) - Constructor for class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler.SequenceAwareMessageGroup
 
SequenceNumberComparator - Class in org.springframework.integration.aggregator
 
SequenceNumberComparator() - Constructor for class org.springframework.integration.aggregator.SequenceNumberComparator
 
SequenceSizeReleaseStrategy - Class in org.springframework.integration.aggregator
An implementation of ReleaseStrategy that simply compares the current size of the message list to the expected 'sequenceSize'.
SequenceSizeReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
 
SequenceSizeReleaseStrategy(boolean) - Constructor for class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
 
serialize(MessageHeaders, JsonGenerator, SerializerProvider) - Method in class org.springframework.integration.support.json.MessageHeadersJacksonSerializer
 
serializeWithType(MessageHeaders, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class org.springframework.integration.support.json.MessageHeadersJacksonSerializer
 
ServiceActivatingHandler - Class in org.springframework.integration.handler
 
ServiceActivatingHandler(Object) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
 
ServiceActivatingHandler(Object, Method) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
 
ServiceActivatingHandler(Object, String) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
 
ServiceActivatingHandler(MessageProcessor<T>) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
 
ServiceActivator - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of handling a message or message payload.
ServiceActivatorAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @ServiceActivator.
ServiceActivatorAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.ServiceActivatorAnnotationPostProcessor
 
ServiceActivatorFactoryBean - Class in org.springframework.integration.config
FactoryBean for creating ServiceActivatingHandler instances.
ServiceActivatorFactoryBean() - Constructor for class org.springframework.integration.config.ServiceActivatorFactoryBean
 
ServiceActivatorParser - Class in org.springframework.integration.config.xml
Parser for the <service-activator> element.
ServiceActivatorParser() - Constructor for class org.springframework.integration.config.xml.ServiceActivatorParser
 
set(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
set(int, Properties) - Method in class org.springframework.integration.history.MessageHistory
 
setActivePollPeriod(long) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
Set the poll period when messages are returned.
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Set the advice chain to be configured within an AbstractReplyProducingMessageHandler to advise just this local endpoint.
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setAdviceMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for AdviceMessage.
setAfterCommitChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setAfterCommitExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setAfterRollbackChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setAfterRollbackExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.support.management.graph.IntegrationGraphServer
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
setApplicationName(String) - Method in class org.springframework.integration.support.management.graph.IntegrationGraphServer
Set the application name that will appear in the 'contentDescriptor' under the 'name' key.
setApplySequence(boolean) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
Specify whether to apply the sequence number and size headers to the messages prior to invoking the subscribed handlers.
setApplySequence(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setApplySequence(boolean) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setApplySequence(boolean) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
Specify whether to apply sequence numbers to the messages prior to sending to the handlers.
setApplySequence(boolean) - Method in class org.springframework.integration.router.AbstractMessageRouter
Specify whether to apply the sequence number and size headers to the messages prior to sending to the recipient channels.
setApplySequence(boolean) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Set the applySequence flag to the specified value.
setAsync(Boolean) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Currently only exposed on the service activator namespace.
setAsync(boolean) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Allow async replies.
setAsyncExecutor(Executor) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the executor for use when the gateway method returns Future or ListenableFuture.
setAutoStartup(Boolean) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
setAutoStartup(boolean) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
setAutoStartup(boolean) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
setBaseDirectory(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
Set the location for the properties file.
setBasename(String) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set a single basename, following the basic ResourceBundle convention of not specifying file extension or language codes, but referring to a Spring resource location: e.g.
setBasenames(String[]) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set an array of basenames, each following the basic ResourceBundle convention of not specifying file extension or language codes, but referring to a Spring resource location: e.g.
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.IntegrationRegistrar
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.MessagingGatewayRegistrar
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.json.JsonToObjectTransformer
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.channel.interceptor.WireTap
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.GlobalChannelInterceptorProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.core.MessagingTemplate
Overridden to set the destination resolver to a BeanFactoryChannelResolver.
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.expression.IntegrationEvaluationContextAwareBeanPostProcessor
Deprecated.
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.converter.MapMessageConverter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.ErrorMessagePublisher
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.support.ExpressionEvaluatingHeaderValueMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.support.MessageProcessingHeaderValueMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.support.RoutingSlipHeaderValueMessageProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
Specify a BeanFactory in order to enable resolution via @beanName in the expression.
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
setBeanName(String) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
setBeanName(String) - Method in class org.springframework.integration.channel.NullChannel
 
setBeanName(String) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
 
setBeanName(String) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setBeanName(String) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setBeanName(String) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
 
setBeforeCommitChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setBeforeCommitExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setBusyWaitMillis(long) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
setCacheSeconds(int) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set the number of seconds to cache loaded properties files.
setChannel(MessageChannel) - Method in class org.springframework.integration.support.ErrorMessagePublisher
 
setChannelAttributeName(String) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
setChannelMap(Map<String, String>) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
setChannelMapping(String, String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Add a channel mapping from the provided key to channel name.
setChannelMapping(String, String) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
setChannelMapping(String, String) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
Add a channel mapping from the provided key to channel name.
setChannelMapping(String, String) - Method in class org.springframework.integration.support.management.RouterMetrics
 
setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Provide mappings from channel keys to channel names.
setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
setChannelMappings(Map<String, String>) - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
Provide mappings from channel keys to channel names.
setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.support.management.RouterMetrics
 
setChannelName(String) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
setChannelName(String) - Method in class org.springframework.integration.support.ErrorMessagePublisher
 
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Set the handler's channel resolver.
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
Specify the DestinationResolver strategy to use.
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
Specify the DestinationResolver strategy to use.
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.context.IntegrationObjectSupport
Specify the DestinationResolver strategy to use.
setChannelResolver(DestinationResolver<MessageChannel>) - Method in class org.springframework.integration.support.ErrorMessagePublisher
 
setChannels(List<MessageChannel>) - Method in class org.springframework.integration.router.RecipientListRouter
Set the channels for this router.
setClassifier(Classifier<? super Throwable, Boolean>) - Method in class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
 
setComponentName(String) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Sets the name of the handler component.
setComponentName(String) - Method in class org.springframework.integration.context.IntegrationObjectSupport
Sets the name of this component.
setComponentNamePatterns(String[]) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
The patterns for which components will be tracked; default '*' (all trackable components).
setComponentNamePatternsSet(Set<String>) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
The patterns for which components will be tracked; default '*' (all trackable components).
setComponentNamePatternsString(String) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
A comma-delimited list of patterns for which components will be tracked; default '*' (all trackable components).
setComponentType(String) - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
 
setComponentType(String) - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
setContentType(String) - Method in class org.springframework.integration.json.ObjectToJsonTransformer
Sets the content-type header value
setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
 
setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
 
setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
 
setConversionService(ConversionService) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setConversionService(ConversionService) - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
setConversionService(ConversionService) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
setConversionService(ConversionService) - Method in class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
Specify the ConversionService to use when trying to convert to requested type.
setConversionService(ConversionService) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
setConversionService(ConversionService) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
 
setConverter(Converter<T, U>) - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
Specify the converter to use.
setCopyOnGet(boolean) - Method in class org.springframework.integration.store.SimpleMessageStore
Set to false to disable copying the group in SimpleMessageStore.getMessageGroup(Object).
setCorrelationId(Object) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setCorrelationId(Object) - Method in class org.springframework.integration.support.MessageBuilder
 
setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
Set the CorrelationStrategy to be used to determine the correlation key for incoming messages
setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.channel.NullChannel
 
setCountsEnabled(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
setCountsEnabled(boolean) - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
setCountsEnabled(boolean) - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
setDatatypes(Class<?>...) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Specify the Message payload datatype(s) supported by this channel.
setDefaultChannel(MessageChannel) - Method in class org.springframework.integration.core.MessagingTemplate
Invokes setDefaultDestination(MessageChannel) - provided for backward compatibility.
setDefaultChannelName(String) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setDefaultChannelName(String) - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
setDefaultChannelName(String) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
Set the default channel where Messages should be sent if the annotation itself does not provide a channel.
setDefaultCountsEnabled(Boolean) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Set whether managed components maintain message counts by default.
setDefaultDelay(long) - Method in class org.springframework.integration.handler.DelayHandler
Set the default delay in milliseconds.
setDefaultEncoding(String) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set the default charset to use for parsing properties files.
setDefaultErrorChannel(MessageChannel) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
setDefaultErrorChannelName(String) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
Specify the bean name of default error channel for this error handler.
setDefaultLoggingEnabled(boolean) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Disable all logging in the normal message flow in framework components.
setDefaultOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setDefaultOutputChannel(MessageChannel) - Method in class org.springframework.integration.router.AbstractMessageRouter
Set the default channel where Messages should be sent if channel resolution fails to return any channels.
setDefaultOutputChannelName(String) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setDefaultOutputChannelName(String) - Method in class org.springframework.integration.router.AbstractMessageRouter
 
setDefaultOverwrite(boolean) - Method in class org.springframework.integration.transformer.HeaderEnricher
 
setDefaultReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default reply channel.
setDefaultReplyChannelName(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default reply channel bean name.
setDefaultReplyTimeout(Long) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default timeout value for receiving reply messages.
setDefaultRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default request channel.
setDefaultRequestChannelName(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default request channel bean name.
setDefaultRequestTimeout(Long) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default timeout value for sending request messages.
setDefaultStatsEnabled(Boolean) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Set whether managed components maintain message statistics by default.
setDelayedAdviceChain(List<Advice>) - Method in class org.springframework.integration.handler.DelayHandler
Specify the List<Advice> to advise DelayHandler.ReleaseMessageHandler proxy.
setDelayExpression(Expression) - Method in class org.springframework.integration.handler.DelayHandler
Specify the Expression that should be checked for a delay period (in milliseconds) or a Date to delay until.
setDelimiters(String) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setDelimiters(String) - Method in class org.springframework.integration.splitter.DefaultMessageSplitter
Set delimiters to use for tokenizing String values.
setDeserializer(Deserializer<Object>) - Method in class org.springframework.integration.transformer.PayloadDeserializingTransformer
 
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
Set the channel to which late arriving trigger messages are sent.
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.config.FilterFactoryBean
 
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.filter.MessageFilter
Specify a channel where rejected Messages should be sent.
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
Specify a channel where rejected Messages should be sent.
setDiscardChannelName(String) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setDiscardChannelName(String) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
Set the name of the channel to which late arriving trigger messages are sent.
setDiscardChannelName(String) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setDiscardChannelName(String) - Method in class org.springframework.integration.filter.MessageFilter
 
setDiscardWithinAdvice(boolean) - Method in class org.springframework.integration.config.FilterFactoryBean
 
setDiscardWithinAdvice(boolean) - Method in class org.springframework.integration.filter.MessageFilter
Set to 'true' if you wish the discard processing to occur within any request handler advice applied to this filter.
setDynamicChannelLimit(int) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Set a limit for how many dynamic channels are retained (for reporting purposes).
setEnabledCountsPatterns(String[]) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Set the array of simple patterns for component names for which message counts will be enabled (defaults to '*').
setEnabledStatsPatterns(String[]) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Set the array of simple patterns for component names for which message statistics will be enabled (response times, rates etc), as well as counts (a positive match here overrides enabledCountsPatterns, you can't have statistics without counts).
setEnvironment(Environment) - Method in class org.springframework.integration.config.IntegrationComponentScanRegistrar
 
setEnvironment(Environment) - Method in class org.springframework.integration.config.IntegrationManagementConfiguration
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the error channel.
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the error channel.
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.support.MessageBuilder
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.transformer.ContentEnricher
Set the content enricher's error channel to allow the error handling flow to return of an alternative object to use for enrichment if exceptions occur in the downstream flow.
setErrorChannelName(String) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Set the error channel name.
setErrorChannelName(String) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the error channel name.
setErrorChannelName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the error channel name.
setErrorChannelName(String) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setErrorChannelName(String) - Method in class org.springframework.integration.support.MessageBuilder
 
setErrorChannelName(String) - Method in class org.springframework.integration.transformer.ContentEnricher
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
Provide an ErrorHandler strategy for handling Exceptions that occur downstream from this channel.
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setErrorMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for ErrorMessage.
setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Set an ErrorMessageStrategy to use to build an error message when a exception occurs.
setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set an ErrorMessageStrategy to use to build an error message when a exception occurs.
setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.support.ErrorMessagePublisher
 
setEvaluationContext(StandardEvaluationContext) - Method in class org.springframework.integration.transformer.DecodingTransformer
 
setExecutor(Executor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
 
setExpectedType(Class<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
 
setExpectedType(Class<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Set the result type expected from evaluation of the expression.
setExpirationDate(Long) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setExpirationDate(Date) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setExpirationDate(Long) - Method in class org.springframework.integration.support.MessageBuilder
 
setExpirationDate(Date) - Method in class org.springframework.integration.support.MessageBuilder
 
setExpireGroupsUponCompletion(boolean) - Method in class org.springframework.integration.aggregator.AggregatingMessageHandler
Will set the 'expireGroupsUponCompletion' flag.
setExpireGroupsUponCompletion(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setExpireGroupsUponTimeout(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Expire (completely remove) a group if it is completed due to timeout.
setExpireGroupsUponTimeout(boolean) - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
Expire (completely remove) a group if it is completed due to timeout.
setExpireGroupsUponTimeout(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setExpireOnDestroy(boolean) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
Flag to indicate that the stores should be expired when this component is destroyed (i.e.
setExpiryCallbacks(Collection<MessageGroupStore.MessageGroupCallback>) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
Convenient injection point for expiry callbacks in the message store.
setExpression(Expression) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
Set a SpEL expression to use.
setExpression(String) - Method in class org.springframework.integration.handler.LoggingHandler
setExpressionOnFailure(Expression) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the expression to evaluate against the root message after a failed handler invocation.
setExpressionOnSuccess(Expression) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the expression to evaluate against the message after a successful handler invocation.
setExpressionPayload(Expression) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
setExpressionString(String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
Set a SpEL expression to use.
setFailover(boolean) - Method in class org.springframework.integration.channel.DirectChannel
Specify whether the channel's dispatcher should have failover enabled.
setFailover(boolean) - Method in class org.springframework.integration.channel.ExecutorChannel
Specify whether the channel's dispatcher should have failover enabled.
setFailover(boolean) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
Specify whether this dispatcher should failover when a single MessageHandler throws an Exception.
setFailureChannel(MessageChannel) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the channel to which to send the ErrorMessage after evaluating the failure expression.
setFailureChannelName(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the channel name to which to send the ErrorMessage after evaluating the failure expression.
setFallbackToSystemLocale(boolean) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set whether to fall back to the system Locale if no files for a specific Locale have been found.
setFileEncodings(Properties) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set per-file charsets to use for parsing properties files.
setFileName(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
Set the name of the properties file in PropertiesPersistingMetadataStore.setBaseDirectory(String).
setFilter(CollectionFilter<Resource>) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
setFilterHeadersInToMessage(boolean) - Method in class org.springframework.integration.support.converter.MapMessageConverter
By default all headers on Map passed to MapMessageConverter.toMessage(Object, MessageHeaders) will be mapped.
setFixedRate(boolean) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Specify whether the periodic interval should be measured between the scheduled start times rather than between actual completion times.
setForceReleaseAdviceChain(List<Advice>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setForceReleaseAdviceChain(List<Advice>) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setFullStatsEnabled(boolean) - Method in class org.springframework.integration.support.management.AbstractMessageChannelMetrics
When false, simple counts are maintained; when true complete statistics are maintained.
setFullStatsEnabled(boolean) - Method in class org.springframework.integration.support.management.AbstractMessageHandlerMetrics
When false, simple counts are maintained; when true complete statistics are maintained.
setFunctions(Map<String, Method>) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
setGatherChannel(MessageChannel) - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
setGatherTimeout(long) - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
setGenericMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for GenericMessage.
setGlobalMethodMetadata(GatewayMethodMetadata) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setGroupTimeoutExpression(Expression) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setGroupTimeoutExpression(Expression) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setHalfOpenAfter(long) - Method in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
 
setHandler(MessageHandler) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setHandlers(List<MessageHandler>) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
setHashMapRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for HashMap.
setHeader(String, Object) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
Set the value for the given header name.
setHeader(String, Object) - Method in class org.springframework.integration.support.MessageBuilder
Set the value for the given header name.
setHeader(String, Object) - Method in class org.springframework.integration.support.MutableMessageBuilder
 
setHeaderExpressionMap(Map<String, Map<String, String>>) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
setHeaderExpressions(Map<String, String>) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setHeaderExpressions(Map<String, HeaderValueMessageProcessor<?>>) - Method in class org.springframework.integration.transformer.ContentEnricher
Provide the map of HeaderValueMessageProcessor to evaluate when enriching the target MessageHeaders.
setHeaderIfAbsent(String, Object) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
Set the value for the given header name only if the header name is not already associated with a value.
setHeaderIfAbsent(String, Object) - Method in class org.springframework.integration.support.MessageBuilder
Set the value for the given header name only if the header name is not already associated with a value.
setHeaderIfAbsent(String, Object) - Method in class org.springframework.integration.support.MutableMessageBuilder
 
setHeaderNames(String...) - Method in class org.springframework.integration.support.converter.MapMessageConverter
setHeaderTypes(Map<String, Class<?>>) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
setHeartBeatMillis(long) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
setIdlePollPeriod(long) - Method in class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
Set the poll period when messages are not returned.
setIgnoreExpressionFailures(boolean) - Method in class org.springframework.integration.handler.DelayHandler
Specify whether Exceptions thrown by DelayHandler.delayExpression evaluation should be ignored (only logged).
setIgnoreFailures(boolean) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
Specify whether failures for one or more of the handlers should be ignored.
setIgnoreFailures(boolean) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
Specify whether failures for one or more of the handlers should be ignored.
setIgnoreSendFailures(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setIgnoreSendFailures(boolean) - Method in class org.springframework.integration.router.AbstractMessageRouter
Specify whether send failures for one or more of the recipients should be ignored.
setImportMetadata(AnnotationMetadata) - Method in class org.springframework.integration.config.IntegrationManagementConfiguration
 
setInboundMessageMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
setInitialDelay(long) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Specify the delay for the initial execution.
setInitialValue(int) - Method in class org.springframework.integration.codec.kryo.KryoClassListRegistrar
Set the inital ID value.
setInputChannel(MessageChannel) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setInputChannelName(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
setIntegrationEvaluationContext(EvaluationContext) - Method in interface org.springframework.integration.expression.IntegrationEvaluationContextAware
Deprecated.
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.transformer.ContentEnricher
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Set the list of channel interceptors.
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
setInterceptors(List<ChannelInterceptor>) - Method in interface org.springframework.integration.channel.ChannelInterceptorAware
Populate the ChannelInterceptors to the target implementation.
setLastModified(long) - Method in interface org.springframework.integration.store.MessageGroup
 
setLastModified(long) - Method in class org.springframework.integration.store.SimpleMessageGroup
 
setLastReleasedMessageSequenceNumber(int) - Method in interface org.springframework.integration.store.MessageGroup
 
setLastReleasedMessageSequenceNumber(int) - Method in class org.springframework.integration.store.SimpleMessageGroup
 
setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
setLastReleasedSequenceNumberForGroup(Object, int) - Method in interface org.springframework.integration.store.MessageGroupStore
Allows you to set the sequence number of the last released Message.
setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.store.SimpleMessageStore
 
setLazyLoadMessageGroups(boolean) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
Specify if the result of the BasicMessageGroupStore.getMessageGroup(Object) should be wrapped to the PersistentMessageGroup - a lazy-load proxy for messages in group Defaults to true.
setLazyLoadMessageGroups(boolean) - Method in class org.springframework.integration.store.SimpleMessageStore
 
setLeaderEventPublisher(LeaderEventPublisher) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
setLevel(LoggingHandler.Level) - Method in class org.springframework.integration.handler.LoggingHandler
Set the logging LoggingHandler.Level to change the behavior at runtime.
setLoadBalancingStrategy(LoadBalancingStrategy) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
Provide a LoadBalancingStrategy for this dispatcher.
setLockRegistry(LockRegistry) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setLockRegistry(LockRegistry) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setLockRegistry(LockRegistry) - Method in class org.springframework.integration.store.SimpleMessageStore
 
setLogExpression(Expression) - Method in class org.springframework.integration.handler.LoggingHandler
Set an Expression to evaluate a log entry at runtime against the request Message.
setLogExpressionString(String) - Method in class org.springframework.integration.handler.LoggingHandler
Set a SpEL expression string to use.
setLoggerName(String) - Method in class org.springframework.integration.handler.LoggingHandler
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.channel.NullChannel
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
setLoggingEnabled(boolean) - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
setLoggingEnabled(boolean) - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
setManagedName(String) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setManagedName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
setManagedName(String) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
setManagedName(String) - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
setManagedName(String) - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
setManagedName(String) - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
setManagedName(String) - Method in interface org.springframework.integration.support.management.MessageSourceMetrics
 
setManagedType(String) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
setManagedType(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
setManagedType(String) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
setManagedType(String) - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
setManagedType(String) - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
setManagedType(String) - Method in interface org.springframework.integration.support.management.MessageHandlerMetrics
 
setManagedType(String) - Method in interface org.springframework.integration.support.management.MessageSourceMetrics
 
setMapper(MethodArgsMessageMapper) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Provide a custom MethodArgsMessageMapper to map from a MethodArgsHolder to a Message.
setMapper(ObjectMapper) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
 
setMapToPayload(boolean) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
 
setMaxMessagesPerPoll(long) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setMaxMessagesPerPoll(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
Set the maximum number of messages to receive for each poll.
setMaxSubscribers(int) - Method in class org.springframework.integration.channel.AbstractExecutorChannel
Specify the maximum number of subscribers supported by the channel's dispatcher.
setMaxSubscribers(int) - Method in class org.springframework.integration.channel.DirectChannel
Specify the maximum number of subscribers supported by the channel's dispatcher.
setMaxSubscribers(int) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
Set the maximum subscribers allowed by this dispatcher.
setMean(double) - Method in class org.springframework.integration.support.management.Statistics
 
setMessage(Message<?>) - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
 
setMessageBuilderFactory(MessageBuilderFactory) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setMessageBuilderFactory(MessageBuilderFactory) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Specify the MessageConverter to use when trying to convert to one of this channel's supported datatypes (in order) for a Message whose payload does not already match.
setMessageGroupFactory(MessageGroupFactory) - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
Specify the MessageGroupFactory to create MessageGroup object where it is necessary.
setMessageGroupStore(MessageGroupStore) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
A message group store to expire according the other configurations.
setMessageHandlingTaskDecorator(MessageHandlingTaskDecorator) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
setMessageHandlingTaskDecorator(MessageHandlingTaskDecorator) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
 
setMessageHeadersRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for MessageHeaders.
setMessageProcessor(MessageProcessor<T>) - Method in class org.springframework.integration.transformer.HeaderEnricher
 
setMessageStore(MessageGroupStore) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setMessageStore(MessageGroupStore) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setMessageStore(MessageGroupStore) - Method in class org.springframework.integration.handler.DelayHandler
Specify the MessageGroupStore that should be used to store Messages while awaiting the delay.
setMethod(Method) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
setMethodMetadataMap(Map<String, GatewayMethodMetadata>) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setMethodName(String) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setMethodName(String) - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
setMethodName(String) - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
setMethodName(String) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
setMetrics(AbstractMessageHandlerMetrics) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setMetricsFactory(MetricsFactory) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Set a metrics factory.
setMetricsFactoryBeanName(String) - Method in class org.springframework.integration.support.management.IntegrationManagementConfigurer
Set a metrics factory bean name.
setMinimumTimeoutForEmptyGroups(long) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
By default, when a MessageGroupStoreReaper is configured to expire partial groups, empty groups are also removed.
setMinimumTimeoutForEmptyGroups(Long) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setMinSubscribers(int) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
If at least this number of subscribers receive the message, AbstractMessageChannel.send(org.springframework.messaging.Message) will return true.
setMinSubscribers(int) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
If at least this number of subscribers receive the message, BroadcastingDispatcher.dispatch(Message) will return true.
setMutableMessageHeadersRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for MutableMessageHeaders.
setMutableMessageRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for MutableMessage.
setNotPropagatedHeaders(String...) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Set headers that will NOT be copied from the inbound message if shouldCopyRequestHeaaders is true.
setNotPropagatedHeaders(String...) - Method in interface org.springframework.integration.handler.HeaderPropagationAware
Set headers that will NOT be copied from the inbound message if the handler is configured to copy headers.
setNullResultHeaderExpressions(Map<String, HeaderValueMessageProcessor<?>>) - Method in class org.springframework.integration.transformer.ContentEnricher
 
setNullResultPropertyExpressions(Map<String, Expression>) - Method in class org.springframework.integration.transformer.ContentEnricher
 
setObject(Object) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
setObjectMapper(ObjectMapper) - Method in class org.springframework.integration.json.JsonPropertyAccessor
 
setOnFailureExpression(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
setOnFailureExpressionString(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the expression to evaluate against the root message after a failed handler invocation.
setOnSuccessExpression(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
setOnSuccessExpressionString(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the expression to evaluate against the message after a successful handler invocation.
setOrder(int) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
setOrder(int) - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
setOrder(Integer) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Set the order in which the handler will be subscribed to its channel (when subscribable).
setOrder(int) - Method in interface org.springframework.integration.context.Orderable
Set the order for this component.
setOrder(int) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
setOutboundMessageMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Set the handler's output channel.
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setOutputChannel(MessageChannel) - Method in interface org.springframework.integration.core.MessageProducer
Specify the MessageChannel to which produced Messages should be sent.
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Specify the MessageChannel where Messages should be sent.
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
setOutputChannelIfPresent(List<Annotation>, AbstractReplyProducingMessageHandler) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
setOutputChannelName(String) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setOutputChannelName(String) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setOutputChannelName(String) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Set the output channel name; overrides outputChannel if provided.
setOutputChannelName(String) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
setOutputChannelName(String) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
setOverride(Trigger) - Method in class org.springframework.integration.util.CompoundTrigger
Set the override trigger; set to null to revert to using the primary trigger.
setOverwrite(Boolean) - Method in class org.springframework.integration.transformer.support.AbstractHeaderValueMessageProcessor
 
setParserConfiguration(SpelParserConfiguration) - Method in class org.springframework.integration.config.ExpressionFactoryBean
 
setPatternMatch(boolean) - Method in class org.springframework.integration.transformer.HeaderFilter
 
setPatternResolver(ResourcePatternResolver) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
setPatterns(String[]) - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
setPayloadExpression(String) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
setPayloadExpression(Expression) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
setPayloadExpression(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setPayloadExpressionString(String) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
setPayloadType(JavaType) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
 
setPeriod(long) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Specify the period of the trigger.
setPhase(int) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setPhase(int) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setPhase(int) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
setPhase(int) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
setPhase(int) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
setPollerMetadata(PollerMetadata) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setPollerMetadata(PollerMetadata) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setPoolSize(int) - Method in class org.springframework.integration.util.SimplePool
Adjusts the current pool size.
setPostProcessWithinAdvice(boolean) - Method in class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
Specify whether the post processing should occur within the scope of any configured advice classes.
setPrefix(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Specify a prefix to be added to each channel name prior to resolution.
setPrimary(Trigger) - Method in class org.springframework.integration.util.CompoundTrigger
Set the primary trigger.
setPrimaryExpression(Expression) - Method in class org.springframework.integration.context.IntegrationObjectSupport
For expression-based components, set the primary expression.
setPriority(boolean) - Method in class org.springframework.integration.store.MessageGroupQueue
If true, ensures that the message store supports priority.
setPriority(Integer) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setPriority(Integer) - Method in class org.springframework.integration.support.MessageBuilder
 
setProcessorBean(Object) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setPropagateEvaluationFailures(boolean) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
If true and an onSuccess expression evaluation fails with an exception, the exception will be thrown to the caller.
setPropertiesPersister(PropertiesPersister) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set the PropertiesPersister to use for parsing properties files.
setPropertyAccessors(Map<String, PropertyAccessor>) - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
setPropertyExpressions(Map<String, Expression>) - Method in class org.springframework.integration.transformer.ContentEnricher
Provide the map of expressions to evaluate when enriching the target payload.
setPublisherMetadataSource(PublisherMetadataSource) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setReactorEnvironment(Object) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Deprecated.
with no-op in favor of global JVM-wide Reactor configuration.
setReadOnlyHeaders(String...) - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
Specify a list of headers which should be considered as read only and prohibited from being populated in the message.
setReadOnlyHeaders(String...) - Method in class org.springframework.integration.support.DefaultMessageBuilderFactory
Specify a list of headers which should be considered as a read only and prohibited from the population to the message.
setReaperDelay(long) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
Set the reaper delay.
setReceiveTimeout(long) - Method in class org.springframework.integration.endpoint.PollingConsumer
 
setReceiveTimeout(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setRecipientMappings(Map<String, String>) - Method in class org.springframework.integration.router.RecipientListRouter
Set the recipients for this router.
setRecipientMappings(Map<String, String>) - Method in interface org.springframework.integration.router.RecipientListRouterManagement
Set recipients.
setRecipients(List<RecipientListRouter.Recipient>) - Method in class org.springframework.integration.router.RecipientListRouter
Set the recipients for this router.
setRecoveryCallback(RecoveryCallback<Object>) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property reference to a bean.
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property reference to a bean.
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
setReleasePartialSequences(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Set releasePartialSequences on an underlying SequenceSizeReleaseStrategy.
setReleasePartialSequences(boolean) - Method in class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
Flag that determines if partial sequences are allowed.
setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
Set the ReleaseStrategy that should be used when deciding if a group in this barrier may be released.
setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setRemoveBatchSize(int) - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
Set the batch size when bulk removing messages from groups for message stores that support batch removal.
setRemoveMessage(boolean) - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
 
setRemoveOnGet(boolean) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
Set to true to immediately remove the channel mapping when DefaultHeaderChannelRegistry.channelNameToChannel(String) is invoked.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the reply channel.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.support.MessageBuilder
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.transformer.ContentEnricher
Sets the content enricher's reply channel.
setReplyChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setReplyChannelName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the reply channel name.
setReplyChannelName(String) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setReplyChannelName(String) - Method in class org.springframework.integration.support.MessageBuilder
 
setReplyChannelName(String) - Method in class org.springframework.integration.transformer.ContentEnricher
 
setReplyHeaderNames(String...) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Provide the header names that should be mapped to a response from a MessageHeaders.
setReplyMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Provide an OutboundMessageMapper for mapping to objects from any reply Messages received in receive or sendAndReceive operations.
setReplyTimeout(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setReplyTimeout(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the timeout value for receiving reply messages.
setReplyTimeout(Long) - Method in class org.springframework.integration.transformer.ContentEnricher
Set the timeout value for receiving reply messages.
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the request channel.
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.transformer.ContentEnricher
Sets the content enricher's request channel.
setRequestChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setRequestChannelName(String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the request channel name.
setRequestChannelName(String) - Method in class org.springframework.integration.transformer.ContentEnricher
 
setRequestHeaderNames(String...) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Provide the header names that should be mapped from a request to a MessageHeaders.
setRequestMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Provide an InboundMessageMapper for creating request Messages from any object passed in a send or sendAndReceive operation.
setRequestPayloadExpression(Expression) - Method in class org.springframework.integration.transformer.ContentEnricher
By default the original message's payload will be used as the actual payload that will be send to the request-channel.
setRequestTimeout(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
setRequestTimeout(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Set the timeout value for sending request messages.
setRequestTimeout(Long) - Method in class org.springframework.integration.transformer.ContentEnricher
Set the timeout value for sending request messages.
setRequireComponentAnnotation(boolean) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
setRequiresReply(Boolean) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
setRequiresReply(boolean) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setRequiresReply(boolean) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
Flag whether a reply is required.
setResolutionRequired(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setResolutionRequired(boolean) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Specify whether this router should ignore any failure to resolve a channel name to an actual MessageChannel instance when delegating to the ChannelResolver strategy.
setResourceLoader(ResourceLoader) - Method in class org.springframework.integration.config.IntegrationComponentScanRegistrar
 
setResourceLoader(ResourceLoader) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Set the ResourceLoader to use for loading bundle properties files.
setRetryStateGenerator(RetryStateGenerator) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
 
setReturnFailureExpressionResult(boolean) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
If true, the result of evaluating the onFailureExpression will be returned as the result of AbstractReplyProducingMessageHandler.handleRequestMessage(Message).
setSelectors(List<MessageSelector>) - Method in class org.springframework.integration.selector.MessageSelectorChain
Initialize the selector chain.
setSendPartialResultOnExpiry(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setSendPartialResultOnExpiry(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setSendTimeout(long) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.ExpressionControlBusFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.FilterFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
 
setSendTimeout(long) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.SplitterFactoryBean
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.TransformerFactoryBean
 
setSendTimeout(long) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
setSendTimeout(long) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Specify the maximum time to wait for a Message to be sent to the output channel.
setSendTimeout(long) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Set the timeout for sending reply Messages.
setSendTimeout(long) - Method in class org.springframework.integration.router.AbstractMessageRouter
Set the timeout for sending a message to the resolved channel.
setSendTimeout(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setSendTimeout(long) - Method in class org.springframework.integration.support.ErrorMessagePublisher
 
setSequenceNumber(Integer) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setSequenceNumber(Integer) - Method in class org.springframework.integration.support.MessageBuilder
 
setSequenceSize(Integer) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
setSequenceSize(Integer) - Method in class org.springframework.integration.support.MessageBuilder
 
setSerializer(Serializer<Object>) - Method in class org.springframework.integration.transformer.PayloadSerializingTransformer
 
setServiceInterface(Class<?>) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the interface class that the generated proxy should implement.
setShouldClonePayload(boolean) - Method in class org.springframework.integration.transformer.ContentEnricher
Specify whether to clone payload objects to create the target object.
setShouldExtractPayload(boolean) - Method in class org.springframework.integration.support.json.JsonOutboundMessageMapper
 
setShouldFlattenKeys(boolean) - Method in class org.springframework.integration.transformer.ObjectToMapTransformer
 
setShouldLogFullMessage(boolean) - Method in class org.springframework.integration.handler.LoggingHandler
Specify whether to log the full Message.
setShouldSkipNulls(boolean) - Method in class org.springframework.integration.transformer.HeaderEnricher
Specify whether null values, such as might be returned from an expression evaluation, should be skipped.
setShouldTrack(boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
setShouldTrack(boolean) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
setShouldTrack(boolean) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Specify whether this component should be tracked in the Message History.
setShouldTrack(boolean) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setShouldTrack(boolean) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Specify whether this gateway should be tracked in the Message History of Messages that originate from its send or sendAndReceive operations.
setShouldTrack(boolean) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
setShouldTrack(boolean) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
setShouldTrack(boolean) - Method in class org.springframework.integration.support.management.LifecycleTrackableMessageHandlerMetrics
 
setShouldTrack(boolean) - Method in class org.springframework.integration.support.management.LifecycleTrackableMessageSourceMetrics
 
setShouldTrack(boolean) - Method in interface org.springframework.integration.support.management.TrackableComponent
 
setShouldTrack(boolean) - Method in class org.springframework.integration.support.management.TrackableRouterMetrics
 
setSource(MessageSource<?>) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
setSource(MessageSource<?>) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Specify the source to be polled for Messages.
setStatsEnabled(boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
setStatsEnabled(boolean) - Method in class org.springframework.integration.channel.NullChannel
 
setStatsEnabled(Boolean) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setStatsEnabled(boolean) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
setStatsEnabled(boolean) - Method in interface org.springframework.integration.support.management.IntegrationStatsManagement
 
setStatsEnabled(boolean) - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
setSuccessChannel(MessageChannel) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the channel to which to send the AdviceMessage after evaluating the success expression.
setSuccessChannelName(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
Set the channel name to which to send the AdviceMessage after evaluating the success expression.
setSuffix(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
Specify a suffix to be added to each channel name prior to resolution.
setTarget(Object) - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
setTarget(Object) - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
 
setTargetMethodName(String) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
Set the method name for the message handler.
setTargetObject(Object) - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
Set the target POJO for the message handler.
setTaskExecutor(Executor) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
setThreshold(int) - Method in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
 
setThrowExceptionOnLateReply(boolean) - Method in class org.springframework.integration.core.MessagingTemplate
 
setThrowExceptionOnRejection(Boolean) - Method in class org.springframework.integration.config.FilterFactoryBean
 
setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.filter.MessageFilter
Specify whether this filter should throw a MessageRejectedException when its selector does not accept a Message.
setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
Specify whether this interceptor should throw a MessageRejectedException when its selector does not accept a Message.
setTimeout(long) - Method in class org.springframework.integration.channel.interceptor.WireTap
Specify the timeout value for sending to the intercepting target.
setTimeout(Long) - Method in class org.springframework.integration.config.RouterFactoryBean
Deprecated.
setTimeout(long) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
Specify the timeout value for sending to the discard channel.
setTimeout(long) - Method in class org.springframework.integration.router.AbstractMessageRouter
setTimeout(long) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
Timeout in milliseconds (default -1).
setTimeoutOnIdle(boolean) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
Allows you to override the rule for the timeout calculation.
setTimeUnit(TimeUnit) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
setTrackableComponent(TrackableComponent) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
 
setTransactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setTransactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setTransformOnSend(boolean) - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
Deprecated.
 
setTrapException(boolean) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
If true, any exception will be caught and null returned.
setTrigger(Trigger) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setTrigger(Trigger) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setTypeConverter(TypeConverter) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setTypeLocator(TypeLocator) - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
 
setupCustomPostProcessors() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
setUuidRegistrationId(int) - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
Set the registration id for UUID.
setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
setValue(Object, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
setValue(Object, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property value corresponding to the attribute whose name is provided if that attribute is defined in the given element.
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property value corresponding to the attribute whose name is provided if that attribute is defined in the given element.
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property value corresponding to the attribute whose name is provided if that attribute is defined in the given element.
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Configures the provided bean definition builder with a property value corresponding to the attribute whose name is provided if that attribute is defined in the given element.
setVotingStrategy(MessageSelectorChain.VotingStrategy) - Method in class org.springframework.integration.selector.MessageSelectorChain
Specify the voting strategy for this selector chain.
setWaitTimeout(long) - Method in class org.springframework.integration.util.SimplePool
Adjusts the wait timeout - the time for which getItem() will wait if no idle entries are available.
setWhiteListPatterns(String...) - Method in class org.springframework.integration.support.converter.WhiteListDeserializingConverter
Set simple patterns for allowable packages/classes for deserialization.
setWhiteListPatterns(String...) - Method in class org.springframework.integration.transformer.PayloadDeserializingTransformer
When using a WhiteListDeserializingConverter (the default) add patterns for packages/classes that are allowed to be deserialized.
SEVERITY - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.filter.MessageFilter
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Subclasses may override this.
shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.BridgeHandler
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
shouldCopyRequestHeaders() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
shouldCreateEndpoint(Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
shouldCreateEndpoint(Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeFromAnnotationPostProcessor
 
shouldCreateEndpoint(Method, List<Annotation>) - Method in class org.springframework.integration.config.annotation.BridgeToAnnotationPostProcessor
 
shouldCreateEndpoint(Method, List<Annotation>) - Method in interface org.springframework.integration.config.annotation.MethodAnnotationPostProcessor
Determine if the provided method and its annotations are eligible to create an AbstractEndpoint.
shouldFireEvents() - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
shouldFireEvents() - Method in class org.springframework.integration.config.xml.IdempotentReceiverInterceptorParser
 
shouldFireEvents() - Method in class org.springframework.integration.config.xml.IntegrationManagementParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.config.xml.IdempotentReceiverInterceptorParser
 
shouldIntercept(String, ChannelInterceptorAware) - Method in interface org.springframework.integration.channel.interceptor.VetoCapableInterceptor
 
shouldIntercept(String, ChannelInterceptorAware) - Method in class org.springframework.integration.channel.interceptor.WireTap
 
shouldSplitOutput(Iterable<?>) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
SIMPLE_CALLBACK - Static variable in class org.springframework.integration.expression.ExpressionEvalMap
 
SimpleActiveIdleMessageSourceAdvice - Class in org.springframework.integration.aop
A simple advice that polls at one rate when messages exist and another when there are no messages.
SimpleActiveIdleMessageSourceAdvice(DynamicPeriodicTrigger) - Constructor for class org.springframework.integration.aop.SimpleActiveIdleMessageSourceAdvice
 
SimpleIncrementingIdGenerator() - Constructor for class org.springframework.integration.support.IdGenerators.SimpleIncrementingIdGenerator
 
SimpleMessageConverter - Class in org.springframework.integration.support.converter
 
SimpleMessageConverter() - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
 
SimpleMessageConverter(InboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
 
SimpleMessageConverter(OutboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
 
SimpleMessageConverter(InboundMessageMapper<?>, OutboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
 
SimpleMessageGroup - Class in org.springframework.integration.store
Represents a mutable group of correlated messages that is bound to a certain MessageStore and group id.
SimpleMessageGroup(Object) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(Collection<? extends Message<?>>, Object) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(MessageGroup) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(Collection<? extends Message<?>>, Object, long, boolean) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(Collection<Message<?>>, Collection<? extends Message<?>>, Object, long, boolean, boolean) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroupFactory - Class in org.springframework.integration.store
The MessageGroupFactory implementation to produce SimpleMessageGroup instances.
SimpleMessageGroupFactory() - Constructor for class org.springframework.integration.store.SimpleMessageGroupFactory
 
SimpleMessageGroupFactory(SimpleMessageGroupFactory.GroupType) - Constructor for class org.springframework.integration.store.SimpleMessageGroupFactory
 
SimpleMessageGroupFactory.GroupType - Enum in org.springframework.integration.store
 
SimpleMessageGroupProcessor - Class in org.springframework.integration.aggregator
A MessageGroupProcessor that simply returns the messages in the group.
SimpleMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.SimpleMessageGroupProcessor
 
SimpleMessageStore - Class in org.springframework.integration.store
Map-based in-memory implementation of MessageStore and MessageGroupStore.
SimpleMessageStore(int, int) - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with a maximum size limited by the given capacity, or unlimited size if the given capacity is less than 1.
SimpleMessageStore(int, int, long) - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with a maximum size limited by the given capacity and the timeout in millisecond to wait for the empty slot in the store.
SimpleMessageStore(int, int, LockRegistry) - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with a maximum size limited by the given capacity and LockRegistry for the message group operations concurrency.
SimpleMessageStore(int, int, long, LockRegistry) - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with a maximum size limited by the given capacity, the timeout in millisecond to wait for the empty slot in the store and LockRegistry for the message group operations concurrency.
SimpleMessageStore(int) - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with the same capacity for individual and grouped messages.
SimpleMessageStore() - Constructor for class org.springframework.integration.store.SimpleMessageStore
Creates a SimpleMessageStore with unlimited capacity
SimpleMetadataStore - Class in org.springframework.integration.metadata
Simple implementation of MetadataStore that uses a ConcurrentMap for the data store.
SimpleMetadataStore() - Constructor for class org.springframework.integration.metadata.SimpleMetadataStore
Instantiate a SimpleMetadataStore using an in-memory ConcurrentHashMap.
SimpleMetadataStore(ConcurrentMap<String, String>) - Constructor for class org.springframework.integration.metadata.SimpleMetadataStore
Instantiate a SimpleMetadataStore using the provided ConcurrentMap.
SimplePollSkipStrategy - Class in org.springframework.integration.scheduling
A simple PollSkipStrategy to be used with a PollSkipAdvice.
SimplePollSkipStrategy() - Constructor for class org.springframework.integration.scheduling.SimplePollSkipStrategy
 
SimplePool<T> - Class in org.springframework.integration.util
Implementation of Pool supporting dynamic resizing and a variable timeout when attempting to obtain an item from the pool.
SimplePool(int, SimplePool.PoolItemCallback<T>) - Constructor for class org.springframework.integration.util.SimplePool
Creates a SimplePool with a specific limit.
SimplePool.PoolItemCallback<T> - Interface in org.springframework.integration.util
User of the pool provide an implementation of this interface; called during various pool operations.
SimplePublisherMetadataSource - Class in org.springframework.integration.aop
Simple implementation of PublisherMetadataSource that allows for configuration of a single channel name, payload expression, and array of header key=value expressions.
SimplePublisherMetadataSource() - Constructor for class org.springframework.integration.aop.SimplePublisherMetadataSource
 
SimpleSequenceSizeReleaseStrategy - Class in org.springframework.integration.aggregator
An implementation of ReleaseStrategy that simply compares the current size of the message list to the expected 'sequenceSize'.
SimpleSequenceSizeReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.SimpleSequenceSizeReleaseStrategy
 
SinglePatternBasedHeaderMatcher(String) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
 
SinglePatternBasedHeaderMatcher(String, boolean) - Constructor for class org.springframework.integration.mapping.AbstractHeaderMapper.SinglePatternBasedHeaderMatcher
 
size() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
size() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
size() - Method in class org.springframework.integration.history.MessageHistory
 
size() - Method in interface org.springframework.integration.store.MessageGroup
 
size() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
size() - Method in class org.springframework.integration.store.MessageGroupQueue
 
size() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
size() - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
 
skipPoll() - Method in interface org.springframework.integration.scheduling.PollSkipStrategy
Return true if this poll should be skipped.
skipPoll() - Method in class org.springframework.integration.scheduling.SimplePollSkipStrategy
 
skipPolls() - Method in class org.springframework.integration.scheduling.SimplePollSkipStrategy
Skip future polls.
SmartLifecycleRoleController - Class in org.springframework.integration.support
Bulk start/stop SmartLifecycle in a particular role in phase order.
SmartLifecycleRoleController(List<String>, List<SmartLifecycle>) - Constructor for class org.springframework.integration.support.SmartLifecycleRoleController
Construct an instance with the provided lists of roles and lifecycles, which must be of equal length.
SmartLifecycleRoleController(MultiValueMap<String, SmartLifecycle>) - Constructor for class org.springframework.integration.support.SmartLifecycleRoleController
Construct an instance with the provided map of roles/instances.
SourcePollingChannelAdapter - Class in org.springframework.integration.endpoint
A Channel Adapter implementation for connecting a MessageSource to a MessageChannel.
SourcePollingChannelAdapter() - Constructor for class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
SourcePollingChannelAdapterFactoryBean - Class in org.springframework.integration.config
FactoryBean for creating a SourcePollingChannelAdapter instance.
SourcePollingChannelAdapterFactoryBean() - Constructor for class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
SPEL_PROPERTY_ACCESSOR_REGISTRAR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
SpelExpressionRetryStateGenerator - Class in org.springframework.integration.handler.advice
Creates a DefaultRetryState from a Message.
SpelExpressionRetryStateGenerator(String) - Constructor for class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
 
SpelExpressionRetryStateGenerator(String, String) - Constructor for class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
 
SpelFunctionFactoryBean - Class in org.springframework.integration.config
A FactoryBean implementation to encapsulate the population of a static Method from the provided SpelFunctionFactoryBean.functionClass and SpelFunctionFactoryBean.functionMethodSignature as a valid StandardEvaluationContext function.
SpelFunctionFactoryBean(Class<?>, String) - Constructor for class org.springframework.integration.config.SpelFunctionFactoryBean
 
SpelFunctionParser - Class in org.springframework.integration.config.xml
Parser for the <spel-function> element.
SpelFunctionParser() - Constructor for class org.springframework.integration.config.xml.SpelFunctionParser
 
SpelPropertyAccessorRegistrar - Class in org.springframework.integration.expression
Utility class that keeps track of a Set of SpEL PropertyAccessors in order to register them with the "integrationEvaluationContext" upon initialization.
SpelPropertyAccessorRegistrar() - Constructor for class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
 
SpelPropertyAccessorRegistrar(PropertyAccessor...) - Constructor for class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
Create an instance with the provided property accessors.
SpelPropertyAccessorRegistrar(Map<String, PropertyAccessor>) - Constructor for class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
Create an instance with the provided named property accessors.
SpelPropertyAccessorsParser - Class in org.springframework.integration.config.xml
Parser for the <spel-property-accessors> element.
SpelPropertyAccessorsParser() - Constructor for class org.springframework.integration.config.xml.SpelPropertyAccessorsParser
 
splitMessage(Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Subclasses must override this method to split the received Message.
splitMessage(Message<?>) - Method in class org.springframework.integration.splitter.DefaultMessageSplitter
 
Splitter - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of splitting a single message or message payload to produce multiple messages or payloads.
SplitterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @Splitter.
SplitterAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.SplitterAnnotationPostProcessor
 
SplitterFactoryBean - Class in org.springframework.integration.config
Factory bean for creating a Message Splitter.
SplitterFactoryBean() - Constructor for class org.springframework.integration.config.SplitterFactoryBean
 
SplitterParser - Class in org.springframework.integration.config.xml
Parser for the <splitter/> element.
SplitterParser() - Constructor for class org.springframework.integration.config.xml.SplitterParser
 
StackTraceUtils - Class in org.springframework.integration.util
Utility methods for analyzing stack traces.
STANDARD_REPLY_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.mapping.AbstractHeaderMapper
A special pattern that only matches standard reply headers.
STANDARD_REQUEST_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.mapping.AbstractHeaderMapper
A special pattern that only matches standard request headers.
StandardHeaderEnricherParser - Class in org.springframework.integration.config.xml
Parser for the <header-enricher> element within the core integration namespace.
StandardHeaderEnricherParser() - Constructor for class org.springframework.integration.config.xml.StandardHeaderEnricherParser
 
start() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
start() - Method in class org.springframework.integration.channel.interceptor.WireTap
Restart the wire tap if it has been stopped.
start() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
start() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
start() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
start() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
start() - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
start() - Method in class org.springframework.integration.filter.MessageFilter
 
start() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
start() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
start() - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
start() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
start() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
start() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
start() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
start() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
Start the registration of the LockRegistryLeaderInitiator.candidate for leader election.
start - Variable in class org.springframework.integration.support.management.DefaultMessageChannelMetrics.DefaultChannelMetricsContext
 
start - Variable in class org.springframework.integration.support.management.DefaultMessageHandlerMetrics.DefaultHandlerMetricsContext
 
start() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
start() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
start() - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
start() - Method in class org.springframework.integration.transformer.ContentEnricher
Lifecycle implementation.
start() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
start() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper
 
startLifecyclesInRole(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Start all registered SmartLifecycles in the role.
StaticHeaderValueMessageProcessor<T> - Class in org.springframework.integration.transformer.support
 
StaticHeaderValueMessageProcessor(T) - Constructor for class org.springframework.integration.transformer.support.StaticHeaderValueMessageProcessor
 
Statistics - Class in org.springframework.integration.support.management
 
Statistics(long, double, double, double, double) - Constructor for class org.springframework.integration.support.management.Statistics
 
Stats() - Constructor for class org.springframework.integration.support.management.graph.IntegrationNode.Stats
 
stop() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
stop(Runnable) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
stop() - Method in class org.springframework.integration.channel.interceptor.WireTap
Stop the wire tap.
stop() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
stop() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
stop(Runnable) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
stop() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
stop(Runnable) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
stop() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
stop() - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
stop() - Method in class org.springframework.integration.filter.MessageFilter
 
stop() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
stop(Runnable) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
stop() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
stop() - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
 
stop() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
stop() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
stop(Runnable) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
stop() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
stop() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
stop(Runnable) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
stop(Runnable) - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
stop() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
Stop the registration of the LockRegistryLeaderInitiator.candidate for leader election.
stop() - Method in class org.springframework.integration.support.management.LifecycleMessageHandlerMetrics
 
stop() - Method in class org.springframework.integration.support.management.LifecycleMessageSourceMetrics
 
stop() - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
stop() - Method in class org.springframework.integration.transformer.ContentEnricher
Lifecycle implementation.
stop() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
stop() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper
 
stopLifecyclesInRole(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Stop all registered SmartLifecycles in the role.
store(Object, Message<?>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
StreamTransformer - Class in org.springframework.integration.transformer
Transforms an InputStream payload to a byte[] or String (if a charset is provided).
StreamTransformer() - Constructor for class org.springframework.integration.transformer.StreamTransformer
Construct an instance to transform an InputStream to a byte[].
StreamTransformer(String) - Constructor for class org.springframework.integration.transformer.StreamTransformer
Construct an instance with the charset to convert the stream to a String; if null a byte[] will be produced instead.
StreamTransformerParser - Class in org.springframework.integration.config.xml
Parser for <stream-transformer/> element.
StreamTransformerParser() - Constructor for class org.springframework.integration.config.xml.StreamTransformerParser
 
stringToBytes(String, String) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
Utility method for null-safe conversion from String to byte[]
subList(int, int) - Method in class org.springframework.integration.history.MessageHistory
 
SubscribableChannelManagement - Interface in org.springframework.integration.support.management
Metrics for subscribable channels.
subscribe(MessageHandler) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
subscribe(MessageHandler) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
success() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
Add a new event with successful outcome.
success(long) - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
Add a new event with successful outcome at time t.
supportedJsonTypes - Static variable in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
SyslogToMapTransformer - Class in org.springframework.integration.transformer
Transforms a packet in Syslog (RFC3164) format to a Map.
SyslogToMapTransformer() - Constructor for class org.springframework.integration.transformer.SyslogToMapTransformer
 
SyslogToMapTransformerParser - Class in org.springframework.integration.config.xml
 
SyslogToMapTransformerParser() - Constructor for class org.springframework.integration.config.xml.SyslogToMapTransformerParser
 

T

TAG - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
take() - Method in class org.springframework.integration.store.MessageGroupQueue
 
TASK_SCHEDULER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
TASK_SCHEDULER_POOL_SIZE - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies the value of ThreadPoolTaskScheduler.poolSize for the taskScheduler bean initialized by the Integration infrastructure.
ThreadStatePropagationChannelInterceptor<S> - Class in org.springframework.integration.channel.interceptor
The ExecutorChannelInterceptor implementation responsible for the Thread (any?) state propagation from one message flow's thread to another through the MessageChannels involved in the flow.
ThreadStatePropagationChannelInterceptor() - Constructor for class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
 
THROW_EXCEPTION_ON_LATE_REPLY - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies the value of GenericMessagingTemplate.throwExceptionOnLateReply.
TimeoutCountSequenceSizeReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that releases all messages if any of the following is true: The sequence is complete (if there is one). There are more messages than a threshold set by the user. The time elapsed since the earliest message, according to their timestamps, exceeds a timeout set by the user.
TimeoutCountSequenceSizeReleaseStrategy() - Constructor for class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
 
TimeoutCountSequenceSizeReleaseStrategy(int, long) - Constructor for class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
 
TIMESTAMP - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
TIMESTAMP_PROPERTY - Static variable in class org.springframework.integration.history.MessageHistory
 
TO_STRING_FRIENDLY_JSON_NODE_TO_STRING_CONVERTER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
toArray() - Method in class org.springframework.integration.history.MessageHistory
 
toArray(T[]) - Method in class org.springframework.integration.history.MessageHistory
 
toHeaders(T) - Method in interface org.springframework.integration.mapping.HeaderMapper
 
toHeadersFromReply(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
toHeadersFromReply(T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
Map from the given reply object to abstracted MessageHeaders.
toHeadersFromRequest(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
toHeadersFromRequest(T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
Map from the given request object to abstracted MessageHeaders.
toJson(Object) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
toJson(Object, Writer) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
toJson(Object) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
toJson(Object, Writer) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
toJson(Object) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
toJson(Object, Writer) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
toJson(Object) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
toJson(Object, Writer) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
toJsonNode(Object) - Method in class org.springframework.integration.support.json.BoonJsonObjectMapper
 
toJsonNode(Object) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
toJsonNode(Object) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
 
toJsonNode(Object) - Method in class org.springframework.integration.support.json.JsonObjectMapperAdapter
 
toMap() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.codec.CodecMessageConverter
 
toMessage(T) - Method in interface org.springframework.integration.mapping.InboundMessageMapper
 
toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
 
toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.support.converter.MapMessageConverter
 
toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.support.converter.PassThruMessageConverter
 
toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
toMessage(String) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
 
toString() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
toString() - Method in class org.springframework.integration.aggregator.MethodInvokingMessageListProcessor
 
toString() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
toString() - Method in class org.springframework.integration.channel.NullChannel
 
toString() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
toString() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
 
toString() - Method in class org.springframework.integration.event.IntegrationEvent
 
toString() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
toString() - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
 
toString() - Method in class org.springframework.integration.filter.ExpressionEvaluatingSelector
 
toString() - Method in interface org.springframework.integration.handler.AbstractReplyProducingMessageHandler.RequestHandler
 
toString() - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
 
toString() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
toString() - Method in class org.springframework.integration.history.MessageHistory
 
toString() - Method in class org.springframework.integration.json.JsonPropertyAccessor.ToStringFriendlyJsonNode
 
toString() - Method in class org.springframework.integration.leader.DefaultCandidate
 
toString() - Method in class org.springframework.integration.leader.event.AbstractLeaderEvent
 
toString() - Method in class org.springframework.integration.message.AdviceMessage
 
toString() - Method in class org.springframework.integration.message.EnhancedErrorMessage
Deprecated.
 
toString() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
toString() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
toString() - Method in class org.springframework.integration.support.management.DefaultMessageChannelMetrics
 
toString() - Method in class org.springframework.integration.support.management.ExponentialMovingAverage
 
toString() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRate
 
toString() - Method in class org.springframework.integration.support.management.ExponentialMovingAverageRatio
 
toString() - Method in class org.springframework.integration.support.management.Statistics
 
toString() - Method in class org.springframework.integration.support.MutableMessage
 
toString() - Method in exception org.springframework.integration.support.PartialSuccessException
 
toString() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper
 
toString() - Method in class org.springframework.integration.util.UpperBound
 
ToStringFriendlyJsonNode(JsonNode) - Constructor for class org.springframework.integration.json.JsonPropertyAccessor.ToStringFriendlyJsonNode
 
TrackableComponent - Interface in org.springframework.integration.support.management
 
TrackableRouterMetrics - Class in org.springframework.integration.support.management
TrackableRouterMetrics(Lifecycle, MappingMessageRouterManagement) - Constructor for class org.springframework.integration.support.management.TrackableRouterMetrics
 
TransactionSynchronizationFactory - Interface in org.springframework.integration.transaction
Strategy for implementing factories that create TransactionSynchronization
TransactionSynchronizationFactoryBean - Class in org.springframework.integration.transaction
The FactoryBean implementation (with Builder style) to be used from JavaConfig to populate DefaultTransactionSynchronizationFactory bean.
TransactionSynchronizationFactoryBean() - Constructor for class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
TransactionSynchronizationFactoryParser - Class in org.springframework.integration.config.xml
Parser for transaction-synchronizatioin-factory element
TransactionSynchronizationFactoryParser() - Constructor for class org.springframework.integration.config.xml.TransactionSynchronizationFactoryParser
 
TransactionSynchronizationProcessor - Interface in org.springframework.integration.transaction
Strategy for implementing transaction synchronization processors
transform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
transform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractTransformer
 
transform(S) - Method in interface org.springframework.integration.transformer.GenericTransformer
 
transform(Message<?>) - Method in class org.springframework.integration.transformer.HeaderEnricher
 
transform(Message<?>) - Method in class org.springframework.integration.transformer.HeaderFilter
 
transform(Message<?>) - Method in interface org.springframework.integration.transformer.Transformer
 
Transformer - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of transforming a message, message header, or message payload.
Transformer - Interface in org.springframework.integration.transformer
Strategy interface for transforming a Message.
TransformerAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
Post-processor for Methods annotated with @Transformer.
TransformerAnnotationPostProcessor(ConfigurableListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.TransformerAnnotationPostProcessor
 
TransformerFactoryBean - Class in org.springframework.integration.config
Factory bean for creating a Message Transformer.
TransformerFactoryBean() - Constructor for class org.springframework.integration.config.TransformerFactoryBean
 
TransformerParser - Class in org.springframework.integration.config.xml
Parser for the <transformer/> element.
TransformerParser() - Constructor for class org.springframework.integration.config.xml.TransformerParser
 
transformPayload(T) - Method in class org.springframework.integration.transformer.AbstractPayloadTransformer
 
transformPayload(T) - Method in class org.springframework.integration.transformer.EncodingPayloadTransformer
 
transformPayload(Map<?, ?>) - Method in class org.springframework.integration.transformer.MapToObjectTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.transformer.ObjectToMapTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.transformer.ObjectToStringTransformer
 
transformPayload(byte[]) - Method in class org.springframework.integration.transformer.PayloadDeserializingTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.transformer.PayloadSerializingTransformer
 
transformPayload(T) - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
 
transformPayload(Object) - Method in class org.springframework.integration.transformer.SyslogToMapTransformer
 
trigger(Message<?>) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
 
trigger(Message<?>) - Method in interface org.springframework.integration.handler.MessageTriggerAction
Take some action based on the message.
tryAcquire(long) - Method in class org.springframework.integration.util.UpperBound
Acquires a permit from the underlying semaphore if this UpperBound is bounded and returns true if it succeeds within the given timeout.
tryOptimizedDispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
 
TYPE_ID - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
 
TYPE_PROPERTY - Static variable in class org.springframework.integration.history.MessageHistory
 

U

unbound() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
 
UNDECODED - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
 
UnexpiredMessageSelector - Class in org.springframework.integration.selector
A MessageSelector that accepts Messages that are not yet expired.
UnexpiredMessageSelector() - Constructor for class org.springframework.integration.selector.UnexpiredMessageSelector
 
UnicastingDispatcher - Class in org.springframework.integration.dispatcher
Implementation of MessageDispatcher that will attempt to send a Message to at most one of its handlers.
UnicastingDispatcher() - Constructor for class org.springframework.integration.dispatcher.UnicastingDispatcher
 
UnicastingDispatcher(Executor) - Constructor for class org.springframework.integration.dispatcher.UnicastingDispatcher
 
UniqueMethodFilter - Class in org.springframework.integration.util
 
UniqueMethodFilter(Class<?>) - Constructor for class org.springframework.integration.util.UniqueMethodFilter
 
unsubscribe(MessageHandler) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
unsubscribe(MessageHandler) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
unwrapExceptionIfNecessary(Exception) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
Unwrap the cause of a AbstractRequestHandlerAdvice.ThrowableHolderException.
unwrapThrowableIfNecessary(Exception) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
Unwrap the cause of a AbstractRequestHandlerAdvice.ThrowableHolderException.
UpperBound - Class in org.springframework.integration.util
Thin wrapper around a Semaphore that allows to create a potentially unlimited upper bound to by used in buffers of messages (e.g.
UpperBound(int) - Constructor for class org.springframework.integration.util.UpperBound
Create an UpperBound with the given capacity.
usingCallback(ExpressionEvalMap.EvaluationCallback) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
 
usingEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
 
usingEvaluationContext(EvaluationContext) - Method in interface org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapComponentsBuilder
 
usingSimpleCallback() - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
 
uuid - Variable in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
UUIDConverter - Class in org.springframework.integration.util
Utility to help generate UUID instances from generic objects.
UUIDConverter() - Constructor for class org.springframework.integration.util.UUIDConverter
 

V

ValueExpression<V> - Class in org.springframework.integration.expression
A very simple hardcoded implementation of the Expression interface that represents an immutable value.
ValueExpression(V) - Constructor for class org.springframework.integration.expression.ValueExpression
 
valueOf(String) - Static method in enum org.springframework.integration.handler.LoggingHandler.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.json.ObjectToJsonTransformer.ResultType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.selector.MessageSelectorChain.VotingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.store.SimpleMessageGroupFactory.GroupType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.integration.support.management.graph.LinkNode.Type
Returns the enum constant of this type with the specified name.
values() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
values() - Static method in enum org.springframework.integration.handler.LoggingHandler.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.json.ObjectToJsonTransformer.ResultType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.selector.MessageSelectorChain.VotingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.store.SimpleMessageGroupFactory.GroupType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.integration.support.management.graph.LinkNode.Type
Returns an array containing the constants of this enum type, in the order they are declared.
verifyResultCollectionConsistsOfMessages(Collection<?>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
verifyType(String, Object) - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
VetoCapableInterceptor - Interface in org.springframework.integration.channel.interceptor
ChannelInterceptors implementing this interface can veto global interception of a particular channel.

W

whileLocked() - Method in class org.springframework.integration.util.WhileLockedProcessor
Override this method to provide the behavior that needs to be executed while under the lock.
WhileLockedProcessor - Class in org.springframework.integration.util
A simple strategy callback class that allows you to provide a code that needs to be executed under Lock provided by LockRegistry A typical usage would be to provide implementation of WhileLockedProcessor.whileLocked() method and then call WhileLockedProcessor.doWhileLocked()
WhileLockedProcessor(LockRegistry, Object) - Constructor for class org.springframework.integration.util.WhileLockedProcessor
 
WhiteListDeserializingConverter - Class in org.springframework.integration.support.converter
A Converter that delegates to a Deserializer to convert data in a byte array to an object.
WhiteListDeserializingConverter() - Constructor for class org.springframework.integration.support.converter.WhiteListDeserializingConverter
Create a WhiteListDeserializingConverter with default ObjectInputStream configuration, using the "latest user-defined ClassLoader".
WhiteListDeserializingConverter(ClassLoader) - Constructor for class org.springframework.integration.support.converter.WhiteListDeserializingConverter
Create a WhiteListDeserializingConverter for using an ObjectInputStream with the given ClassLoader.
WhiteListDeserializingConverter(Deserializer<Object>) - Constructor for class org.springframework.integration.support.converter.WhiteListDeserializingConverter
Create a WhiteListDeserializingConverter that delegates to the provided Deserializer.
willAddHeaders(Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
Return true if the subclass needs to add headers in the resulting splits.
WireTap - Class in org.springframework.integration.channel.interceptor
A ChannelInterceptor that publishes a copy of the intercepted message to a secondary target while still sending the original message to the main channel.
WireTap(MessageChannel) - Constructor for class org.springframework.integration.channel.interceptor.WireTap
Create a new wire tap with no MessageSelector.
WireTap(MessageChannel, MessageSelector) - Constructor for class org.springframework.integration.channel.interceptor.WireTap
Create a new wire tap with the provided MessageSelector.
WireTap(String) - Constructor for class org.springframework.integration.channel.interceptor.WireTap
Create a new wire tap based on the MessageChannel name and with no MessageSelector.
WireTap(String, MessageSelector) - Constructor for class org.springframework.integration.channel.interceptor.WireTap
Create a new wire tap with the provided MessageSelector.
WireTapParser - Class in org.springframework.integration.config.xml
Parser for the <wire-tap> element.
WireTapParser() - Constructor for class org.springframework.integration.config.xml.WireTapParser
 
withPayload(T) - Method in class org.springframework.integration.support.DefaultMessageBuilderFactory
 
withPayload(T) - Static method in class org.springframework.integration.support.MessageBuilder
Create a builder for a new Message instance with the provided payload.
withPayload(T) - Method in interface org.springframework.integration.support.MessageBuilderFactory
 
withPayload(T) - Static method in class org.springframework.integration.support.MutableMessageBuilder
Create a builder for a new Message instance with the provided payload.
withPayload(T) - Method in class org.springframework.integration.support.MutableMessageBuilderFactory
 
withReturnType(Class<?>) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
 
withReturnType(Class<?>) - Method in interface org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapComponentsBuilder
 
withRoot(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
 
withRoot(Object) - Method in interface org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapComponentsBuilder
 
wrapExceptionIfNecessary(Message<?>, Exception) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
 
write(Kryo, Output, File) - Method in class org.springframework.integration.codec.kryo.FileSerializer
 
write(Message<T>, NamedComponent) - Static method in class org.springframework.integration.history.MessageHistory
 
write(Message<T>, NamedComponent, MessageBuilderFactory) - Static method in class org.springframework.integration.history.MessageHistory
 
write(EvaluationContext, Object, String, Object) - Method in class org.springframework.integration.json.JsonPropertyAccessor
 

Y

yield() - Method in interface org.springframework.integration.leader.Context
Causes the Candidate this context was passed to to relinquish leadership.
yieldLeadership() - Method in class org.springframework.integration.leader.DefaultCandidate
Voluntarily yield leadership if held.
A B C D E F G H I J K L M N O P Q R S T U V W Y 
Skip navigation links