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

D

DataBindingInboundRequestMapper - Class in org.springframework.integration.http
InboundRequestMapper implementation that binds the request parameter map to a target instance.
DataBindingInboundRequestMapper() - Constructor for class org.springframework.integration.http.DataBindingInboundRequestMapper
 
DataBindingInboundRequestMapper(Class<?>) - Constructor for class org.springframework.integration.http.DataBindingInboundRequestMapper
 
DatagramPacketMessageMapper - Class in org.springframework.integration.ip.udp
Message Mapper for converting to and from UDP DatagramPackets.
DatagramPacketMessageMapper() - Constructor for class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
dataPart - Variable in class org.springframework.integration.ip.tcp.NioSocketReader
 
decorate(Node, BeanDefinitionHolder, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
 
DEFAULT_CHARSET - Static variable in class org.springframework.integration.util.UUIDConverter
 
DEFAULT_DOMAIN - Static variable in class org.springframework.integration.control.ControlBus
 
DEFAULT_LONG_STRING_LENGTH - Static variable in class org.springframework.integration.jdbc.JdbcMessageStore
 
DEFAULT_POLLER_METADATA_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
DEFAULT_REAPER_INTERVAL - Static variable in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
DEFAULT_SEND_TIMEOUT - Static variable in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
DEFAULT_SEND_TIMEOUT - Static variable in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.JdbcMessageStore
Default value for the table prefix property.
DEFAULT_THRESHOLD - Static variable in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
Default threshold is effectively infinite.
DEFAULT_TIMEOUT - Static variable in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
DEFAULT_TIMEOUT - Static variable in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
Default timeout is one minute.
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
 
DefaultDirectoryScanner - Class in org.springframework.integration.file
Default directory scanner and base class for other directory scanners.
DefaultDirectoryScanner() - Constructor for class org.springframework.integration.file.DefaultDirectoryScanner
 
DefaultFileNameGenerator - Class in org.springframework.integration.file
Default implementation of the filename generator strategy.
DefaultFileNameGenerator() - Constructor for class org.springframework.integration.file.DefaultFileNameGenerator
 
DefaultInboundRequestMapper - Class in org.springframework.integration.http
Default implementation of InboundRequestMapper for inbound HttpServletRequests.
DefaultInboundRequestMapper() - Constructor for class org.springframework.integration.http.DefaultInboundRequestMapper
 
DefaultJmsHeaderMapper - Class in org.springframework.integration.jms
Default implementation of JmsHeaderMapper.
DefaultJmsHeaderMapper() - Constructor for class org.springframework.integration.jms.DefaultJmsHeaderMapper
 
DefaultMessageSplitter - Class in org.springframework.integration.splitter
The default Message Splitter implementation.
DefaultMessageSplitter() - Constructor for class org.springframework.integration.splitter.DefaultMessageSplitter
 
DefaultMethodInvoker - Class in org.springframework.integration.util
Implementation of MethodInvoker to be used when the actual Method reference is known.
DefaultMethodInvoker(Object, Method) - Constructor for class org.springframework.integration.util.DefaultMethodInvoker
 
DefaultOutboundRequestMapper - Class in org.springframework.integration.http
Default implementation of OutboundRequestMapper.
DefaultOutboundRequestMapper() - Constructor for class org.springframework.integration.http.DefaultOutboundRequestMapper
Create a DefaultOutboundRequestMapper with no default URL.
DefaultOutboundRequestMapper(URL) - Constructor for class org.springframework.integration.http.DefaultOutboundRequestMapper
Create a DefaultOutboundRequestMapper with the given default URL.
DefaultRouterParser - Class in org.springframework.integration.config.xml
Parser for the <router/> element.
DefaultRouterParser() - Constructor for class org.springframework.integration.config.xml.DefaultRouterParser
 
DefaultSqlParameterSourceFactory - Class in org.springframework.integration.jdbc
A default implementation of SqlParameterSourceFactory which creates an SqlParameterSource according to the result of the data passed in.
DefaultSqlParameterSourceFactory() - Constructor for class org.springframework.integration.jdbc.DefaultSqlParameterSourceFactory
 
DefaultSqlParameterSourceFactory(Map<String, Object>) - Constructor for class org.springframework.integration.jdbc.DefaultSqlParameterSourceFactory
 
DefaultTransformerConfigurer - Class in org.springframework.integration.xml.transformer
TransformerConfigurer instance which looks for headers and uses them to configure the provided Transformer instance.
DefaultTransformerConfigurer() - Constructor for class org.springframework.integration.xml.transformer.DefaultTransformerConfigurer
 
DefaultXmlPayloadConverter - Class in org.springframework.integration.xml
Default implementation of XmlPayloadConverter.
DefaultXmlPayloadConverter() - Constructor for class org.springframework.integration.xml.DefaultXmlPayloadConverter
 
DefaultXmlPayloadConverter(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.DefaultXmlPayloadConverter
 
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 presence of a delay header on an inbound Message or a default delay value configured on this handler.
DelayHandler(long) - Constructor for class org.springframework.integration.handler.DelayHandler
Create a DelayHandler with the given default delay.
DelayHandler(long, TaskScheduler) - Constructor for class org.springframework.integration.handler.DelayHandler
Create a DelayHandler with the given default delay.
delegate - Variable in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
deleteMessages(Message[]) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Deletes the given messages from this receiver's folder.
deleteMessages(Message[]) - Method in class org.springframework.integration.mail.Pop3MailReceiver
Deletes the given messages from this receiver's folder, and closes it to expunge deleted messages.
describeTo(Description) - Method in class org.springframework.integration.test.matcher.HeaderMatcher
describeTo(Description) - Method in class org.springframework.integration.test.matcher.MapContentMatchers
describeTo(Description) - Method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
 
describeTo(Description) - Method in class org.springframework.integration.test.matcher.PayloadMatcher
deserialize(byte[]) - Static method in class org.springframework.integration.jdbc.util.SerializationUtils
 
destinationAddress - Variable in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
destroy() - Method in class org.springframework.integration.handler.DelayHandler
 
destroy() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
destroy() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
destroy() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
destroy() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
determineTargetChannel(Message<?>) - Method in class org.springframework.integration.router.AbstractSingleChannelRouter
Subclasses must implement this method to return the target channel.
determineTargetChannel(Message<?>) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
determineTargetChannel(Message<?>) - Method in class org.springframework.integration.router.PayloadTypeRouter
 
determineTargetChannelName(Message<?>) - Method in class org.springframework.integration.router.AbstractSingleChannelNameRouter
Subclasses must implement this method to return the channel name.
determineTargetChannelName(Message<?>) - Method in class org.springframework.integration.xml.router.XmlPayloadValidatingRouter
 
determineTargetChannels(Message<?>) - Method in class org.springframework.integration.router.AbstractChannelNameResolvingMessageRouter
 
determineTargetChannels(Message<?>) - Method in class org.springframework.integration.router.AbstractMessageRouter
Subclasses must implement this method to return the target channels for a given Message.
determineTargetChannels(Message<?>) - Method in class org.springframework.integration.router.AbstractSingleChannelRouter
 
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 no LoadBalancingStrategy.
DirectChannel(LoadBalancingStrategy) - Constructor for class org.springframework.integration.channel.DirectChannel
Create a DirectChannel with a LoadBalancingStrategy.
DirectoryScanner - Interface in org.springframework.integration.file
Strategy for scanning directories.
discoverMethodParameterNames(Method) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
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
 
doClose() - Method in class org.springframework.integration.ip.tcp.AbstractSocketReader
Called after an exception; close the transport.
doClose() - Method in class org.springframework.integration.ip.tcp.AbstractSocketWriter
Called when an IO error
doClose() - Method in class org.springframework.integration.ip.tcp.NetSocketReader
 
doClose() - Method in class org.springframework.integration.ip.tcp.NetSocketWriter
 
doClose() - Method in class org.springframework.integration.ip.tcp.NioSocketReader
 
doClose() - Method in class org.springframework.integration.ip.tcp.NioSocketWriter
 
doExecuteRequest(HttpRequest) - Method in class org.springframework.integration.http.AbstractHttpRequestExecutor
Subclasses must implement this method to execute the request.
doExecuteRequest(HttpRequest) - Method in class org.springframework.integration.http.CommonsHttpRequestExecutor
 
doExecuteRequest(HttpRequest) - Method in class org.springframework.integration.http.SimpleHttpRequestExecutor
 
doHandle(Object, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
doHandle(Object, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
doHandle(Object, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
DomResultFactory - Class in org.springframework.integration.xml.result
 
DomResultFactory(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.result.DomResultFactory
 
DomResultFactory() - Constructor for class org.springframework.integration.xml.result.DomResultFactory
 
DomSourceFactory - Class in org.springframework.integration.xml.source
SourceFactory implementation which supports creation of a DOMSource from a Document or String payload.
DomSourceFactory() - Constructor for class org.springframework.integration.xml.source.DomSourceFactory
 
DomSourceFactory(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.source.DomSourceFactory
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
Subclasses must implement this method to parse the adapter element.
doParse(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.AnnotationConfigParser
 
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, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
 
doParse(Element, ParserContext, String) - Method in class org.springframework.integration.ip.config.IpInboundChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.jms.config.JmsChannelParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.jmx.config.ControlBusParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.security.config.SecuredChannelsParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.XPathSelectorParser
 
doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelNameResolvingRouterParser
 
doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.HeaderValueRouterParser
 
doPoll() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
doPoll() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
doPoll() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
Subclasses may add to the bean definition by overriding this method.
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.ip.config.IpInboundGatewayParser
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.rmi.config.RmiInboundGatewayParser
 
doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
 
doReceive(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(long) - Method in class org.springframework.integration.channel.ThreadLocalChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Subclasses must implement this method.
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.PriorityChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.QueueChannel
 
doSend(Message<?>, long) - Method in class org.springframework.integration.channel.ThreadLocalChannel
 
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.event.ApplicationEventInboundChannelAdapter
 
doStart() - Method in class org.springframework.integration.gateway.AbstractMessagingGateway
 
doStart() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
doStart() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
doStart() - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
doStart() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
doStart() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Registers the notification listener with the specified ObjectNames.
doStart() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
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.event.ApplicationEventInboundChannelAdapter
 
doStop() - Method in class org.springframework.integration.gateway.AbstractMessagingGateway
 
doStop() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
doStop() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
doStop() - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
doStop() - Method in class org.springframework.integration.ip.tcp.TcpNetReceivingChannelAdapter
 
doStop() - Method in class org.springframework.integration.ip.tcp.TcpNioReceivingChannelAdapter
 
doStop() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
doStop() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
doStop() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Unregisters the notification listener.
doStop() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
doTransform(Message) - Method in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
 
doTransform(Message) - Method in class org.springframework.integration.mail.transformer.MailToStringTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractPayloadTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractTransformer
Subclasses must implement this method to provide the transformation logic.
doTransform(Message<?>) - Method in class org.springframework.integration.transformer.ClaimCheckInTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
 
doTransform(Message<?>) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
doWrite(Message<?>) - Method in class org.springframework.integration.ip.tcp.AbstractTcpSendingMessageHandler
Method that actually does the write.

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