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

S

sameExceptIgnorableHeaders(Message<?>, String...) - Static method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
 
SAVED_KEY - Static variable in class org.springframework.integration.jdbc.JdbcMessageStore
The name of the message header that stores a flag to indicate that the message has been saved.
scheduleSendMessage(DatagramPacket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
SchemaValidator - Class in org.springframework.integration.xml.router
 
SchemaValidator(Resource, String) - Constructor for class org.springframework.integration.xml.router.SchemaValidator
 
searchForNewMessages() - Method in class org.springframework.integration.mail.AbstractMailReceiver
Subclasses must implement this method to return new mail messages.
searchForNewMessages() - Method in class org.springframework.integration.mail.ImapMailReceiver
Retrieves new messages from this receiver's folder.
searchForNewMessages() - Method in class org.springframework.integration.mail.Pop3MailReceiver
 
SecuredChannelsParser - Class in org.springframework.integration.security.config
Creates a ChannelSecurityInterceptor to control send and receive access, and creates a bean post-processor to apply the interceptor to MessageChannels whose names match the specified patterns.
SecuredChannelsParser() - Constructor for class org.springframework.integration.security.config.SecuredChannelsParser
 
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.MessageChannelTemplate
 
send(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.MessageChannelTemplate
 
send(Message<?>) - Method in class org.springframework.integration.channel.NullChannel
 
send(Message<?>, long) - Method in class org.springframework.integration.channel.NullChannel
 
send(Message<?>) - Method in interface org.springframework.integration.core.MessageChannel
Send a Message to this channel.
send(Message<?>, long) - Method in interface org.springframework.integration.core.MessageChannel
Send a message, blocking until either the message is accepted or the specified timeout period elapses.
send(Object) - Method in class org.springframework.integration.gateway.AbstractMessagingGateway
 
send(DatagramPacket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
send(Message<?>) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
send(Message<?>, long) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
sendAck(Message<byte[]>) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
sendAndReceive(Message<?>) - Method in class org.springframework.integration.channel.MessageChannelTemplate
 
sendAndReceive(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.MessageChannelTemplate
 
sendAndReceive(Object) - Method in class org.springframework.integration.gateway.AbstractMessagingGateway
 
sendAndReceiveMessage(Object) - Method in class org.springframework.integration.gateway.AbstractMessagingGateway
 
sendMessage(Message<?>) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
sendReplyMessage(Message<?>, MessageChannel) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
SEQUENCE_NUMBER - Static variable in class org.springframework.integration.core.MessageHeaders
 
SEQUENCE_SIZE - Static variable in class org.springframework.integration.core.MessageHeaders
 
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
 
SerializationUtils - Class in org.springframework.integration.jdbc.util
Static utility to help with serialization.
SerializationUtils() - Constructor for class org.springframework.integration.jdbc.util.SerializationUtils
 
serialize(Object) - Static method in class org.springframework.integration.jdbc.util.SerializationUtils
Serialize the object provided.
server() - Method in class org.springframework.integration.ip.tcp.AbstractTcpReceivingChannelAdapter
Establishes the server.
server() - Method in class org.springframework.integration.ip.tcp.TcpNetReceivingChannelAdapter
Creates the server socket, listens for incoming connections and schedules execution of the TcpNetReceivingChannelAdapter.handleSocket(Socket) method for each new connection.
server() - Method in class org.springframework.integration.ip.tcp.TcpNioReceivingChannelAdapter
Opens a non-blocking ServerSocketChannel, registers it with a Selector and calls TcpNioReceivingChannelAdapter.doSelect(ServerSocketChannel, Selector).
serverChannel - Variable in class org.springframework.integration.ip.tcp.TcpNioReceivingChannelAdapter
 
serverSocket - Variable in class org.springframework.integration.ip.tcp.TcpNetReceivingChannelAdapter
 
SERVICE_NAME_PREFIX - Static variable in class org.springframework.integration.rmi.RmiInboundGateway
 
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
 
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(ListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.ServiceActivatorAnnotationPostProcessor
 
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
 
setAcceptGzipEncoding(boolean) - Method in class org.springframework.integration.http.AbstractHttpRequestExecutor
Set whether to accept GZIP encoding, that is, whether to send the HTTP "Accept-Encoding" header with "gzip" as value.
setAckAddress(String) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setAcknowledge(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setAdviceChain(List<Advice>) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setAlwaysUseSourceFactory(boolean) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
If true always delegate to the SourceFactory.
setAlwaysUseSourceResultFactories(boolean) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
Forces use of ResultFactory and SourceFactory even for directly supported payloads such as String and Document
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.event.ApplicationEventPublishingMessageHandler
 
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.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.
setArgumentMapVariableName(String) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
setArgumentVariableNameMap(Map<String, String[]>) - Method in class org.springframework.integration.aop.MethodNameMappingExpressionSource
 
setAttributeName(String) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
Specify the name of the attribute to be retrieved.
setAutoCreateDirectory(Boolean) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setAutoCreateDirectory(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.FileReadingMessageSource
Specify whether to create the source directory automatically if it does not yet exist upon initialization.
setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Specify whether to create the destination directory automatically if it does not yet exist upon initialization.
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.ws.MarshallingWebServiceInboundGateway
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
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
 
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.BeanFactoryChannelResolver
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
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.SourcePollingChannelAdapterFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.control.ControlBus
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.DelayHandler
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.http.DataBindingInboundRequestMapper
Provides the BeanFactory necessary to look up a 'targetBeanName' if specified.
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.MapToObjectTransformer
 
setBeanFactory(BeanFactory) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
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.context.IntegrationObjectSupport
 
setBeanName(String) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setBeanName(String) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setBuffsPerConnection(int) - Method in class org.springframework.integration.ip.tcp.TcpNioSendingMessageHandler
If direct buffers are being used, sets the max number of buffers allowed per connection.
setBytesPerMessage(int) - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
setCaseSensitive(boolean) - Method in class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Specify whether comparison of value returned by XPathExpression to test value should be case sensitive.
setChannelAttributeName(String) - Method in class org.springframework.integration.aop.MethodAnnotationExpressionSource
 
setChannelMap(Map<String, String>) - Method in class org.springframework.integration.aop.MethodNameMappingExpressionSource
 
setChannelMap(Map<String, ? extends MessageChannel>) - Method in class org.springframework.integration.channel.MapBasedChannelResolver
Provide a map of channels to be used by this resolver.
setChannelMap(Map<MessageSelector, ? extends Collection<MessageChannel>>) - Method in class org.springframework.integration.router.RecipientListRouter
Set a custom map of selectors to channels.
setChannelName(String) - Method in class org.springframework.integration.aop.SimpleExpressionSource
 
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
Set the ChannelResolver to be used when there is no default output channel.
setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.router.AbstractChannelNameResolvingMessageRouter
Specify the ChannelResolver strategy to use.
setChannels(List<MessageChannel>) - Method in class org.springframework.integration.router.RecipientListRouter
Set the output channels of this router.
setCharset(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setCharset(String) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Set the charset name to use when writing a File from a String-based Message payload.
setCharset(String) - Method in class org.springframework.integration.file.transformer.FileToStringTransformer
Set the charset name to use when copying the File to a String.
setCharset(String) - Method in class org.springframework.integration.http.DefaultOutboundRequestMapper
Specify the charset name to use for converting String-typed payloads to bytes.
setCharset(String) - Method in class org.springframework.integration.ip.tcp.SocketMessageMapper
 
setCharset(String) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setCharset(String) - Method in class org.springframework.integration.mail.transformer.MailToStringTransformer
Specify the name of the Charset to use when converting from bytes.
setComparator(Comparator<Message<?>>) - Method in class org.springframework.integration.aggregator.ResequencingMessageGroupProcessor
A comparator to use to order messages before processing.
setComparator(Comparator<File>) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the JMS ConnectionFactory that this gateway should use.
setConversionService(ConversionService) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Specify the ConversionService to use when trying to convert to one of this channel's supported datatypes for a Message whose payload does not already match.
setConversionService(ConversionService) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setConversionService(ConversionService) - Method in class org.springframework.integration.handler.AbstractMessageProcessor
 
setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.enricher.XPathHeaderEnricher
 
setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.router.AbstractXPathRouter
Converter used to convert payloads prior to XPath testing.
setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.router.XmlPayloadValidatingRouter
Converter used to convert payloads prior to validation
setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
Specify the converter used to convert payloads prior to XPath testing.
setCopyUploadedFiles(boolean) - Method in class org.springframework.integration.http.DefaultInboundRequestMapper
Specify whether uploaded multipart files should be copied to a temporary file on the server.
setCorrelationId(Object) - Method in class org.springframework.integration.message.MessageBuilder
 
setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setCreateDocuments(boolean) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
setCustomSocketReaderClassName(String) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
setCustomSocketReaderClassName(String) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
 
setCustomSocketReaderClassName(String) - Method in class org.springframework.integration.ip.tcp.TcpNetReceivingChannelAdapter
 
setCustomSocketReaderClassName(String) - Method in class org.springframework.integration.ip.tcp.TcpNioReceivingChannelAdapter
 
setCustomSocketWriterClassName(String) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
setCustomSocketWriterClassName(String) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
 
setCustomSocketWriterClassName(String) - Method in class org.springframework.integration.ip.tcp.TcpNetSendingMessageHandler
 
setCustomSocketWriterClassName(String) - Method in class org.springframework.integration.ip.tcp.TcpNioSendingMessageHandler
 
setDataSource(DataSource) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
The JDBC DataSource to use when interacting with the database.
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.aop.MessagePublishingInterceptor
 
setDefaultChannel(MessageChannel) - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
setDefaultChannel(MessageChannel) - 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.
setDefaultChannel(MessageChannel) - Method in class org.springframework.integration.channel.MessageChannelTemplate
Specify the default MessageChannel to use when invoking the send and/or receive methods that do not expect a channel parameter.
setDefaultDelay(long) - Method in class org.springframework.integration.handler.DelayHandler
Set the default delay in milliseconds.
setDefaultErrorChannel(MessageChannel) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
setDefaultEvaluationType(XPathEvaluationType) - Method in class org.springframework.integration.xml.enricher.XPathHeaderEnricher
 
setDefaultNotificationType(String) - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
Specify a dot-delimited String representing the Notification type to use by default when no explicit Notification mapper has been configured.
setDefaultObjectName(String) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
Specify a default ObjectName to use when no such header is available on the Message being handled.
setDefaultOperationName(String) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
Specify a default operation name to be invoked when no such header is available on the Message being handled.
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.
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.
setDefaultReplyDestination(Destination) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Set the default reply destination to send reply messages to.
setDefaultReplyQueueName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Set the name of the default reply queue to send reply messages to.
setDefaultReplyTimeout(long) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default timeout value for receiving reply messages.
setDefaultReplyTopicName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Set the name of the default reply topic to send reply messages to.
setDefaultRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default request channel.
setDefaultRequestTimeout(long) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the default timeout value for sending request messages.
setDefaultUrl(URL) - Method in class org.springframework.integration.http.DefaultOutboundRequestMapper
Specify the default URL to use when the outbound message does not contain a value for the HttpHeaders.REQUEST_URL header.
setDelayHeaderName(String) - Method in class org.springframework.integration.handler.DelayHandler
Specify the name of the header that should be checked for a delay period (in milliseconds) or a Date to delay until.
setDeleteFiles(boolean) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
Specify whether to delete the File after transformation.
setDeleteSourceFiles(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setDeleteSourceFiles(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Specify whether to delete source Files after writing to the destination directory.
setDelimiters(String) - Method in class org.springframework.integration.splitter.DefaultMessageSplitter
Set delimiters to use for tokenizing String values.
setDeliveryMode(int) - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
setDeliveryMode(int) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify the JMS DeliveryMode to use when sending request Messages.
setDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
setDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setDestination(Destination) - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
setDestination(Destination) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setDestinationName(String) - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
setDestinationName(String) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Set the DestinationResolver that should be used to resolve reply destination names for this listener.
setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setDestinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Provide the DestinationResolver to use when resolving either a 'requestDestinationName' or 'replyDestinationName' value.
setDirectory(File) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setDirectory(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setDirectory(File) - Method in class org.springframework.integration.file.FileReadingMessageSource
Specify the input directory.
setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
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.
setDocumentBuilder(DocumentBuilderFactory) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
setErrorChannel(MessageChannel) - Method in class org.springframework.integration.message.MessageBuilder
 
setErrorChannelName(String) - Method in class org.springframework.integration.message.MessageBuilder
 
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
 
setEvaluationTypes(Map<String, XPathEvaluationType>) - Method in class org.springframework.integration.xml.enricher.XPathHeaderEnricher
 
setEventTypes(List<Class<? extends ApplicationEvent>>) - Method in class org.springframework.integration.event.ApplicationEventInboundChannelAdapter
Set the list of event types (classes that extend ApplicationEvent) that this adapter should send to the message channel.
setExceptionTypeChannelMap(Map<Class<? extends Throwable>, MessageChannel>) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
setExceptionVariableName(String) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
setExpectReply(boolean) - Method in class org.springframework.integration.gateway.RemotingInboundGatewaySupport
Specify whether the gateway should be expected to return a reply.
setExpectReply(boolean) - Method in class org.springframework.integration.http.HttpInboundEndpoint
Specify whether this endpoint should perform a request/reply operation.
setExpectReply(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify whether a JMS reply Message is expected.
setExpirationDate(Long) - Method in class org.springframework.integration.message.MessageBuilder
 
setExpirationDate(Date) - Method in class org.springframework.integration.message.MessageBuilder
 
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<MessageGroupCallback>) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
Convenient injection point for expiry callbacks in the message store.
setExplicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
setExplicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setExplicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify whether explicit QoS settings are enabled (deliveryMode, priority, and timeToLive).
setExplicitQosEnabledForReplies(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify whether explicit QoS should be enabled for replies (for timeToLive, priority, and deliveryMode settings).
setExpression(String) - Method in class org.springframework.integration.handler.LoggingHandler
 
setExpressionSource(ExpressionSource) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
setExtractIntegrationMessagePayload(boolean) - Method in class org.springframework.integration.jms.HeaderMappingMessageConverter
Specify whether the outbound integration Message's payload should be extracted prior to conversion into a JMS Message.
setExtractJmsMessageBody(boolean) - Method in class org.springframework.integration.jms.HeaderMappingMessageConverter
Specify whether the inbound JMS Message's body should be extracted during the conversion process.
setExtractPayload(boolean) - Method in class org.springframework.integration.http.DefaultOutboundRequestMapper
Specify whether the outbound message's payload should be extracted when preparing the request body.
setExtractPayload(boolean) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
Specify whether the payload should be extracted from each received JMS Message to be used as the Spring Integration Message payload.
setExtractPayload(boolean) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
Specify whether the payload should be extracted from each Spring Integration Message to be converted to the body of a JMS Message.
setExtractPayload(boolean) - Method in class org.springframework.integration.ws.SimpleWebServiceInboundGateway
 
setExtractPayload(boolean) - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
Specify whether the source Message's payload should be extracted prior to marshalling.
setExtractReplyPayload(boolean) - Method in class org.springframework.integration.http.HttpInboundEndpoint
Specify whether the reply Message's payload should be passed in the response.
setExtractReplyPayload(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify whether the Spring Integration reply Message's payload should be extracted prior to converting into a JMS Message.
setExtractReplyPayload(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
This property will take effect if no custom MessageConverter has been provided to the JmsOutboundGateway.setMessageConverter(MessageConverter) method.
setExtractRequestPayload(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify whether the JMS request Message's body should be extracted prior to converting into a Spring Integration Message.
setExtractRequestPayload(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
This property will take effect if no custom MessageConverter has been provided to the JmsOutboundGateway.setMessageConverter(MessageConverter) method.
setFailedMessage(Message<?>) - Method in exception org.springframework.integration.core.MessagingException
 
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.
setFaultMessageResolver(FaultMessageResolver) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.FileWritingMessageHandler
Provide the FileNameGenerator strategy to use when generating the destination file's name.
setFilenamePattern(Pattern) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
setFilter(FileListFilter) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setFilter(FileListFilter) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
Sets a custom filter to be used by this scanner.
setFilter(FileListFilter) - Method in interface org.springframework.integration.file.DirectoryScanner
Sets a custom filter to be used by this scanner.
setFilter(FileListFilter) - Method in class org.springframework.integration.file.FileReadingMessageSource
Sets a FileListFilter.
setFilter(NotificationFilter) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Specify a NotificationFilter to be passed to the server when registering this listener.
setFilterReference(FileListFilter) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
setHandback(Object) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Specify a handback object to provide context to the listener upon notification.
setHandler(MessageHandler) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setHandlers(List<MessageHandler>) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
setHeader(String, Object) - Method in class org.springframework.integration.message.MessageBuilder
Set the value for the given header name.
setHeader(Node, String, XPathExpression, XPathEvaluationType, MessageBuilder<?>) - Method in class org.springframework.integration.xml.enricher.XPathHeaderEnricher
 
setHeaderExpressionMap(Map<String, String[]>) - Method in class org.springframework.integration.aop.MethodNameMappingExpressionSource
 
setHeaderExpressions(String[]) - Method in class org.springframework.integration.aop.SimpleExpressionSource
 
setHeaderIfAbsent(String, Object) - Method in class org.springframework.integration.message.MessageBuilder
Set the value for the given header name only if the header name is not already associated with a value.
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Provide a JmsHeaderMapper implementation to use when converting between JMS Messages and Spring Integration Messages.
setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Provide a JmsHeaderMapper implementation for mapping the Spring Integration Message Headers to/from JMS Message properties.
setHeaderName(String) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
Specify a custom header name to check for the file name.
setHeaderTypes(Map<String, Class<?>>) - Method in class org.springframework.integration.json.InboundJsonMessageMapper
 
setHttpClient(HttpClient) - Method in class org.springframework.integration.http.CommonsHttpRequestExecutor
Set the HttpClient instance to use for this request executor.
setIgnoreChannelNameResolutionFailures(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setIgnoreChannelNameResolutionFailures(boolean) - Method in class org.springframework.integration.router.AbstractChannelNameResolvingMessageRouter
Specify whether this router should ignore any failure to resolve a channel name to an actual MessageChannel instance when delegating to the ChannelResolver strategy.
setIgnoreEmptyResponses(boolean) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
Specify whether empty String response payloads should be ignored.
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.
setInputChannelName(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel
Set the list of channel interceptors.
setInterceptors(ClientInterceptor[]) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setIsolationLevelName(String) - Method in class org.springframework.integration.channel.MessageChannelTemplate
 
setJavaMailAuthenticator(Authenticator) - Method in class org.springframework.integration.mail.AbstractMailReceiver
Optional, sets the Authenticator to be used to obtain a session
setJavaMailProperties(Properties) - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
setJavaMailProperties(Properties) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setJdbcTemplate(JdbcOperations) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
The JdbcOperations to use when interacting with the database.
setJmsTemplate(JmsTemplate) - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
setLengthCheck(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
setLoadBalancingStrategy(LoadBalancingStrategy) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
Provide a LoadBalancingStrategy for this dispatcher.
setLobHandler(LobHandler) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Override the LobHandler that is used to create and unpack large objects in SQL queries.
setLocker(AbstractFileLockerFilter) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setLocker(FileLocker) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
Sets a custom locker to be used by this scanner.
setLocker(FileLocker) - Method in interface org.springframework.integration.file.DirectoryScanner
Sets a custom locker to be used by this scanner.
setLocker(FileLocker) - Method in class org.springframework.integration.file.FileReadingMessageSource
Optional.
setMapToPayload(boolean) - Method in class org.springframework.integration.json.InboundJsonMessageMapper
 
setMaxFetchSize(int) - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
setMaxFetchSize(int) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setMaxMessageSize(int) - Method in class org.springframework.integration.ip.tcp.AbstractSocketReader
 
setMaxMessagesPerPoll(int) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Set the maximum number of messages to receive for each poll.
setMaxMessagesPerPoll(int) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Provide a MessageConverter implementation to use when converting between JMS Messages and Spring Integration Messages.
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
Specify a MessageConverter to use when mapping from JMS Mesages to Spring Integration Messages.
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Provide a MessageConverter strategy to use for converting the Spring Integration request Message into a JMS Message and for converting the JMS reply Messages back into Spring Integration Messages.
setMessageFactory(WebServiceMessageFactory) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setMessageFormat(int) - Method in class org.springframework.integration.ip.tcp.AbstractSocketReader
 
setMessageFormat(int) - Method in class org.springframework.integration.ip.tcp.AbstractSocketWriter
 
setMessageFormat(int) - Method in class org.springframework.integration.ip.tcp.AbstractTcpReceivingChannelAdapter
 
setMessageFormat(int) - Method in class org.springframework.integration.ip.tcp.AbstractTcpSendingMessageHandler
 
setMessageFormat(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
setMessageFormat(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
 
setMessageFormat(int) - Method in interface org.springframework.integration.ip.tcp.SocketWriter
 
setMessageGroupStore(MessageGroupStore) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
A message group store to expire according the the other configurations.
setMessageIdEnabled(boolean) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setMessageProcessor(MessageProcessor) - Method in class org.springframework.integration.transformer.HeaderEnricher
 
setMessageSelector(String) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
Specify a JMS Message Selector expression to use when receiving Messages.
setMessageSender(WebServiceMessageSender) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setMessageSenders(WebServiceMessageSender[]) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setMessageStore(MessageGroupStore) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setMessageStore(MessageStore) - Method in class org.springframework.integration.handler.DelayHandler
Specify the MessageStore that should be used to store Messages while awaiting the delay.
setMessageTimestampEnabled(boolean) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setMethod(Method) - Method in class org.springframework.integration.message.MethodInvokingMessageSource
 
setMethodName(String) - Method in class org.springframework.integration.message.MethodInvokingMessageSource
 
setMethodNameVariableName(String) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
setMethodToChannelMap(Map<String, GatewayMethodDefinition>) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
setMethodValidator(MethodValidator) - Method in class org.springframework.integration.util.NameResolvingMethodInvoker
 
setMinAcksForSuccess(int) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
If acknowledge = true; how many acks needed for success.
setMultipartCharset(String) - Method in class org.springframework.integration.http.DefaultInboundRequestMapper
Specify the charset name to use when converting multipart file content into Strings.
setMultipartResolver(MultipartResolver) - Method in class org.springframework.integration.http.DefaultInboundRequestMapper
Specify the MultipartResolver to use when checking requests.
setNodeMapper(NodeMapper) - Method in class org.springframework.integration.xml.router.XPathMultiChannelRouter
 
setNotificationMapper(OutboundMessageMapper<Notification>) - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
Set a mapper for creating Notifications from a Message.
setObject(Object) - Method in class org.springframework.integration.message.MethodInvokingMessageSource
 
setObjectName(String) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
Specify the String value of the JMX MBean's ObjectName.
setObjectName(ObjectName) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Specify the JMX ObjectName of the notification publisher to which this notification listener should be subscribed.
setOperationChannel(SubscribableChannel) - Method in class org.springframework.integration.control.ControlBus
 
setOrder(int) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
setOrder(Integer) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setOrder(int) - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
setOrder(int) - Method in class org.springframework.integration.handler.DelayHandler
 
setOrder(int) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
setOrder(int) - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
setOrder(int) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
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.file.config.FileWritingMessageHandlerFactoryBean
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.handler.DelayHandler
Set the output channel for this handler.
setOutputChannel(MessageChannel) - Method in class org.springframework.integration.handler.MessageHandlerChain
 
setPayloadExpression(String) - Method in class org.springframework.integration.aop.SimpleExpressionSource
 
setPayloadTypeChannelMap(Map<Class<?>, MessageChannel>) - Method in class org.springframework.integration.router.PayloadTypeRouter
 
setPhase(int) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
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.ip.tcp.AbstractTcpReceivingChannelAdapter
 
setPoolSize(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
setPoolSize(int) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
setPort(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
setPrefix(String) - Method in class org.springframework.integration.router.AbstractChannelNameResolvingMessageRouter
Specify a prefix to be added to each channel name prior to resolution.
setPreventDuplicates(Boolean) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
setPriority(int) - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
setPriority(int) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setPriority(int) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify the JMS priority to use when sending request Messages.
setPriority(MessagePriority) - Method in class org.springframework.integration.message.MessageBuilder
 
setPropagationBehaviorName(String) - Method in class org.springframework.integration.channel.MessageChannelTemplate
 
setPubSubDomain(boolean) - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
setPubSubDomain(boolean) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setPubSubDomain(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify whether the request destination is a Topic.
setPubSubNoLocal(boolean) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setQueueSize(Integer) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setReadTimeout(int) - Method in class org.springframework.integration.http.CommonsHttpRequestExecutor
Set the socket read timeout for the underlying HttpClient.
setReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setReceiveBufferSize(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
setReceiveTimeout(long) - Method in class org.springframework.integration.channel.MessageChannelTemplate
Specify the timeout value to use for receive operations.
setReceiveTimeout(long) - Method in class org.springframework.integration.endpoint.PollingConsumer
 
setReceiveTimeout(long) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the max timeout value for the MessageConsumer's receive call when waiting for a reply.
setReceiveTimeout(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Populates the specified bean definition property with the reference to a bean.
setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Populates the bean definition property corresponding to the specified attributeName with the reference to a bean identified by the value of that attribute if the attribute is defined in the given element.
setRegion(String) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
A unique grouping identifier for all messages persisted with this store.
setRegistryHost(String) - Method in class org.springframework.integration.rmi.RmiInboundGateway
 
setRegistryPort(int) - Method in class org.springframework.integration.rmi.RmiInboundGateway
 
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.CorrelatingMessageHandler
 
setReliabilityAttributes(boolean, boolean, String, int, int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setRemoteInvocationExecutor(RemoteInvocationExecutor) - Method in class org.springframework.integration.rmi.RmiInboundGateway
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.AbstractMessagingGateway
Set the reply channel.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.AbstractRemotingOutboundGateway
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
Specify the Spring Integration reply channel.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify the Spring Integration reply channel.
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.message.MessageBuilder
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setReplyChannel(MessageChannel) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setReplyChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMethodDefinition
 
setReplyChannelName(String) - Method in class org.springframework.integration.message.MessageBuilder
 
setReplyDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify the delivery mode for JMS reply Messages.
setReplyDestination(Destination) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the JMS Destination from which reply Messages should be received.
setReplyDestinationName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the name of the JMS Destination from which reply Messages should be received.
setReplyKey(String) - Method in class org.springframework.integration.http.HttpInboundEndpoint
Specify the key to be used when storing the reply Message or payload in the model map.
setReplyPriority(int) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify the priority value for JMS reply Messages.
setReplyTimeout(long) - Method in class org.springframework.integration.gateway.AbstractMessagingGateway
Set the timeout value for receiving reply messages.
setReplyTimeout(String) - Method in class org.springframework.integration.gateway.GatewayMethodDefinition
 
setReplyTimeout(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify the maximum time to wait for reply Messages.
setReplyTimeout(long) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setReplyTimeToLive(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify the time-to-live property for JMS reply Messages.
setRequestCallback(WebServiceMessageCallback) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.gateway.AbstractMessagingGateway
Set the request channel.
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify the channel to which request Messages should be sent.
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.rmi.RmiInboundGateway
Specify the request channel where messages will be sent.
setRequestChannel(MessageChannel) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setRequestChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMethodDefinition
 
setRequestDestination(Destination) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the JMS Destination to which request Messages should be sent.
setRequestDestinationName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Set the name of the JMS Destination to which request Messages should be sent.
setRequestExecutor(HttpRequestExecutor) - Method in class org.springframework.integration.http.HttpOutboundEndpoint
Specify the HttpRequestExecutor to use for executing the HttpRequest instances at runtime.
setRequestKey(String) - Method in class org.springframework.integration.http.HttpInboundEndpoint
Specify the key to be used when storing the request Message in the model map.
setRequestMapper(InboundRequestMapper) - Method in class org.springframework.integration.http.HttpInboundEndpoint
Specify an InboundRequestMapper implementation to map from the inbound HttpServletRequest instances to Messages at runtime.
setRequestMapper(OutboundRequestMapper) - Method in class org.springframework.integration.http.HttpOutboundEndpoint
Specify an OutboundRequestMapper implementation to map from Messages to outbound HttpRequest objects.
setRequestTimeout(long) - Method in class org.springframework.integration.gateway.AbstractMessagingGateway
Set the timeout value for sending request messages.
setRequestTimeout(String) - Method in class org.springframework.integration.gateway.GatewayMethodDefinition
 
setRequestTimeout(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
Specify the maximum time to wait when sending a request message to the request channel.
setRequestTimeout(long) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
setRequiresReply(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setRequiresReply(boolean) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
Flag wether reply is required.
setResolutionRequired(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
 
setResolutionRequired(boolean) - Method in class org.springframework.integration.router.AbstractMessageRouter
Set whether this router should always be required to resolve at least one channel.
setResourceLoader(ResourceLoader) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
 
setResultFactory(ResultFactory) - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
 
setResultFactory(ResultFactory) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
setReturnValueVariableName(String) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
setRowMapper(RowMapper<?>) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
setScanEachPoll(Boolean) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setScanEachPoll(boolean) - Method in class org.springframework.integration.file.FileReadingMessageSource
Optional.
setScanner(DirectoryScanner) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
 
setScanner(DirectoryScanner) - Method in class org.springframework.integration.file.FileReadingMessageSource
Optionally specify a custom scanner, for example the RecursiveLeafOnlyDirectoryScanner
setSelectors(List<MessageSelector>) - Method in class org.springframework.integration.selector.MessageSelectorChain
Initialize the selector chain.
setSendPartialResultOnExpiry(boolean) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setSendTimeout(long) - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
setSendTimeout(long) - Method in class org.springframework.integration.channel.MessageChannelTemplate
Specify the timeout value to use for send operations.
setSendTimeout(long) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
 
setSendTimeout(Long) - Method in class org.springframework.integration.config.FilterFactoryBean
 
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.file.config.FileWritingMessageHandlerFactoryBean
 
setSendTimeout(long) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
Set the timeout for sending reply Messages.
setSendTimeout(long) - Method in class org.springframework.integration.handler.DelayHandler
Set the timeout for sending reply Messages.
setSequenceNumber(Integer) - Method in class org.springframework.integration.message.MessageBuilder
 
setSequenceSize(Integer) - Method in class org.springframework.integration.message.MessageBuilder
 
setServer(MBeanServer) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
Provide the MBeanServer where the JMX MBean has been registered.
setServer(MBeanServer) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
Provide a reference to the MBeanServer where the notification publishing MBeans are registered.
setServer(MBeanServer) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
Provide a reference to the MBeanServer within which the MBean target for operation invocation has been registered.
setServiceInterface(Class<?>) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Set the interface class that the generated proxy should implement.
setSessionAcknowledgeMode(int) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setSessionTransacted(boolean) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setShouldAppendNewLine(boolean) - Method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
 
setShouldDeleteMessages(boolean) - Method in class org.springframework.integration.mail.ImapMailReceiver
Specify whether mail messages should be deleted after retrieval.
setShouldExtractPayload(boolean) - Method in class org.springframework.integration.json.OutboundJsonMessageMapper
 
setShouldLogFullMessage(boolean) - Method in class org.springframework.integration.handler.LoggingHandler
Specify whether to log the full Message.
setShouldReconnectAutomatically(boolean) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
Specify whether the IDLE task should reconnect automatically after catching a FolderClosedException while waiting for messages.
setShouldThrowErrors(boolean) - Method in class org.springframework.integration.gateway.AbstractMessagingGateway
Specify whether the Throwable payload of a received ErrorMessage should be extracted and thrown from a send-and-receive operation.
setShouldTruncate(boolean) - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
setSkipSettingNullResults(boolean) - Method in class org.springframework.integration.xml.enricher.XPathHeaderEnricher
 
setSocketAttributes(Socket) - Method in class org.springframework.integration.ip.tcp.AbstractTcpSendingMessageHandler
Sets socket attributes on the socket.
setSocketAttributes(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setSocketOptions(Socket) - Method in class org.springframework.integration.ip.tcp.AbstractTcpReceivingChannelAdapter
Sets soTimeout, soKeepAlive and tcpNoDelay according to the configured properties.
setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.AbstractTcpReceivingChannelAdapter
 
setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.AbstractTcpSendingMessageHandler
 
setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
 
setSoLinger(int) - Method in class org.springframework.integration.ip.tcp.AbstractTcpSendingMessageHandler
Enables SO_LINGER on the underlying socket.
setSoLinger(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
setSoReceiveBufferSize(int) - Method in interface org.springframework.integration.ip.CommonSocketOptions
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
 
setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
setSoSendBufferSize(int) - Method in interface org.springframework.integration.ip.CommonSocketOptions
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
 
setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.tcp.AbstractTcpSendingMessageHandler
 
setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
setSoTimeout(int) - Method in interface org.springframework.integration.ip.CommonSocketOptions
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
setSoTimeout(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
 
setSoTrafficClass(int) - Method in class org.springframework.integration.ip.tcp.AbstractTcpSendingMessageHandler
 
setSoTrafficClass(int) - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
 
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.
setSourceFactory(SourceFactory) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
 
setSourceFactory(SourceFactory) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
 
setSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
 
setSqlParameterSourceFactoryForUpdate(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
setStaticHeaders(Map<String, Object>) - Method in class org.springframework.integration.gateway.GatewayMethodDefinition
 
setStoreUri(String) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
setSuffix(String) - Method in class org.springframework.integration.router.AbstractChannelNameResolvingMessageRouter
Specify a suffix to be added to each channel name prior to resolution.
setSupportedMethods(String...) - Method in class org.springframework.integration.http.HttpInboundEndpoint
Specify the supported request methods for this endpoint.
setTablePrefix(String) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Public setter for the table prefix property.
setTargetBeanName(String) - Method in class org.springframework.integration.http.DataBindingInboundRequestMapper
Specify the name of a bean definition to use when creating the target instance.
setTargetType(Class<?>) - Method in class org.springframework.integration.http.DataBindingInboundRequestMapper
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
setTaskExecutor(Executor) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
 
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.
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
 
setTimeout(long) - Method in class org.springframework.integration.router.AbstractMessageRouter
Set the timeout for sending a message to the resolved channel.
setTimeout(long) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
Timeout in milliseconds (default -1).
setTimeToLive(int) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
Set the underlying MulticastSocket time to live property.
setTimeToLive(long) - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
setTimeToLive(long) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
setTimeToLive(long) - Method in class org.springframework.integration.jms.JmsOutboundGateway
Specify the timeToLive for each sent Message.
setTransactionDefinition(TransactionDefinition) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
setTransactionDefinition(TransactionDefinition) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.channel.MessageChannelTemplate
Specify a transaction manager to use for all exchange operations.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Specify a transaction manager to use for all polling operations.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.scheduling.PollerMetadata
 
setTransactionReadOnly(boolean) - Method in class org.springframework.integration.channel.MessageChannelTemplate
 
setTransactionTimeout(int) - Method in class org.springframework.integration.channel.MessageChannelTemplate
 
setTransformOnSend(boolean) - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
 
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
 
setTypeConverter(TypeConverter) - Method in class org.springframework.integration.util.DefaultMethodInvoker
 
setUpdatePerRow(boolean) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
setUpdateSql(String) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
 
setUpdateSql(String) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.NioSocketReader
 
setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.NioSocketWriter
 
setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.TcpNioReceivingChannelAdapter
 
setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.TcpNioSendingMessageHandler
 
setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
Populates the specified bean definition property with the value of 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
Populates the bean definition property corresponding to the specified attributeName with the value of that attribute if it is defined in the given element.
setView(View) - Method in class org.springframework.integration.http.HttpInboundEndpoint
Specify a View to be used for rendering the response.
setVotingStrategy(MessageSelectorChain.VotingStrategy) - Method in class org.springframework.integration.selector.MessageSelectorChain
Specify the voting strategy for this selector chain.
setWaitForTasksToCompleteOnShutdown(boolean) - Method in class org.springframework.integration.handler.DelayHandler
Set whether to wait for scheduled tasks to complete on shutdown.
setWebBindingInitializer(WebBindingInitializer) - Method in class org.springframework.integration.http.DataBindingInboundRequestMapper
Specify an optional WebBindingInitializer to be invoked prior to the request binding process.
setXmlPayloadConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
shouldCreateEndpoint(T) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
 
shouldDeleteMessages() - Method in class org.springframework.integration.mail.AbstractMailReceiver
Subclasses must implement this method to indicate whether the mail messages should be deleted after being received.
shouldDeleteMessages() - Method in class org.springframework.integration.mail.ImapMailReceiver
 
shouldDeleteMessages() - Method in class org.springframework.integration.mail.Pop3MailReceiver
POP3 is unable to detect new Messages, so this always returns true.
shouldGenerateId() - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.JdbcMessageHandlerParser
 
shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.JdbcPollingChannelAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.jms.config.JmsInboundChannelAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
 
shouldGenerateId() - Method in class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
 
shouldGenerateId() - Method in class org.springframework.integration.security.config.SecuredChannelsParser
 
shouldGenerateId() - Method in class org.springframework.integration.xml.config.XmlPayloadValidatingRouterParser
 
shouldGenerateId() - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
shouldGenerateId() - Method in class org.springframework.integration.xml.config.XPathMessageSplitterParser
 
shouldGenerateId() - Method in class org.springframework.integration.xml.config.XPathRouterParser
 
shouldGenerateId() - Method in class org.springframework.integration.xml.config.XPathSelectorParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.JdbcMessageHandlerParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.JdbcPollingChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jms.config.JmsInboundChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xml.config.XmlPayloadValidatingRouterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xml.config.XPathMessageSplitterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xml.config.XPathRouterParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xml.config.XPathSelectorParser
 
shutDown() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
SimpleExpressionSource - Class in org.springframework.integration.aop
Simple implementation of ExpressionSource that allows for configuration of a single channel name, payload expression, and array of header key=value expressions.
SimpleExpressionSource() - Constructor for class org.springframework.integration.aop.SimpleExpressionSource
 
SimpleHttpRequestExecutor - Class in org.springframework.integration.http
Implementation of HttpRequestExecutor that uses HttpURLConnection directly.
SimpleHttpRequestExecutor() - Constructor for class org.springframework.integration.http.SimpleHttpRequestExecutor
 
SimpleMessageGroup - Class in org.springframework.integration.store
Represents a mutable group of correlated messages that is bound to a certain MessageStore and correlation key.
SimpleMessageGroup(Object) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(Collection<? extends Message<?>>, Object) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(Collection<? extends Message<?>>, Collection<? extends Message<?>>, Object, long) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageGroup(MessageGroup) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
 
SimpleMessageMapper - Class in org.springframework.integration.gateway
An implementation of the InboundMessageMapper and OutboundMessageMapper strategy interfaces that maps directly to and from the Message payload instance.
SimpleMessageMapper() - Constructor for class org.springframework.integration.gateway.SimpleMessageMapper
 
SimpleMessageStore - Class in org.springframework.integration.store
Map-based 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) - 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
SimpleMessagingGateway - Class in org.springframework.integration.gateway
An implementation of AbstractMessagingGateway that delegates to an InboundMessageMapper and OutboundMessageMapper.
SimpleMessagingGateway() - Constructor for class org.springframework.integration.gateway.SimpleMessagingGateway
 
SimpleMessagingGateway(InboundMessageMapper<?>, OutboundMessageMapper<?>) - Constructor for class org.springframework.integration.gateway.SimpleMessagingGateway
 
SimpleTcpNetInboundGateway - Class in org.springframework.integration.ip.tcp
Simple implementation of a TCP/IP inbound gateway; uses Socket and socket reader thread hangs on receive for response; therefore no multiplexing of incoming messages is supported.
SimpleTcpNetInboundGateway() - Constructor for class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
SimpleTcpNetOutboundGateway - Class in org.springframework.integration.ip.tcp
Simple TCP outbound gateway; delegates write to a TcpNetSendingMessageHandler then blocks on read of same socket.
SimpleTcpNetOutboundGateway(String, int) - Constructor for class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
Constructs a SimpleTcpNetOutboundGateway that sends data to the specified host and port, and waits for a response.
SimpleWebServiceInboundGateway - Class in org.springframework.integration.ws
 
SimpleWebServiceInboundGateway() - Constructor for class org.springframework.integration.ws.SimpleWebServiceInboundGateway
 
SimpleWebServiceOutboundGateway - Class in org.springframework.integration.ws
An outbound Messaging Gateway for invoking a Web Service.
SimpleWebServiceOutboundGateway(DestinationProvider) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
SimpleWebServiceOutboundGateway(DestinationProvider, SourceExtractor) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
SimpleWebServiceOutboundGateway(DestinationProvider, SourceExtractor, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
size() - Method in class org.springframework.integration.core.MessageHeaders
 
size() - Method in interface org.springframework.integration.store.MessageGroup
 
size() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
SOAP_ACTION - Static variable in class org.springframework.integration.ws.WebServiceHeaders
 
socket - Variable in class org.springframework.integration.ip.tcp.NetSocketReader
 
socket - Variable in class org.springframework.integration.ip.tcp.NetSocketWriter
 
socket - Variable in class org.springframework.integration.ip.tcp.TcpNetSendingMessageHandler
 
socket - Variable in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
socket - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
socketChannel - Variable in class org.springframework.integration.ip.tcp.TcpNioSendingMessageHandler
 
SocketIoUtils - Class in org.springframework.integration.ip.util
 
SocketIoUtils() - Constructor for class org.springframework.integration.ip.util.SocketIoUtils
 
SocketMessageMapper - Class in org.springframework.integration.ip.tcp
Maps incoming data from a SocketReader to a Message and from a Message to outgoing data forwarded to a SocketWriter.
SocketMessageMapper() - Constructor for class org.springframework.integration.ip.tcp.SocketMessageMapper
 
SocketReader - Interface in org.springframework.integration.ip.tcp
General interface for assembling message data from a TCP/IP Socket.
SocketWriter - Interface in org.springframework.integration.ip.tcp
A general interface for writing to sockets.
soKeepAlive - Variable in class org.springframework.integration.ip.tcp.AbstractTcpReceivingChannelAdapter
 
soKeepAlive - Variable in class org.springframework.integration.ip.tcp.AbstractTcpSendingMessageHandler
 
soKeepAlive - Variable in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
soLinger - Variable in class org.springframework.integration.ip.tcp.AbstractTcpSendingMessageHandler
 
soReceiveBufferSize - Variable in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
soReceiveBufferSize - Variable in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
soReceiveBufferSize - Variable in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
 
soReceiveBufferSize - Variable in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
soSendBufferSize - Variable in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
soSendBufferSize - Variable in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
soSendBufferSize - Variable in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
soTcpNoDelay - Variable in class org.springframework.integration.ip.tcp.AbstractTcpSendingMessageHandler
 
soTimeout - Variable in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
soTimeout - Variable in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
soTimeout - Variable in class org.springframework.integration.ip.tcp.SimpleTcpNetInboundGateway
 
soTrafficClass - Variable in class org.springframework.integration.ip.tcp.AbstractTcpSendingMessageHandler
 
SourceCreatingTransformer - Class in org.springframework.integration.xml.transformer
Transforms the payload to a Source using a SourceFactory.
SourceCreatingTransformer() - Constructor for class org.springframework.integration.xml.transformer.SourceCreatingTransformer
 
SourceCreatingTransformer(SourceFactory) - Constructor for class org.springframework.integration.xml.transformer.SourceCreatingTransformer
 
SourceFactory - Interface in org.springframework.integration.xml.source
Factory to create a Source possibly taking into account the provided message payload instance.
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
 
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
 
splitMessage(Message<?>) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
splitNodePayload(Node, Message) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
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(ListableBeanFactory) - 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
 
SqlParameterSourceFactory - Interface in org.springframework.integration.jdbc
Collaborator for JdbcPollingChannelAdapter which allows creation of instances of SqlParameterSource for use in updates to be created according to the result of the poll.
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.interceptor.WireTap
Restart the wire tap if it has been stopped.
start() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
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.ws.MarshallingWebServiceInboundGateway
 
StaticHandlerMethodResolver - Class in org.springframework.integration.handler
An implementation of HandlerMethodResolver that always returns the same Method instance.
StaticHandlerMethodResolver(Method) - Constructor for class org.springframework.integration.handler.StaticHandlerMethodResolver
 
stderr() - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
Factory method that creates a target for stderr (System.err) with the default charset encoding.
stderr(String) - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
Factory method that creates a target for stderr (System.err) with the specified charset encoding.
stdin() - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
stdin(String) - Static method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
stdout() - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
Factory method that creates a target for stdout (System.out) with the default charset encoding.
stdout(String) - Static method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
Factory method that creates a target for stdout (System.out) with the specified charset encoding.
stop() - Method in class org.springframework.integration.channel.interceptor.WireTap
Stop the wire tap.
stop() - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
 
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.ws.MarshallingWebServiceInboundGateway
 
StreamNamespaceHandler - Class in org.springframework.integration.stream.config
 
StreamNamespaceHandler() - Constructor for class org.springframework.integration.stream.config.StreamNamespaceHandler
 
StringMessage - Class in org.springframework.integration.message
A message implementation that accepts a String payload.
StringMessage(String) - Constructor for class org.springframework.integration.message.StringMessage
 
StringResultFactory - Class in org.springframework.integration.xml.result
 
StringResultFactory() - Constructor for class org.springframework.integration.xml.result.StringResultFactory
 
StringSourceFactory - Class in org.springframework.integration.xml.source
SourceFactory implementation which supports creation of a StringSource from either a Document or String payload
StringSourceFactory() - Constructor for class org.springframework.integration.xml.source.StringSourceFactory
 
StringSourceFactory(TransformerFactory) - Constructor for class org.springframework.integration.xml.source.StringSourceFactory
 
StringValueTestXPathMessageSelector - Class in org.springframework.integration.xml.selector
XPath MessageSelector that tests if a provided value supports payloads of type Document or String.
StringValueTestXPathMessageSelector(String, Map<String, String>, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Create a selector which tests for the given value and supports multiple namespaces.
StringValueTestXPathMessageSelector(String, String, String, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Creates a single namespace Xpath selector.
StringValueTestXPathMessageSelector(String, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Creates non-namespaced testing selector.
StringValueTestXPathMessageSelector(XPathExpression, String) - Constructor for class org.springframework.integration.xml.selector.StringValueTestXPathMessageSelector
Creates a selector with the provided XPathExpression.
STX - Static variable in interface org.springframework.integration.ip.tcp.MessageFormats
 
stxPart - Variable in class org.springframework.integration.ip.tcp.NioSocketWriter
A buffer containing the STX for when the messageFormat is MessageFormats.FORMAT_STX_ETX.
SUBJECT - Static variable in class org.springframework.integration.mail.MailHeaders
 
SubscribableChannel - Interface in org.springframework.integration.channel
Interface for any MessageChannel implementation that accepts subscribers.
subscribe(MessageHandler) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
subscribe(MessageHandler) - Method in interface org.springframework.integration.channel.SubscribableChannel
Register a MessageHandler as a subscriber to this channel.
subscribe(MessageHandler) - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
supports(Class) - Method in class org.springframework.integration.security.channel.ChannelInvocationDefinitionSource
 

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