- Gateway - Annotation Type in org.springframework.integration.annotation
-
Indicates that a method is capable of mapping its parameters to a message
or message payload.
- GatewayMethodMetadata - Class in org.springframework.integration.gateway
-
Represents the metadata associated with a Gateway method.
- GatewayMethodMetadata() - Constructor for class org.springframework.integration.gateway.GatewayMethodMetadata
-
- GatewayParser - Class in org.springframework.integration.config.xml
-
Parser for the <gateway/> element.
- GatewayParser() - Constructor for class org.springframework.integration.config.xml.GatewayParser
-
- GatewayProxyFactoryBean - Class in org.springframework.integration.gateway
-
Generates a proxy for the provided service interface to enable interaction
with messaging components without application code being aware of them allowing
for POJO-style interaction.
- GatewayProxyFactoryBean() - Constructor for class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Create a Factory whose service interface type can be configured by setter injection.
- GatewayProxyFactoryBean(Class<?>) - Constructor for class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- GemfireCqInboundChannelAdapterParser - Class in org.springframework.integration.gemfire.config.xml
-
- GemfireCqInboundChannelAdapterParser() - Constructor for class org.springframework.integration.gemfire.config.xml.GemfireCqInboundChannelAdapterParser
-
- GemfireInboundChannelAdapterParser - Class in org.springframework.integration.gemfire.config.xml
-
- GemfireInboundChannelAdapterParser() - Constructor for class org.springframework.integration.gemfire.config.xml.GemfireInboundChannelAdapterParser
-
- GemfireIntegrationNamespaceHandler - Class in org.springframework.integration.gemfire.config.xml
-
- GemfireIntegrationNamespaceHandler() - Constructor for class org.springframework.integration.gemfire.config.xml.GemfireIntegrationNamespaceHandler
-
- GemfireMessageStore - Class in org.springframework.integration.gemfire.store
-
- GemfireMessageStore(Region<Object, Object>) - Constructor for class org.springframework.integration.gemfire.store.GemfireMessageStore
-
Provides the region to be used for the message store.
- GemfireMessageStore(Cache) - Constructor for class org.springframework.integration.gemfire.store.GemfireMessageStore
-
Provides a cache reference used to create a message store region named
'messageStoreRegion'
- GemfireOutboundChannelAdapterParser - Class in org.springframework.integration.gemfire.config.xml
-
- GemfireOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.gemfire.config.xml.GemfireOutboundChannelAdapterParser
-
- generateAlias(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- generateFileName(Message<?>) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
-
- generateFileName(Message<?>) - Method in interface org.springframework.integration.file.FileNameGenerator
-
- generateId() - Method in class org.springframework.integration.MessageHeaders.AlternativeJdkIdGenerator
-
- generateId() - Method in interface org.springframework.integration.MessageHeaders.IdGenerator
-
- generateId() - Method in class org.springframework.integration.MessageHeaders.JdkIdGenerator
-
- generateId() - Method in class org.springframework.integration.MessageHeaders.SimpleIncrementingIdGenerator
-
- generateScriptName(Message<?>) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
-
- generateScriptVariables(Message<?>) - Method in class org.springframework.integration.scripting.DefaultScriptVariableGenerator
-
- generateScriptVariables(Message<?>) - Method in interface org.springframework.integration.scripting.ScriptVariableGenerator
-
- generateSearchTerm(Flags, Folder) - Method in interface org.springframework.integration.mail.SearchTermStrategy
-
Will generate an instance of the SearchTerm
- GenericMessage<T> - Class in org.springframework.integration.message
-
Base Message class defining common properties such as id, payload, and headers.
- GenericMessage(T) - Constructor for class org.springframework.integration.message.GenericMessage
-
Create a new message with the given payload.
- GenericMessage(T, Map<String, Object>) - Constructor for class org.springframework.integration.message.GenericMessage
-
Create a new message with the given payload.
- get(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
-
- get(Message<?>, Session<F>, String, String, String, boolean) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Copy a remote file to the configured local directory.
- get(Message<?>, InputStreamCallback) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Retrieve a remote file as an InputStream, based on information in a message.
- get(Message<?>, InputStreamCallback) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- get(int) - Method in class org.springframework.integration.history.MessageHistory
-
- get(Object, Class<T>) - Method in class org.springframework.integration.MessageHeaders
-
- get(Object) - Method in class org.springframework.integration.MessageHeaders
-
- get(String) - Method in interface org.springframework.integration.metadata.MetadataStore
-
Reads a value for the given key from this MetadataStore.
- get(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
-
- get(String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
-
- get(String) - Method in class org.springframework.integration.redis.metadata.RedisMetadataStore
-
Retrieve the persisted value for the provided key.
- getAckPort() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- getActiveCount() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getActiveCount() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- getActiveCount() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
-
- getActiveCount() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- getActiveCount() - Method in interface org.springframework.integration.util.Pool
-
Returns the number of allocated items that are currently
checked out of the pool.
- getActiveCount() - Method in class org.springframework.integration.util.SimplePool
-
- getActiveHandlerCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- getAdvice() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
-
- getAdviceChain() - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- getAggregatedExceptions() - Method in exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
-
- getAllConfigAttributes() - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
-
- getAllocatedCount() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getAllocatedCount() - Method in interface org.springframework.integration.util.Pool
-
Returns the current count of allocated items (in use and
idle).
- getAllocatedCount() - Method in class org.springframework.integration.util.SimplePool
-
- getApplicationContextId() - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
Returns the ApplicationContext.getId()
if the
ApplicationContext
is available.
- getApplicationEventPublisher() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getArgs() - Method in class org.springframework.integration.gateway.MethodArgsHolder
-
- getAttributes(Object) - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
-
- getAttributes() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
-
Will return an immutable Map of current attributes.
- getBacklog() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
The number of sockets in the server connection backlog.
- getBeanClass(Element) - Method in class org.springframework.integration.config.xml.SpelFunctionParser
-
- getBeanClass(Element) - Method in class org.springframework.integration.xml.config.XPathExpressionParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.GatewayParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.MessageHistoryParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.SelectorChainParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.SelectorParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.groovy.config.GroovyScriptParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.ip.config.TcpInboundGatewayParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.rmi.config.RmiInboundGatewayParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.scripting.config.AbstractScriptParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.scripting.config.jsr223.ScriptParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.security.config.SecuredChannelsParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.xmpp.config.ChatMessageInboundChannelAdapterParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.xmpp.config.PresenceInboundChannelAdapterParser
-
- getBeanClassName(Element) - Method in class org.springframework.integration.xmpp.config.XmppConnectionParser
-
- getBeanDefinitionBuilderConstructorValue(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
-
- getBeanDefinitionBuilderConstructorValue(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalWireTapParser
-
- getBeanFactory() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- getBeanFactory() - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- getBytes() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
-
- getCacheLevel() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- getCause() - Method in class org.springframework.integration.event.IntegrationEvent
-
- getChannel() - Method in class org.springframework.integration.router.RecipientListRouter.Recipient
-
- getChannel() - Method in class org.springframework.integration.security.channel.ChannelInvocation
-
- getChannelCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- getChannelErrorRate(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- getChannelInterceptor() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
-
- getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Subclasses must implement this method to return the channel keys.
- getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
-
- getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.HeaderValueRouter
-
- getChannelKeys(Message<?>) - Method in class org.springframework.integration.router.PayloadTypeRouter
-
Selects the most appropriate channel name matching channel identifiers which are the
fully qualified class names encountered while traversing the payload type hierarchy.
- getChannelKeys(Message<?>) - Method in class org.springframework.integration.xml.router.XPathRouter
-
- getChannelMappings() - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Returns an unmodifiable version of the channel mappings.
- getChannelName(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
-
- getChannelName(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
-
- getChannelName(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
-
- getChannelNames() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- getChannelOutputStream() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- getChannelOutputStream() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
-
- getChannelReceiveCount(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- getChannelSendRate(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- getClientConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- getClientConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- getCode() - Method in enum org.springframework.integration.jdbc.config.JdbcTypesEnum
-
Get the numerical representation of the JDBC Type enum.
- getCommand() - Method in enum org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
-
- getComponentName() - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- getComponentName() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- getComponentName() - Method in interface org.springframework.integration.support.context.NamedComponent
-
- getComponentType() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- getComponentType() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- getComponentType() - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
- getComponentType() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
-
- getComponentType() - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
Subclasses may implement this method to provide component type information.
- getComponentType() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- getComponentType() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- getComponentType() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
-
- getComponentType() - Method in class org.springframework.integration.file.FileReadingMessageSource
-
- getComponentType() - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
-
- getComponentType() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
- getComponentType() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
-
- getComponentType() - Method in class org.springframework.integration.filter.MessageFilter
-
- getComponentType() - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizingMessageSource
-
- getComponentType() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- getComponentType() - Method in class org.springframework.integration.handler.AbstractMessageHandler
-
- getComponentType() - Method in class org.springframework.integration.handler.BridgeHandler
-
- getComponentType() - Method in class org.springframework.integration.handler.DelayHandler
-
- getComponentType() - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
-
- getComponentType() - Method in class org.springframework.integration.handler.LoggingHandler
-
- getComponentType() - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- getComponentType() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
-
- getComponentType() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
-
- getComponentType() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
- getComponentType() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getComponentType() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- getComponentType() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- getComponentType() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- getComponentType() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- getComponentType() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- getComponentType() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- getComponentType() - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
- getComponentType() - Method in class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
-
- getComponentType() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- getComponentType() - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
-
- getComponentType() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- getComponentType() - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- getComponentType() - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
- getComponentType() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
- getComponentType() - Method in class org.springframework.integration.jpa.inbound.JpaPollingChannelAdapter
-
- getComponentType() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
- getComponentType() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- getComponentType() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- getComponentType() - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
- getComponentType() - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
- getComponentType() - Method in class org.springframework.integration.rmi.RmiInboundGateway
-
- getComponentType() - Method in class org.springframework.integration.router.AbstractMessageRouter
-
- getComponentType() - Method in class org.springframework.integration.router.RecipientListRouter
-
- getComponentType() - Method in class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
-
- getComponentType() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
-
- getComponentType() - Method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
- getComponentType() - Method in interface org.springframework.integration.support.context.NamedComponent
-
- getComponentType() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
-
- getComponentType() - Method in class org.springframework.integration.twitter.inbound.DirectMessageReceivingMessageSource
-
- getComponentType() - Method in class org.springframework.integration.twitter.inbound.MentionsReceivingMessageSource
-
- getComponentType() - Method in class org.springframework.integration.twitter.inbound.SearchReceivingMessageSource
-
- getComponentType() - Method in class org.springframework.integration.twitter.inbound.TimelineReceivingMessageSource
-
- getComponentType() - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
-
- getComponentType() - Method in class org.springframework.integration.xml.router.XPathRouter
-
- getComponentType() - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
-
- getComponentType() - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
- getComponentType() - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
-
- getComponentType() - Method in class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
-
- getConcurrentConsumers() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- getConfigAttributesForReceive() - Method in interface org.springframework.integration.security.channel.ChannelAccessPolicy
-
- getConfigAttributesForReceive() - Method in class org.springframework.integration.security.channel.DefaultChannelAccessPolicy
-
- getConfigAttributesForSend() - Method in interface org.springframework.integration.security.channel.ChannelAccessPolicy
-
- getConfigAttributesForSend() - Method in class org.springframework.integration.security.channel.DefaultChannelAccessPolicy
-
- getConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
- getConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
Not supported because the factory manages multiple connections and this
method cannot discriminate.
- getConnection() - Method in interface org.springframework.integration.ip.tcp.connection.ConnectionFactory
-
- getConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- getConnectionFactoryName() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionEvent
-
- getConnectionId() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
- getConnectionId() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionEvent
-
- getConnectionId() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- getConnectionId() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- getConnections() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
- getConnections() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
- getConnections() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- getConsumes() - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- getContentType() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
-
- getConversionService(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
-
Return the ConversionService
bean whose name is "integrationConversionService" if available.
- getConversionService() - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- getConverter() - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
-
- getCorrelationId() - Method in class org.springframework.integration.MessageHeaders
-
- getCorrelationKey(Message<?>) - Method in interface org.springframework.integration.aggregator.CorrelationStrategy
-
Find the correlation key for the given message.
- getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
-
- getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.HeaderAttributeCorrelationStrategy
-
- getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
-
- getCount() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
-
- getCount() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
-
- getCount() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
-
- getCount() - Method in class org.springframework.integration.monitor.Statistics
-
- getCountAllMessagesInGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
-
- getCountAllMessagesInGroupQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
-
Get the query used to retrieve a count of all messages currently persisted
for a channel.
- getCreateMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
-
- getCreateMessageQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
-
Query to add a single message to the database.
- getDefaultPollerMetadata(BeanFactory) - Static method in class org.springframework.integration.scheduling.PollerMetadata
-
- getDelayedMessageCount() - Method in class org.springframework.integration.handler.DelayHandler
-
- getDelayedMessageCount() - Method in interface org.springframework.integration.handler.DelayHandlerManagement
-
- getDeleteMessageGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
-
- getDeleteMessageGroupQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
-
Query to delete all messages that belong to a specific channel.
- getDeleteMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
-
- getDeleteMessageQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
-
Query to delete a single message from the database.
- getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getDeserializer() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
- getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- getDeserializerStateKey() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
- getDeserializerStateKey() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- getDeserializerStateKey() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
-
- getDeserializerStateKey() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- getDestinationAddress() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- getDispatcher() - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
-
- getDispatcher() - Method in class org.springframework.integration.channel.DirectChannel
-
- getDispatcher() - Method in class org.springframework.integration.channel.ExecutorChannel
-
- getDispatcher() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
-
- getDocumentBuilder() - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
-
- getDuration() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- getDuration() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
-
- getDuration() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- getEntityName(EntityManager, Class<?>) - Static method in class org.springframework.integration.jpa.support.JpaUtils
-
- getErrorChannel(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
-
- getErrorChannel() - Method in class org.springframework.integration.MessageHeaders
-
- getErrorCount() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- getErrorCount() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
-
- getErrorCount() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- getErrorHandler() - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- getErrorRate() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getErrorRate() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
-
Return the instance of StandardEvaluationContext
bean whose name is "integrationEvaluationContext" .
- getEvaluationContext() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- getEvaluationContext(boolean) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
Emits a WARN log if the beanFactory field is null, unless the argument is false.
- getEvaluationResult() - Method in exception org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice.MessageHandlingExpressionEvaluatingAdviceException
-
- getExceptions() - Method in exception org.springframework.integration.xml.AggregatedXmlMessageValidationException
-
- getExchangeName() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
Subclasses may override this method to return an Exchange name.
- getExchangeName() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
-
- getExpirationDate() - Method in class org.springframework.integration.MessageHeaders
-
- getExpression(String, Locale) - Method in interface org.springframework.integration.expression.ExpressionSource
-
- getExpression(String, Locale) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Resolves the given key in the retrieved bundle files to an Expression.
- getExpression() - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
- getExpression() - Method in class org.springframework.integration.jpa.support.JpaParameter
-
- getExpressionFor(String) - Static method in class org.springframework.integration.context.IntegrationProperties
-
Build the bean property definition expression to resolve the value
from Integration properties within the bean building phase.
- getExpressionString() - Method in class org.springframework.integration.expression.DynamicExpression
-
- getFailedMessage() - Method in exception org.springframework.integration.MessagingException
-
- getFile() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingEvent
-
- getFile() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
- getFile(String) - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
-
- getFileInfo() - Method in interface org.springframework.integration.file.remote.FileInfo
-
- getFileInfo() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
-
- getFileInfo() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
-
- getFileMap() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
-
- getFilename(F) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
-
Subclasses must implement this method to extract the file's name.
- getFilename(F) - Method in class org.springframework.integration.file.filters.AbstractSimplePatternFileListFilter
-
Subclasses must implement this method to extract the file's name.
- getFilename(File) - Method in class org.springframework.integration.file.filters.RegexPatternFileListFilter
-
- getFilename(File) - Method in class org.springframework.integration.file.filters.SimplePatternFileListFilter
-
- getFilename() - Method in interface org.springframework.integration.file.remote.FileInfo
-
- getFilename(F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- getFilename(AbstractFileInfo<F>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- getFilename(F) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- getFilename(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpRegexPatternFileListFilter
-
- getFilename(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpSimplePatternFileListFilter
-
- getFilename(FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
-
- getFilename(AbstractFileInfo<FTPFile>) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
-
- getFilename(FTPFile) - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizer
-
- getFilename() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
-
- getFilename(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
-
- getFilename(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.filters.SftpSimplePatternFileListFilter
-
- getFilename(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
-
- getFilename(AbstractFileInfo<ChannelSftp.LsEntry>) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
-
- getFilename(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
-
- getFilename() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
-
- getFileNames() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
-
- getFiles(String) - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
-
- getFirstParameterType() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
-
- getFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- getForString(String) - Static method in enum org.springframework.integration.file.support.FileExistsMode
-
For a given non-null and not-empty input string, this method returns the
corresponding
FileExistsMode
.
- getFullChannelName() - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Returns the fully qualified channel name including the application context
id, if available.
- getFunctionName() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
-
- getGatewayClassName(Element) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
-
- getGatewayClassName() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
-
- getGatewayClassName() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
-
- getGatewayClassName(Element) - Method in class org.springframework.integration.rmi.config.RmiOutboundGatewayParser
-
- getGatewayClassName() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
-
- getGatewayClassName(Element) - Method in class org.springframework.integration.ws.config.WebServiceOutboundGatewayParser
-
- getGroupId() - Method in interface org.springframework.integration.store.MessageGroup
-
- getGroupId() - Method in class org.springframework.integration.store.MessageGroupMetadata
-
- getGroupId() - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- getHandleCount() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- getHandleCount() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
-
- getHandleCount() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- getHandlerClassName() - Method in class org.springframework.integration.xmpp.config.AbstractXmppOutboundChannelAdapterParser
-
- getHandlerClassName() - Method in class org.springframework.integration.xmpp.config.ChatMessageOutboundChannelAdapterParser
-
- getHandlerClassName() - Method in class org.springframework.integration.xmpp.config.PresenceOutboundChannelAdapterParser
-
- getHandlerCount() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
-
- getHandlerCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- getHandlerDuration(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- getHandlerExecutionChain(Object, HttpServletRequest) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
-
- getHandlerIterator(Message<?>, Collection<MessageHandler>) - Method in interface org.springframework.integration.dispatcher.LoadBalancingStrategy
-
- getHandlerIterator(Message<?>, Collection<MessageHandler>) - Method in class org.springframework.integration.dispatcher.RoundRobinLoadBalancingStrategy
-
Returns an iterator that starts at a new point in the collection every time the
first part of the list that is skipped will be used at the end of the
iteration, so it guarantees all handlers are returned once on subsequent
next()
invocations.
- getHandlerNames() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- getHandlers() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
-
Returns an unmodifiable Set
of this dispatcher's handlers.
- getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
-
- getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
-
- getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
-
- getHeaderExpressions() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- getHeaderIfAvailable(Map<String, Object>, String, Class<V>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
- getHeaders() - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- getHeaders() - Method in class org.springframework.integration.message.GenericMessage
-
- getHeaders() - Method in interface org.springframework.integration.Message
-
- getHeaders() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
-
- getHeaderTypes() - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
-
- getHost() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- getHost() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getHost() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getHostAddress() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
- getHostAddress() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- getHostAddress() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- getHostName() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
- getHostName() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- getHostName() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- getId() - Method in class org.springframework.integration.MessageHeaders
-
- getIdleConsumerLimit() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- getIdleCount() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getIdleCount() - Method in interface org.springframework.integration.util.Pool
-
Returns the number of items that have been allocated
but are not currently in use.
- getIdleCount() - Method in class org.springframework.integration.util.SimplePool
-
- getIdleTaskExecutionLimit() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- getInboundFileSynchronizerClassname() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
-
- getInboundFileSynchronizerClassname() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
-
- getInboundFileSynchronizerClassname() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
-
- getInputChannelAttributeName() - Method in class org.springframework.integration.amqp.config.AmqpOutboundGatewayParser
-
- getInputChannelAttributeName() - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
-
- getInputChannelAttributeName() - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
-
- getInputChannelAttributeName() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
-
- getInputChannelAttributeName() - Method in class org.springframework.integration.file.config.FileOutboundGatewayParser
-
- getInputChannelAttributeName() - Method in class org.springframework.integration.http.config.HttpOutboundGatewayParser
-
- getInputChannelAttributeName() - Method in class org.springframework.integration.ip.config.TcpOutboundGatewayParser
-
- getInputChannelAttributeName() - Method in class org.springframework.integration.jdbc.config.JdbcOutboundGatewayParser
-
- getInputChannelAttributeName() - Method in class org.springframework.integration.jdbc.config.StoredProcOutboundGatewayParser
-
- getInputChannelAttributeName() - Method in class org.springframework.integration.jms.config.JmsOutboundGatewayParser
-
- getInputChannelAttributeName() - Method in class org.springframework.integration.jmx.config.OperationInvokingOutboundGatewayParser
-
- getInputChannelAttributeName() - Method in class org.springframework.integration.jpa.config.xml.AbstractJpaOutboundGatewayParser
-
- getInputChannelName() - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
- getInputMessage() - Method in class org.springframework.integration.message.AdviceMessage
-
- getInputStream() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
-
- getIntegrationProperties(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
-
- getIntegrationProperties() - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- getIntegrationProperty(String, Class<T>) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- getInterceptor() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactory
-
Called for each new connection;
a new interceptor must be returned on each call.
- getInterceptorFactories() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactoryChain
-
- getInterceptors() - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Exposes the interceptor list for subclasses.
- getItem() - Method in interface org.springframework.integration.util.Pool
-
Obtains an item from the pool.
- getItem() - Method in class org.springframework.integration.util.SimplePool
-
Obtains an item from the pool; waits up to waitTime milliseconds (default infinity).
- getJdbcCallOperationsCacheStatistics() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- getJdbcCallOperationsCacheStatisticsAsMap() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- getJdbcOperations() - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
To be used to get a reference to JdbcOperations
in case this class is subclassed
- getJpaExecutorBuilder(Element, ParserContext) - Static method in class org.springframework.integration.jpa.config.xml.JpaParserUtils
-
Create a new
BeanDefinitionBuilder
for the class
JpaExecutor
.
- getJpaParameterBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jpa.config.xml.JpaParserUtils
-
Create a ManagedList
of BeanDefinition
s containing parsed
JPA Parameters.
- getLastMessage() - Method in class org.springframework.integration.test.support.AbstractResponseValidator
-
- getLastModified() - Method in interface org.springframework.integration.store.MessageGroup
-
- getLastModified() - Method in class org.springframework.integration.store.MessageGroupMetadata
-
- getLastModified() - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- getLastRead() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- getLastReleasedMessageSequenceNumber() - Method in interface org.springframework.integration.store.MessageGroup
-
Returns the sequenceNumber of the last released message.
- getLastReleasedMessageSequenceNumber() - Method in class org.springframework.integration.store.MessageGroupMetadata
-
- getLastReleasedMessageSequenceNumber() - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- getLastSend() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- getLevel() - Method in class org.springframework.integration.handler.LoggingHandler
-
- getListener() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getListener() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
- getListener() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- getListener() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- getLocalAddress() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- getLocalAddress() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
- getMapper() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getMapper() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getMapper() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- getMappingKeyAttributeName() - Method in class org.springframework.integration.config.xml.AbstractRouterParser
-
Returns the name of the attribute that provides a key for the
channel mappings.
- getMappingKeyAttributeName() - Method in class org.springframework.integration.config.xml.ErrorMessageExceptionTypeRouterParser
-
- getMappingKeyAttributeName() - Method in class org.springframework.integration.config.xml.PayloadTypeRouterParser
-
- getMax() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
-
- getMax() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
-
- getMax() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
-
- getMax() - Method in class org.springframework.integration.monitor.Statistics
-
- getMaxConcurrentConsumers() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- getMaxDuration() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- getMaxDuration() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
-
- getMaxDuration() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- getMaxMessageSize() - Method in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
-
The maximum supported message size for this serializer.
- getMaxMessagesPerPoll() - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- getMaxMessagesPerTask() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- getMaxSendDuration() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getMaxSendDuration() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getMean() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
-
- getMean() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
-
- getMean() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
-
- getMean() - Method in class org.springframework.integration.monitor.Statistics
-
- getMeanDuration() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- getMeanDuration() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
-
- getMeanDuration() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- getMeanErrorRate() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getMeanErrorRate() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getMeanErrorRatio() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getMeanErrorRatio() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getMeanSendDuration() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getMeanSendDuration() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getMeanSendRate() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getMeanSendRate() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getMessage() - Method in exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
-
- getMessage() - Method in class org.springframework.integration.event.core.MessagingEvent
-
- getMessage() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingEvent
-
- getMessage(UUID) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
- getMessage(UUID) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- getMessage(UUID) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- getMessage() - Method in class org.springframework.integration.security.channel.ChannelInvocation
-
- getMessage(UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- getMessage(UUID) - Method in interface org.springframework.integration.store.MessageStore
-
Return the Message with the given id, or null if no Message with that id exists in the MessageStore.
- getMessage(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- getMessage() - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
- getMessage() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
-
- getMessage() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
-
- getMessage() - Method in exception org.springframework.integration.xml.AggregatedXmlMessageValidationException
-
- getMessageChannel() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getMessageConverters() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
- getMessageCount() - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
- getMessageCount() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Method not implemented.
- getMessageCount() - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- getMessageCount() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- getMessageCount() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
-
- getMessageCount() - Method in interface org.springframework.integration.monitor.MessageSourceMetrics
-
- getMessageCount() - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
-
- getMessageCount() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- getMessageCount() - Method in interface org.springframework.integration.store.MessageStore
-
Optional attribute giving the number of messages in the store.
- getMessageCount() - Method in class org.springframework.integration.store.SimpleMessageStore
-
- getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
- getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Method not implemented.
- getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
- getMessageCountForAllMessageGroups() - Method in interface org.springframework.integration.store.MessageGroupStore
-
Optional attribute giving the number of messages in the store over all groups.
- getMessageCountForRegionQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
-
- getMessageCountForRegionQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
-
Query that retrieve a count of all messages for a region.
- getMessageGroup(Object) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
- getMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Not fully used.
- getMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- getMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- getMessageGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
Will create a new instance of SimpleMessageGroup if necessary.
- getMessageGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
-
- getMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- getMessageGroupCount() - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
- getMessageGroupCount() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Method not implemented.
- getMessageGroupCount() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
- getMessageGroupCount() - Method in interface org.springframework.integration.store.MessageGroupStore
-
Optional attribute giving the number of message groups.
- getMessageHandler() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- getMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
-
- getMessageQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
-
Query that retrieves a message for the provided message id, channel and
region.
- getMessages() - Method in interface org.springframework.integration.store.MessageGroup
-
Returns all available Messages from the group at the time of invocation
- getMessages() - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- getMessages() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
-
- getMessageSource() - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
-
- getMessageSourceClassname() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
-
- getMessageSourceClassname() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
-
- getMessageSourceClassname() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
-
- getMessageStore() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- getMessagingTemplate() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
- getMessagingTemplate() - Method in class org.springframework.integration.router.AbstractMessageRouter
-
- getMetadataStore(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
-
- getMethod() - Method in class org.springframework.integration.gateway.MethodArgsHolder
-
- getMethodInvocation() - Method in class org.springframework.integration.security.channel.ChannelInvocation
-
- getMethods() - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- getMin() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
-
- getMin() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
-
- getMin() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
-
- getMin() - Method in class org.springframework.integration.monitor.Statistics
-
- getMinDuration() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- getMinDuration() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
-
- getMinDuration() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- getMinSendDuration() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getMinSendDuration() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getMissingFileDelay() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
- getModified() - Method in interface org.springframework.integration.file.remote.FileInfo
-
- getModified(F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- getModified(F) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- getModified(FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
-
- getModified(FTPFile) - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizer
-
- getModified() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
-
- getModified(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
-
- getModified(ChannelSftp.LsEntry) - Method in class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
-
- getModified() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
-
- getMultiFileMap() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
-
- getMultipartContentType(String) - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
-
Once we depend upon Spring 3.1 as a minimum, this code can be changed to:
this.multipartServletRequest.getMultipartContentType(String paramOrFileName)
- getName() - Method in class org.springframework.integration.history.MessageHistory.Entry
-
- getName() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
-
- getName() - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
- getName() - Method in class org.springframework.integration.jpa.support.JpaParameter
-
- getName() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getName() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- getName() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
-
- getName() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
-
- getName() - Method in interface org.springframework.integration.monitor.MessageSourceMetrics
-
- getName() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- getName() - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
-
- getName() - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
- getNewChannels() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
- getNewDocumentBuilder() - Method in class org.springframework.integration.xml.result.DomResultFactory
-
- getNoJacksonLibException() - Static method in class org.springframework.integration.support.json.JacksonJsonUtils
-
- getObject() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- getObject() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- getObject() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
-
- getObject() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
-
- getObject() - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
-
- getObject() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- getObject() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
-
- getObject() - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
-
- getObject() - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- getObject() - Method in class org.springframework.integration.file.remote.session.SessionFactoryFactoryBean
-
Deprecated.
- getObject() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- getObject() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.config.ExpressionFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.config.ReleaseStrategyFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.file.remote.session.SessionFactoryFactoryBean
-
Deprecated.
- getObjectType() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- getOffendingJPAQl() - Method in exception org.springframework.integration.jpa.core.JpaOperationFailedException
-
- getOne() - Method in interface org.springframework.integration.store.MessageGroup
-
- getOne() - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- getOpenConnectionIds() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Returns a list of (currently) open
TcpConnection
connection ids; allows,
for example, broadcast operations to all open connections.
- getOption() - Method in enum org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
-
- getOrder() - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
-
- getOrder() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
-
- getOrder() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- getOrder() - Method in class org.springframework.integration.handler.AbstractMessageHandler
-
- getOriginal() - Method in class org.springframework.integration.handler.DelayHandler.DelayedMessageWrapper
-
- getOriginalFilename() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
-
- getOutboundGatewayJpaExecutorBuilder(Element, ParserContext) - Static method in class org.springframework.integration.jpa.config.xml.JpaParserUtils
-
Create a new
BeanDefinitionBuilder
for the class
JpaExecutor
that is specific for JPA Outbound Gateways.
- getOutputChannelName() - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
- getParameterMap() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
-
- getParams() - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- getPathPatterns() - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- getPatterns() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
-
- getPatterns() - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
-
- getPayload() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
Uses the deserializer to obtain the message payload
from the connection's input stream.
- getPayload() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- getPayload() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
-
- getPayload() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- getPayload() - Method in class org.springframework.integration.message.GenericMessage
-
- getPayload() - Method in interface org.springframework.integration.Message
-
- getPayload() - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
- getPayload() - Method in class org.springframework.integration.util.MessagingMethodInvokerHelper.ParametersWrapper
-
- getPayloadExpression(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
-
- getPayloadExpression(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
-
- getPayloadExpression(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
-
- getPayloadExpression() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- getPayloadType() - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
-
- getPermissions() - Method in interface org.springframework.integration.file.remote.FileInfo
-
- getPermissions() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
-
- getPermissions() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
-
- getPhase() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- getPhase() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- getPhase() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- getPhase() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- getPhase() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
- getPhase() - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- getPhase() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
- getPhase() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- getPhase() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getPhase() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getPhase() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- getPhase() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- getPhase() - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- getPhase() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
- getPhase() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- getPhase() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- getPhase() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
- getPhase() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- getPhase() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- getPointcut() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
-
- getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
-
- getPollFromGroupExcludeIdsQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
-
Get the query used to retrieve the oldest message for a channel excluding
messages that match the provided message ids.
- getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.DerbyChannelMessageStoreQueryProvider
-
- getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.HsqlChannelMessageStoreQueryProvider
-
- getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.MySqlChannelMessageStoreQueryProvider
-
- getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
-
- getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.PostgresChannelMessageStoreQueryProvider
-
- getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.AbstractChannelMessageStoreQueryProvider
-
- getPollFromGroupQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
-
Get the query used to retrieve the oldest message for a channel.
- getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.DerbyChannelMessageStoreQueryProvider
-
- getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.HsqlChannelMessageStoreQueryProvider
-
- getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.MySqlChannelMessageStoreQueryProvider
-
- getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
-
- getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.PostgresChannelMessageStoreQueryProvider
-
- getPoolSize() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getPoolSize() - Method in interface org.springframework.integration.util.Pool
-
Returns the current size (limit) of the pool.
- getPoolSize() - Method in class org.springframework.integration.util.SimplePool
-
Returns the current size of the pool; may be greater than the target pool size
if it was recently reduced and too many items were in use to allow the new size
to be set.
- getPort() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- getPort() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- getPort() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getPort() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getPort() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
- getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
-
- getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- getPort() - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
-
- getPriority() - Method in class org.springframework.integration.jms.DynamicJmsTemplate
-
- getPriority() - Method in class org.springframework.integration.MessageHeaders
-
- getProcedureParameterBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
-
- getProduces() - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- getProjectionExpression() - Method in class org.springframework.integration.jpa.support.JpaParameter
-
- getPropertyAccessors() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
-
- getPropertyValue(Object, String) - Static method in class org.springframework.integration.test.util.TestUtils
-
- getPropertyValue(Object, String, Class<T>) - Static method in class org.springframework.integration.test.util.TestUtils
-
- getQuery(JdbcMessageStore.Query) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
Replace patterns in the input to produce a valid SQL query.
- getQuery(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Replace patterns in the input to produce a valid SQL query.
- getQueryString(String, String) - Static method in class org.springframework.integration.jpa.support.JpaUtils
-
Returns the query string for the given class name.
- getQueuedMessageCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- getQueueSize() - Method in class org.springframework.integration.channel.QueueChannel
-
- getQueueSize() - Method in interface org.springframework.integration.channel.QueueChannelOperations
-
Return the current number of queued
Messages
in this channel.
- getQueueSize() - Method in class org.springframework.integration.monitor.QueueChannelMetrics
-
- getQueueSize() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- getRandomSeedPort() - Static method in class org.springframework.integration.test.util.SocketUtils
-
Determines a random seed port number within the port range
10000 and
60000.
- getReadablePropertyNames() - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSource
-
Provide access to the property names of the wrapped bean.
- getReaperDelay() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- getReceiveBufferSize() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- getReceiveCount() - Method in class org.springframework.integration.monitor.PollableChannelMetrics
-
- getReceiveErrorCount() - Method in class org.springframework.integration.monitor.PollableChannelMetrics
-
- getReceiveTimeout() - Method in class org.springframework.integration.jms.DynamicJmsTemplate
-
- getReceiveTimeout() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- getReceiveTimeout() - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- getRecoveryInterval() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- getRegexPatternFileListFilterClassname() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
-
- getRegexPatternFileListFilterClassName() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
-
- getRegexPatternFileListFilterClassname() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
-
- getRegexPatternFileListFilterClassName() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
-
- getRegexPatternFileListFilterClassname() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
-
- getRegexPatternFileListFilterClassName() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
-
- getRemainingCapacity() - Method in class org.springframework.integration.channel.QueueChannel
-
- getRemainingCapacity() - Method in interface org.springframework.integration.channel.QueueChannelOperations
-
Return the remaining capacity of this channel.
- getRemainingCapacity() - Method in class org.springframework.integration.monitor.QueueChannelMetrics
-
- getRemoteDirectory() - Method in class org.springframework.integration.file.remote.AbstractFileInfo
-
- getRemoteDirectory() - Method in interface org.springframework.integration.file.remote.FileInfo
-
- getRemoteFilename(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- getRemoteFileSeparator() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- getReplyChannel() - Method in class org.springframework.integration.MessageHeaders
-
- getReplyChannelName() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- getReplyTimeout() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- getRequestChannelName() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- getRequestDate() - Method in class org.springframework.integration.handler.DelayHandler.DelayedMessageWrapper
-
- getRequestMapping() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
- getRequestMethods() - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- getRequestTimeout() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- getRequiredConversionService() - Method in class org.springframework.integration.router.AbstractMessageRouter
-
- getRequiredTaskScheduler(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
-
Return the TaskScheduler
bean whose name is "taskScheduler".
- getResource() - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
- getResourceKey() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- getResourceKey() - Method in class org.springframework.integration.endpoint.PollingConsumer
-
- getResourceKey() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- getResourceToBind() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
Return a resource (MessageSource etc) to bind when using transaction
synchronization.
- getResourceToBind() - Method in class org.springframework.integration.endpoint.PollingConsumer
-
- getResourceToBind() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- getResponseValidator() - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
- getResultListForClass(Class<?>, int, int) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- getResultListForClass(Class<?>, int, int) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
- getResultListForNamedQuery(String, ParameterSource, int, int) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- getResultListForNamedQuery(String, ParameterSource, int, int) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
- getResultListForNativeQuery(String, Class<?>, ParameterSource, int, int) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- getResultListForNativeQuery(String, Class<?>, ParameterSource, int, int) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
- getResultListForQuery(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- getResultListForQuery(String, ParameterSource, int, int) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- getResultListForQuery(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
Executes the provided query to return a list of results
- getResultListForQuery(String, ParameterSource, int, int) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
Executes the provided query to return a list of results.
- getRetryInterval() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- getRetryInterval() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- getRetryInterval() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- getReturningResultsetBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
-
- getRoutingKey() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
-
Subclasses may override this method to return a routing key.
- getRoutingKey() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
-
- getRoutingKey() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- getScriptAsString() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
-
- getScriptExecutor(String) - Static method in class org.springframework.integration.scripting.jsr223.ScriptExecutorFactory
-
- getScriptSource(Message<?>) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
-
- getScriptSource(Message<?>) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
- getScriptSource(Message<?>) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
-
Subclasses must implement this method to create a script source,
optionally using the message to locate or create the script.
- getScriptSource(Message<?>) - Method in class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
-
- getScriptSourceClassName() - Method in class org.springframework.integration.groovy.config.GroovyScriptParser
-
- getScriptSourceClassName() - Method in class org.springframework.integration.scripting.config.AbstractScriptParser
-
- getScriptSourceClassName() - Method in class org.springframework.integration.scripting.config.jsr223.ScriptParser
-
- getSecureObjectClass() - Method in class org.springframework.integration.security.channel.ChannelSecurityInterceptor
-
- getSendCount() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getSendCount() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getSendDuration() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getSendDuration() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getSender() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getSender() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getSender() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- getSender() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- getSendErrorCount() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getSendErrorCount() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getSendRate() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getSendRate() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getSendTimeout() - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- getSequenceNumber() - Method in class org.springframework.integration.MessageHeaders
-
- getSequenceSize() - Method in class org.springframework.integration.MessageHeaders
-
- getSequenceSize() - Method in interface org.springframework.integration.store.MessageGroup
-
- getSequenceSize() - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getSerializer() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
- getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- getServerChannel() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
- getServerConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- getServerConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- getServerSocket() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
- getServerSocketFactory() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSocketFactorySupport
-
- getServerSocketFactory() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSSLSocketFactorySupport
-
- getServerSocketFactory() - Method in interface org.springframework.integration.ip.tcp.connection.TcpSocketFactorySupport
-
Supplies the ServerSocketFactory
to be used to
create new ServerSocket
s.
- getSession() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
-
Get a session from the pool (or block if none available).
- getSession() - Method in interface org.springframework.integration.file.remote.session.SessionFactory
-
- getSession() - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- getSession() - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
- getSessionAcknowledgeMode() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- getSimplePatternFileListFilterClassname() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
-
- getSimplePatternFileListFilterClassName() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
-
- getSimplePatternFileListFilterClassname() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
-
- getSimplePatternFileListFilterClassName() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
-
- getSimplePatternFileListFilterClassname() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
-
- getSimplePatternFileListFilterClassName() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
-
- getSingleResultForQuery(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
-
- getSingleResultForQuery(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
-
Executes the provided query to return a single element
- getSize() - Method in interface org.springframework.integration.file.remote.FileInfo
-
- getSize() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
-
- getSize() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
-
- getSize() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
-
- getSizeOfIdCache() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Returns the size of the Message Id Cache, which caches Message Ids for
those messages that are currently being processed.
- getSocket() - Method in class org.springframework.integration.ip.udp.MulticastReceivingChannelAdapter
-
- getSocket() - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
- getSocket() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- getSocket() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- getSocketFactory() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSocketFactorySupport
-
- getSocketFactory() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSSLSocketFactorySupport
-
- getSocketFactory() - Method in interface org.springframework.integration.ip.tcp.connection.TcpSocketFactorySupport
-
Supplies the SocketFactory
to be used to
create new Socket
s.
- getSoLinger() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getSoLinger() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getSoReceiveBufferSize() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- getSoReceiveBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getSoReceiveBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getSoReceiveBufferSize() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- getSoSendBufferSize() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- getSoSendBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getSoSendBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getSoTimeout() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- getSoTimeout() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- getSoTimeout() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getSoTimeout() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getSoTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getSoTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- getSource() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- getSource() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
-
- getSource() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
-
- getSource() - Method in interface org.springframework.integration.monitor.MessageSourceMetrics
-
- getSource() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- getSource() - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
-
- getSourceMessageCount(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- getSpecificTargetClasses() - Method in class org.springframework.integration.json.JsonPropertyAccessor
-
- getSpelExpression() - Method in class org.springframework.integration.jpa.support.JpaParameter
-
- getSqlParameterDefinitionBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
-
- getSSLChannelOutputStream() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
-
- getSSLContext() - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpSSLContextSupport
-
- getSSLContext() - Method in interface org.springframework.integration.ip.tcp.connection.TcpSSLContextSupport
-
Gets an SSLContext.
- getStandardDeviation() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
-
- getStandardDeviation() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
-
- getStandardDeviation() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
-
- getStandardDeviation() - Method in class org.springframework.integration.monitor.Statistics
-
- getStandardDeviationDuration() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- getStandardDeviationDuration() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
-
- getStandardDeviationDuration() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- getStandardDeviationSendDuration() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getStandardDeviationSendDuration() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getStandardHeaderPrefix() - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
- getStandardHeaderPrefix() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
Returns the list of standard REPLY headers.
- getStandardHeaderPrefix() - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
-
- getStandardHeaderPrefix() - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
-
- getStandardReplyHeaderNames() - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
- getStandardReplyHeaderNames() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
Returns the list of standard REQUEST headers.
- getStandardReplyHeaderNames() - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
-
- getStandardRequestHeaderNames() - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
-
- getStandardRequestHeaderNames() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
Returns the PREFIX used by standard headers (if any)
- getStandardRequestHeaderNames() - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
-
- getStandardRequestHeaderNames() - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
-
- getStatistics() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
-
- getStatistics() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
-
- getStatistics() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
-
- getStoredProcedureName() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- getStoredProcedureNameExpressionAsString() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- getStoredProcExecutorBuilder(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
-
- getSupportedMediaTypes() - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
-
- getTaskExecutor() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
- getTaskExecutor() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- getTaskExecutor() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Creates a taskExecutor (if one was not provided).
- getTaskExecutor() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- getTaskExecutor() - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- getTaskScheduler(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
-
Return the TaskScheduler
bean whose name is "taskScheduler" if available.
- getTaskScheduler() - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- getTcpSocketFactorySupport() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
-
- getTcpSocketFactorySupport() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
- getTcpSocketSupport() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- getTemporaryFileSuffix() - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
- getTemporaryFileSuffix() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
- getTemporaryFileSuffix() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- getTemporaryFileSuffix() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- getTextFromAttributeOrNestedElement(Element, String, ParserContext) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Get a text value from a named attribute if it exists, otherwise check for a nested element of the same name.
- getTheConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
- getTheConnection() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
Returns the underlying connection (or next interceptor)
- getTheSocket() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- getTheSocket() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- getTimeSinceLastMeasurement() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
-
- getTimeSinceLastMeasurement() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
-
- getTimeSinceLastSend() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- getTimeSinceLastSend() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- getTimestamp() - Method in class org.springframework.integration.history.MessageHistory.Entry
-
- getTimestamp() - Method in class org.springframework.integration.MessageHeaders
-
- getTimestamp() - Method in interface org.springframework.integration.store.MessageGroup
-
- getTimestamp() - Method in class org.springframework.integration.store.MessageGroupMetadata
-
- getTimestamp() - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- getTransactionSynchronizationFactory() - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.AbstractTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.ClaimCheckInParser
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.ClaimCheckOutParser
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.HeaderFilterParser
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.JsonToObjectTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.MapToObjectTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.ObjectToMapTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.ObjectToStringTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.PayloadDeserializingTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.PayloadSerializingTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.config.xml.SyslogToMapTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.file.config.FileToByteArrayTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.file.config.FileToStringTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.mail.config.MailToStringTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.xml.config.MarshallingTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.xml.config.UnmarshallingTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.xml.config.XPathHeaderEnricherParser
-
- getTransformerClassName() - Method in class org.springframework.integration.xml.config.XPathTransformerParser
-
- getTransformerClassName() - Method in class org.springframework.integration.xml.config.XsltPayloadTransformerParser
-
- getTransformOnSend() - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
-
Deprecated.
- getTrigger() - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- getType() - Method in class org.springframework.integration.history.MessageHistory.Entry
-
- getUUID(Object) - Static method in class org.springframework.integration.util.UUIDConverter
-
Convenient utility to convert an object to a UUID.
- getValue() - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValue(Object) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValue(Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValue(Object, Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValue(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValue(EvaluationContext, Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValue(EvaluationContext, Object, Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValue() - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
- getValue() - Method in class org.springframework.integration.jpa.support.JpaParameter
-
- getValue(String) - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSource
-
- getValue(String) - Method in interface org.springframework.integration.jpa.support.parametersource.ParameterSource
-
Return the parameter value for the requested named parameter.
- getValueByPosition(int) - Method in interface org.springframework.integration.jpa.support.parametersource.PositionSupportingParameterSource
-
- getValueType() - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValueType(Object) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValueType(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValueType(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValueTypeDescriptor() - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValueTypeDescriptor(Object) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
-
- getWebServiceTemplate() - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- getXPathExpresion() - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
-
- GlobalChannelInterceptorParser - Class in org.springframework.integration.config.xml
-
Parser for 'channel-interceptor' elements.
- GlobalChannelInterceptorParser() - Constructor for class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
-
- GlobalChannelInterceptorWrapper - Class in org.springframework.integration.channel.interceptor
-
- GlobalChannelInterceptorWrapper(ChannelInterceptor) - Constructor for class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
-
- GlobalWireTapParser - Class in org.springframework.integration.config.xml
-
Parser for the top level 'wire-tap' element
- GlobalWireTapParser() - Constructor for class org.springframework.integration.config.xml.GlobalWireTapParser
-
- GroovyCommandMessageProcessor - Class in org.springframework.integration.groovy
-
- GroovyCommandMessageProcessor() - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
-
- GroovyCommandMessageProcessor(ScriptVariableGenerator) - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
-
- GroovyCommandMessageProcessor(Binding) - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
-
- GroovyCommandMessageProcessor(Binding, ScriptVariableGenerator) - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
-
- GroovyControlBusFactoryBean - Class in org.springframework.integration.groovy.config
-
FactoryBean for creating
MessageHandler
instances to handle a message as a Groovy Script.
- GroovyControlBusFactoryBean() - Constructor for class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
-
- GroovyControlBusParser - Class in org.springframework.integration.groovy.config
-
Parser for the <groovy:control-bus/> element.
- GroovyControlBusParser() - Constructor for class org.springframework.integration.groovy.config.GroovyControlBusParser
-
- GroovyNamespaceHandler - Class in org.springframework.integration.groovy.config
-
- GroovyNamespaceHandler() - Constructor for class org.springframework.integration.groovy.config.GroovyNamespaceHandler
-
- GroovyScriptExecutingMessageProcessor - Class in org.springframework.integration.groovy
-
- GroovyScriptExecutingMessageProcessor(ScriptSource) - Constructor for class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
Create a processor for the given ScriptSource
that will use a
DefaultScriptVariableGenerator.
- GroovyScriptExecutingMessageProcessor(ScriptSource, ScriptVariableGenerator) - Constructor for class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
Create a processor for the given ScriptSource
that will use the provided
ScriptVariableGenerator.
- GroovyScriptParser - Class in org.springframework.integration.groovy.config
-
Parser for the <groovy:script/> element.
- GroovyScriptParser() - Constructor for class org.springframework.integration.groovy.config.GroovyScriptParser
-
- OBJECT_NAME - Static variable in class org.springframework.integration.jmx.JmxHeaders
-
- ObjectToJsonTransformer - Class in org.springframework.integration.json
-
Transformer implementation that converts a payload instance into a JSON string representation.
- ObjectToJsonTransformer(Object) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
-
- ObjectToJsonTransformer(JsonObjectMapper<?>) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
-
- ObjectToJsonTransformer() - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
-
- ObjectToJsonTransformerParser - Class in org.springframework.integration.config.xml
-
- ObjectToJsonTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
-
- ObjectToMapTransformer - Class in org.springframework.integration.transformer
-
Will transform an object graph into a Map.
- ObjectToMapTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToMapTransformer
-
- ObjectToMapTransformerParser - Class in org.springframework.integration.config.xml
-
- ObjectToMapTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToMapTransformerParser
-
- ObjectToStringTransformer - Class in org.springframework.integration.transformer
-
A simple transformer that creates an outbound payload by invoking the
inbound payload Object's toString()
method.
- ObjectToStringTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToStringTransformer
-
- ObjectToStringTransformer(String) - Constructor for class org.springframework.integration.transformer.ObjectToStringTransformer
-
- ObjectToStringTransformerParser - Class in org.springframework.integration.config.xml
-
Parser for the 'object-to-string-transformer' element.
- ObjectToStringTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToStringTransformerParser
-
- obtain(Object) - Method in class org.springframework.integration.util.DefaultLockRegistry
-
Obtains a lock by masking the lockKey's hashCode() with
the mask and using the result as an index to the lock table.
- obtain(Object) - Method in interface org.springframework.integration.util.LockRegistry
-
Obtains the lock associated with the parameter object.
- obtain(Object) - Method in class org.springframework.integration.util.PassThruLockRegistry
-
- obtainConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
- obtainConnection() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- obtainConnection() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
- obtainConnection(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- obtainNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
- obtainSecurityMetadataSource() - Method in class org.springframework.integration.security.channel.ChannelSecurityInterceptor
-
- obtainSharedConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
- offer(Message<?>) - Method in class org.springframework.integration.store.MessageGroupQueue
-
- offer(Message<?>, long, TimeUnit) - Method in class org.springframework.integration.store.MessageGroupQueue
-
- onApplicationEvent(ApplicationEvent) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
-
- onApplicationEvent(ApplicationContextEvent) - Method in class org.springframework.integration.config.IdGeneratorConfigurer
-
- onApplicationEvent(ApplicationEvent) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.handler.DelayHandler
-
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
-
- onApplicationEvent(TcpConnectionEvent) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionEventListeningMessageProducer
-
- ONE_MINUTE_SECONDS - Static variable in class org.springframework.integration.monitor.DirectChannelMetrics
-
- ONE_SECOND_SECONDS - Static variable in class org.springframework.integration.monitor.DirectChannelMetrics
-
- onError(RetryContext, RetryCallback<T>, Throwable) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- onEvent(CqEvent) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
-
- onFailure(Message<File>) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
Adds the failed message back to the 'toBeReceived' queue if there is room.
- onInit() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- onInit() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- onInit() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- onInit() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
- onInit() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- onInit() - Method in class org.springframework.integration.channel.DirectChannel
-
- onInit() - Method in class org.springframework.integration.channel.ExecutorChannel
-
- onInit() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
-
Callback method for initialization.
- onInit() - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
Subclasses may implement this for initialization logic.
- onInit() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- onInit() - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
-
- onInit() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- onInit() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- onInit() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- onInit() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
-
- onInit() - Method in class org.springframework.integration.file.FileReadingMessageSource
-
- onInit() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
- onInit() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- onInit() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
-
- onInit() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- onInit() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- onInit() - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
-
- onInit() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
- onInit() - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- onInit() - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
-
- onInit() - Method in class org.springframework.integration.handler.LoggingHandler
-
- onInit() - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- onInit() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
- onInit() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Locates the MultipartResolver
bean based on the default name defined by the
DispatcherServlet.MULTIPART_RESOLVER_BEAN_NAME
constant if available.
- onInit() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
- onInit() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- onInit() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- onInit() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- onInit() - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
- onInit() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
-
- onInit() - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
- onInit() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
- onInit() - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
-
- onInit() - Method in class org.springframework.integration.jpa.inbound.JpaPollingChannelAdapter
-
Check for mandatory attributes
- onInit() - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- onInit() - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
- onInit() - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
-
- onInit() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- onInit() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- onInit() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- onInit() - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
- onInit() - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- onInit() - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
- onInit() - Method in class org.springframework.integration.rmi.RmiInboundGateway
-
- onInit() - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
- onInit() - Method in class org.springframework.integration.router.RecipientListRouter
-
- onInit() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
-
- onInit() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
-
- onInit() - Method in class org.springframework.integration.transformer.MapToObjectTransformer
-
- onInit() - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
-
- onInit() - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
- onInit() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
-
- onInit() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
-
- onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- onMessage(Message<?>) - Method in interface org.springframework.integration.ip.tcp.connection.TcpListener
-
Called by a TCPConnection when a new message arrives.
- onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- onMessage(Message, Session) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- onMessage(Message) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- onMessage(Message<?>) - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
-
- onSend(Message<File>) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
The message is just logged.
- open(RetryContext, RetryCallback<T>) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- openFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- OPERATION_NAME - Static variable in class org.springframework.integration.jmx.JmxHeaders
-
- OperationInvokingChannelAdapterParser - Class in org.springframework.integration.jmx.config
-
- OperationInvokingChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.OperationInvokingChannelAdapterParser
-
- OperationInvokingMessageHandler - Class in org.springframework.integration.jmx
-
- OperationInvokingMessageHandler() - Constructor for class org.springframework.integration.jmx.OperationInvokingMessageHandler
-
- OperationInvokingOutboundGatewayParser - Class in org.springframework.integration.jmx.config
-
- OperationInvokingOutboundGatewayParser() - Constructor for class org.springframework.integration.jmx.config.OperationInvokingOutboundGatewayParser
-
- options - Variable in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- OracleChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
-
- OracleChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
-
- ORDER - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- Orderable - Interface in org.springframework.integration.context
-
Interface that extends
Ordered
while also exposing the
Orderable.setOrder(int)
as an interface-level so that it is avaiable
on AOP proxies, etc.
- OrderlyShutdownCapable - Interface in org.springframework.integration.context
-
Interface for components that wish to be considered for
an orderly shutdown using management interfaces.
- orderlyShutdownCapableComponentsAfter() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- orderlyShutdownCapableComponentsBefore() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- org.springframework.integration - package org.springframework.integration
-
Base package for Spring Integration Core.
- org.springframework.integration.aggregator - package org.springframework.integration.aggregator
-
Provides classes related to message aggregation.
- org.springframework.integration.amqp - package org.springframework.integration.amqp
-
Base package for AMQP support.
- org.springframework.integration.amqp.channel - package org.springframework.integration.amqp.channel
-
Provides classes related to AMQP-backed channels.
- org.springframework.integration.amqp.config - package org.springframework.integration.amqp.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.amqp.inbound - package org.springframework.integration.amqp.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.amqp.outbound - package org.springframework.integration.amqp.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.integration.amqp.support - package org.springframework.integration.amqp.support
-
Provides AMQP support classes.
- org.springframework.integration.annotation - package org.springframework.integration.annotation
-
Provides annotations for annotation-based configuration.
- org.springframework.integration.aop - package org.springframework.integration.aop
-
Provides classes to support message publication using AOP.
- org.springframework.integration.channel - package org.springframework.integration.channel
-
Provides classes representing various channel types.
- org.springframework.integration.channel.interceptor - package org.springframework.integration.channel.interceptor
-
Provides classes related to channel interception.
- org.springframework.integration.config - package org.springframework.integration.config
-
Base package for configuration.
- org.springframework.integration.config.annotation - package org.springframework.integration.config.annotation
-
Provides classes supporting annotation-based configuration.
- org.springframework.integration.config.xml - package org.springframework.integration.config.xml
-
Provides supporting XML-based configuration - parsers, namespace handlers.
- org.springframework.integration.context - package org.springframework.integration.context
-
Provides classes relating to application context configuration.
- org.springframework.integration.core - package org.springframework.integration.core
-
Provides core classes.
- org.springframework.integration.dispatcher - package org.springframework.integration.dispatcher
-
Provides classes related to dispatching messages.
- org.springframework.integration.endpoint - package org.springframework.integration.endpoint
-
Provides core classes related to Endpoints.
- org.springframework.integration.event - package org.springframework.integration.event
-
ApplicationEvents generated by the Spring Integration framework.
- org.springframework.integration.event.config - package org.springframework.integration.event.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.event.core - package org.springframework.integration.event.core
-
Provides Event core classes.
- org.springframework.integration.event.inbound - package org.springframework.integration.event.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.event.outbound - package org.springframework.integration.event.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.integration.expression - package org.springframework.integration.expression
-
Provides classes supporting SpEL expressions.
- org.springframework.integration.feed.config - package org.springframework.integration.feed.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.feed.inbound - package org.springframework.integration.feed.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.file - package org.springframework.integration.file
-
Base package for File support.
- org.springframework.integration.file.config - package org.springframework.integration.file.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.file.event - package org.springframework.integration.file.event
-
ApplicationEvents generated by the file module.
- org.springframework.integration.file.filters - package org.springframework.integration.file.filters
-
Provides classes supporting file filtering.
- org.springframework.integration.file.locking - package org.springframework.integration.file.locking
-
Provides classes supporting file locking.
- org.springframework.integration.file.remote - package org.springframework.integration.file.remote
-
Base package for supporting remote files.
- org.springframework.integration.file.remote.gateway - package org.springframework.integration.file.remote.gateway
-
Provides classes supporting remote file gateways.
- org.springframework.integration.file.remote.handler - package org.springframework.integration.file.remote.handler
-
Provides classes supporting remote file message handlers.
- org.springframework.integration.file.remote.session - package org.springframework.integration.file.remote.session
-
Provides classes supporting remote file sessions.
- org.springframework.integration.file.remote.synchronizer - package org.springframework.integration.file.remote.synchronizer
-
Provides classes supporting the synchronization of remote and
local file directories.
- org.springframework.integration.file.support - package org.springframework.integration.file.support
-
Provides various support classes used across Spring Integration File Components.
- org.springframework.integration.file.tail - package org.springframework.integration.file.tail
-
Classes used for tailing file system files.
- org.springframework.integration.file.test - package org.springframework.integration.file.test
-
Provides classes used to support common test cases in modules
that are dependent on the file module.
- org.springframework.integration.file.transformer - package org.springframework.integration.file.transformer
-
Provides classes supporting the transformation of file contents
to messages.
- org.springframework.integration.filter - package org.springframework.integration.filter
-
Provides classes supporting the filter pattern.
- org.springframework.integration.ftp.config - package org.springframework.integration.ftp.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.ftp.filters - package org.springframework.integration.ftp.filters
-
Provides classes supporting FTP file filtering.
- org.springframework.integration.ftp.gateway - package org.springframework.integration.ftp.gateway
-
Provides classes supporting FTP gateways.
- org.springframework.integration.ftp.inbound - package org.springframework.integration.ftp.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.ftp.session - package org.springframework.integration.ftp.session
-
Provides classes supporting FTP sessions.
- org.springframework.integration.gateway - package org.springframework.integration.gateway
-
Provides classes supporting messaging gateways.
- org.springframework.integration.gemfire.config.xml - package org.springframework.integration.gemfire.config.xml
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.gemfire.inbound - package org.springframework.integration.gemfire.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.gemfire.outbound - package org.springframework.integration.gemfire.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.integration.gemfire.store - package org.springframework.integration.gemfire.store
-
Provides classes releated to storing messages.
- org.springframework.integration.groovy - package org.springframework.integration.groovy
-
Base package for Groovy support.
- org.springframework.integration.groovy.config - package org.springframework.integration.groovy.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.handler - package org.springframework.integration.handler
-
Provides classes implementing various types of message handler.
- org.springframework.integration.handler.advice - package org.springframework.integration.handler.advice
-
Provides classes that are used to advise
MessageHandler
s with
cross-cutting concerns.
- org.springframework.integration.history - package org.springframework.integration.history
-
Provides classes supporting the capture of message history.
- org.springframework.integration.http - package org.springframework.integration.http
-
Base package for Http support.
- org.springframework.integration.http.config - package org.springframework.integration.http.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.http.converter - package org.springframework.integration.http.converter
-
Provides classes supporting message conversion.
- org.springframework.integration.http.inbound - package org.springframework.integration.http.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.http.multipart - package org.springframework.integration.http.multipart
-
Provides classes supporting multipart HTTP requests.
- org.springframework.integration.http.outbound - package org.springframework.integration.http.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.integration.http.support - package org.springframework.integration.http.support
-
Provides classes to support Http endpoints, including header
mapping.
- org.springframework.integration.ip - package org.springframework.integration.ip
-
Base package for IP (TCP/UDP) Support.
- org.springframework.integration.ip.config - package org.springframework.integration.ip.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.ip.event - package org.springframework.integration.ip.event
-
ApplicationEvents generated by the ip module.
- org.springframework.integration.ip.tcp - package org.springframework.integration.ip.tcp
-
Base package for TCP Support.
- org.springframework.integration.ip.tcp.connection - package org.springframework.integration.ip.tcp.connection
-
All things related to tcp connections - client and
server factories; listener and sender interfaces.
- org.springframework.integration.ip.tcp.serializer - package org.springframework.integration.ip.tcp.serializer
-
Byte array (de)serializers for putting some protocol on the
wire so that incoming messages can be constructed from stream data.
- org.springframework.integration.ip.udp - package org.springframework.integration.ip.udp
-
Base package for UDP support.
- org.springframework.integration.ip.util - package org.springframework.integration.ip.util
-
Provides utilities for IP support.
- org.springframework.integration.jdbc - package org.springframework.integration.jdbc
-
Root package of the Spring Integration JDBC module, which contains various
JDBC and Stored Procedure/Function supporting components.
- org.springframework.integration.jdbc.config - package org.springframework.integration.jdbc.config
-
Contains parser classes for the JDBC namespace support.
- org.springframework.integration.jdbc.store - package org.springframework.integration.jdbc.store
-
Provides JDBC-backed Message Store implementations.
- org.springframework.integration.jdbc.store.channel - package org.springframework.integration.jdbc.store.channel
-
Provides support classes for the JdbcChannelMessageStore.
- org.springframework.integration.jdbc.storedproc - package org.springframework.integration.jdbc.storedproc
-
Provides Stored Procedure/Function supporting classes.
- org.springframework.integration.jms - package org.springframework.integration.jms
-
Base package for JMS Support.
- org.springframework.integration.jms.config - package org.springframework.integration.jms.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.jmx - package org.springframework.integration.jmx
-
Base package for JMX support.
- org.springframework.integration.jmx.config - package org.springframework.integration.jmx.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.jpa.config.xml - package org.springframework.integration.jpa.config.xml
-
Provides parser classes to provide Xml namespace support for the Jpa components.
- org.springframework.integration.jpa.core - package org.springframework.integration.jpa.core
-
Provides core classes of the JPA module.
- org.springframework.integration.jpa.inbound - package org.springframework.integration.jpa.inbound
-
Provides inbound Spring Integration Jpa components.
- org.springframework.integration.jpa.outbound - package org.springframework.integration.jpa.outbound
-
Provides Spring Integration components for doing outbound operations.
- org.springframework.integration.jpa.support - package org.springframework.integration.jpa.support
-
Provides various support classes used across Spring Integration Jpa Components.
- org.springframework.integration.jpa.support.parametersource - package org.springframework.integration.jpa.support.parametersource
-
Provides generic support for ParameterSources and ParameterSource Factories.
- org.springframework.integration.json - package org.springframework.integration.json
-
Provides classes supporting JSON in Spring Integration.
- org.springframework.integration.mail - package org.springframework.integration.mail
-
Base package for Mail support.
- org.springframework.integration.mail.config - package org.springframework.integration.mail.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.mail.event - package org.springframework.integration.mail.event
-
Events generated by the mail module
- org.springframework.integration.mail.transformer - package org.springframework.integration.mail.transformer
-
Provides classes related to transforming mail messages.
- org.springframework.integration.mapping - package org.springframework.integration.mapping
-
Provides classes related to mapping to/from message headers.
- org.springframework.integration.mapping.support - package org.springframework.integration.mapping.support
-
Support classes for mapping.
- org.springframework.integration.message - package org.springframework.integration.message
-
Provides concrete
Message
implementations.
- org.springframework.integration.metadata - package org.springframework.integration.metadata
-
Provides classes supporting metadata stores.
- org.springframework.integration.mongodb.config - package org.springframework.integration.mongodb.config
-
Contains parser classes for the MongoDb namespace support.
- org.springframework.integration.mongodb.inbound - package org.springframework.integration.mongodb.inbound
-
Provides classes related to the Mongo inbound channel adapters
- org.springframework.integration.mongodb.outbound - package org.springframework.integration.mongodb.outbound
-
Provides classes related to the Mongo outbound channel adapters
- org.springframework.integration.mongodb.store - package org.springframework.integration.mongodb.store
-
Provides classes related to the MongoDB message store.
- org.springframework.integration.mongodb.support - package org.springframework.integration.mongodb.support
-
Provides supporting classes for this module.
- org.springframework.integration.monitor - package org.springframework.integration.monitor
-
Provides classes related to Spring Integration managed resources.
- org.springframework.integration.redis.channel - package org.springframework.integration.redis.channel
-
Provides classes related to Redis-backed channels.
- org.springframework.integration.redis.config - package org.springframework.integration.redis.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.redis.event - package org.springframework.integration.redis.event
-
Events generated by the redis module
- org.springframework.integration.redis.inbound - package org.springframework.integration.redis.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.redis.metadata - package org.springframework.integration.redis.metadata
-
- org.springframework.integration.redis.outbound - package org.springframework.integration.redis.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.integration.redis.store - package org.springframework.integration.redis.store
-
Provides classes related to the Redis message store.
- org.springframework.integration.redis.support - package org.springframework.integration.redis.support
-
Provides supporting classes for this module.
- org.springframework.integration.resource - package org.springframework.integration.resource
-
Provides classes related to messaging
using Spring Resource
s
- org.springframework.integration.rmi - package org.springframework.integration.rmi
-
Base package for RMI support.
- org.springframework.integration.rmi.config - package org.springframework.integration.rmi.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.router - package org.springframework.integration.router
-
Provides classes supporting the router pattern.
- org.springframework.integration.scheduling - package org.springframework.integration.scheduling
-
Provides classes related to task scheduling.
- org.springframework.integration.scripting - package org.springframework.integration.scripting
-
Base package for scripting support.
- org.springframework.integration.scripting.config - package org.springframework.integration.scripting.config
-
Base package supporting configuration.
- org.springframework.integration.scripting.config.jsr223 - package org.springframework.integration.scripting.config.jsr223
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.scripting.jsr223 - package org.springframework.integration.scripting.jsr223
-
Provides classes supporting JSR223 Scripting.
- org.springframework.integration.security.channel - package org.springframework.integration.security.channel
-
Provides classes related to secured channels.
- org.springframework.integration.security.config - package org.springframework.integration.security.config
-
Provides classes for configuration - parsers, namespace handlers, bean post processors.
- org.springframework.integration.selector - package org.springframework.integration.selector
-
Provides classes related to message selection.
- org.springframework.integration.sftp.config - package org.springframework.integration.sftp.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.sftp.filters - package org.springframework.integration.sftp.filters
-
Provides classes supporting SFTP file filtering.
- org.springframework.integration.sftp.gateway - package org.springframework.integration.sftp.gateway
-
Provides classes supporting SFTP gateways.
- org.springframework.integration.sftp.inbound - package org.springframework.integration.sftp.inbound
-
Provides classes supporting inbound endpoints.
- org.springframework.integration.sftp.session - package org.springframework.integration.sftp.session
-
Provides classes supporting SFTP sessions.
- org.springframework.integration.splitter - package org.springframework.integration.splitter
-
Provides classes supporting the splitter pattern.
- org.springframework.integration.store - package org.springframework.integration.store
-
Provides classes releated to storing messages.
- org.springframework.integration.stream - package org.springframework.integration.stream
-
Base package for stream support.
- org.springframework.integration.stream.config - package org.springframework.integration.stream.config
-
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.support - package org.springframework.integration.support
-
Base core support package.
- org.springframework.integration.support.channel - package org.springframework.integration.support.channel
-
Provides classes supporting channel resolution.
- org.springframework.integration.support.context - package org.springframework.integration.support.context
-
Provides classes supporting use of the application context.
- org.springframework.integration.support.converter - package org.springframework.integration.support.converter
-
Provides classes supporting message conversion.
- org.springframework.integration.support.json - package org.springframework.integration.support.json
-
Provides classes supporting json.
- org.springframework.integration.syslog - package org.springframework.integration.syslog
-
Base package for Syslog Support.
- org.springframework.integration.syslog.config - package org.springframework.integration.syslog.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.syslog.inbound - package org.springframework.integration.syslog.inbound
-
Provides classes for inbound endpoints.
- org.springframework.integration.test.matcher - package org.springframework.integration.test.matcher
-
Provides several BaseMatcher
implementations.
- org.springframework.integration.test.support - package org.springframework.integration.test.support
-
Provides several test support classes including for testing Spring Integration
request-response message scenarios.
- org.springframework.integration.test.util - package org.springframework.integration.test.util
-
Provides various test utilities, for example
TestUtils
provides convenience
helpers to easily retrieve private bean properties.
- org.springframework.integration.transaction - package org.springframework.integration.transaction
-
Provides classes supporting the use of transactions and
pseudo transactions in Spring Integration applications.
- org.springframework.integration.transformer - package org.springframework.integration.transformer
-
Contains core-implementation of various Transformers which includes Enrichers
and Filters.
- org.springframework.integration.transformer.support - package org.springframework.integration.transformer.support
-
Contains support classes for Transformers.
- org.springframework.integration.twitter.config - package org.springframework.integration.twitter.config
-
Contains parser classes for the Twitter namespace support.
- org.springframework.integration.twitter.core - package org.springframework.integration.twitter.core
-
Provides classes used across all Twitter components.
- org.springframework.integration.twitter.inbound - package org.springframework.integration.twitter.inbound
-
Provides inbound Twitter components.
- org.springframework.integration.twitter.outbound - package org.springframework.integration.twitter.outbound
-
Provides outbound Twitter components.
- org.springframework.integration.util - package org.springframework.integration.util
-
Provides core utility classes.
- org.springframework.integration.ws - package org.springframework.integration.ws
-
Provides several inbound and outbound Web Service components.
- org.springframework.integration.ws.config - package org.springframework.integration.ws.config
-
Contains parser classes for the Web Services namespace support.
- org.springframework.integration.xml - package org.springframework.integration.xml
-
Root package of the XML Module.
- org.springframework.integration.xml.config - package org.springframework.integration.xml.config
-
Contains parser classes for the XML namespace support.
- org.springframework.integration.xml.result - package org.springframework.integration.xml.result
-
Provides
ResultFactory
that
will return
Result
, possibly taking into account
payload instance.
- org.springframework.integration.xml.router - package org.springframework.integration.xml.router
-
Provides XML message routers.
- org.springframework.integration.xml.selector - package org.springframework.integration.xml.selector
-
- org.springframework.integration.xml.source - package org.springframework.integration.xml.source
-
- org.springframework.integration.xml.splitter - package org.springframework.integration.xml.splitter
-
- org.springframework.integration.xml.transformer - package org.springframework.integration.xml.transformer
-
Provides Transformer and Enricher implementations.
- org.springframework.integration.xml.xpath - package org.springframework.integration.xml.xpath
-
Provides XPath supporting classes.
- org.springframework.integration.xmpp - package org.springframework.integration.xmpp
-
Root package of the Spring Integration XMPP Module.
- org.springframework.integration.xmpp.config - package org.springframework.integration.xmpp.config
-
Contains parser classes for the XMPP namespace support.
- org.springframework.integration.xmpp.core - package org.springframework.integration.xmpp.core
-
Provides classes shared across all XMPP components.
- org.springframework.integration.xmpp.inbound - package org.springframework.integration.xmpp.inbound
-
- org.springframework.integration.xmpp.outbound - package org.springframework.integration.xmpp.outbound
-
- org.springframework.integration.xmpp.support - package org.springframework.integration.xmpp.support
-
Provides XMPP specific support classes.
- ORIGINAL_FILE - Static variable in class org.springframework.integration.file.FileHeaders
-
- OSDelegatingFileTailingMessageProducer - Class in org.springframework.integration.file.tail
-
A file tailing message producer that delegates to the OS tail program.
- OSDelegatingFileTailingMessageProducer() - Constructor for class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
-
- OutboundGatewayType - Enum in org.springframework.integration.jpa.support
-
Indicates the mode of operation for the outbound Jpa Gateway.
- outboundMapper() - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Factory method for creating a basic outbound mapper instance.
- OutboundMessageMapper<T> - Interface in org.springframework.integration.mapping
-
Strategy interface for mapping from a
Message
to an Object.
- read(String, OutputStream) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- read(String, OutputStream) - Method in interface org.springframework.integration.file.remote.session.Session
-
- read(String, OutputStream) - Method in class org.springframework.integration.ftp.session.FtpSession
-
- read(Message<?>) - Static method in class org.springframework.integration.history.MessageHistory
-
- read(Class<? extends MultiValueMap<String, ?>>, HttpInputMessage) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
-
- read(InputStream, byte[], boolean) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
Reads data from the socket and puts the data in buffer.
- read(EvaluationContext, Object, String) - Method in class org.springframework.integration.json.JsonPropertyAccessor
-
- readHeader(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
Reads the header and returns the length of the data part.
- readHeaders(P, String) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
-
- readHeaders(JsonInboundMessageMapper.JsonMessageParser<?>, String) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
-
- readInternal(Class, HttpInputMessage) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
-
- readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.DefaultMultipartFileReader
-
- readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
-
- readMultipartFile(MultipartFile) - Method in interface org.springframework.integration.http.multipart.MultipartFileReader
-
Reads MultipartFile
content.
- readMultipartFile(MultipartFile) - Method in class org.springframework.integration.http.multipart.SimpleMultipartFileReader
-
- readPacket() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
Invoked by the factory when there is data to be read.
- readPayload(P, String) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
-
- readPayload(JsonInboundMessageMapper.JsonMessageParser<?>, String) - Method in class org.springframework.integration.support.json.JsonInboundMessageMapper
-
- readRaw(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- readRaw(String) - Method in interface org.springframework.integration.file.remote.session.Session
-
Retrieve a remote file as a raw InputStream
.
- readRaw(String) - Method in class org.springframework.integration.ftp.session.FtpSession
-
- receive() - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
-
- receive() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- receive(long) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
- receive() - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
Receive the first available message from this channel.
- receive(long) - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
Receive the first available message from this channel.
- receive() - Method in class org.springframework.integration.channel.NullChannel
-
- receive(long) - Method in class org.springframework.integration.channel.NullChannel
-
- receive() - Method in interface org.springframework.integration.core.MessageSource
-
Retrieve the next available message from this source.
- receive() - Method in interface org.springframework.integration.core.MessagingOperations
-
Receive a message synchronously from the default channel, but only
wait up to a specified time for delivery.
- receive(PollableChannel) - Method in interface org.springframework.integration.core.MessagingOperations
-
Receive a message synchronously from the specified channel, but only
wait up to a specified time for delivery.
- receive(String) - Method in interface org.springframework.integration.core.MessagingOperations
-
Receive a message synchronously from the specified channel, but only
wait up to a specified time for delivery.
- receive() - Method in class org.springframework.integration.core.MessagingTemplate
-
- receive(PollableChannel) - Method in class org.springframework.integration.core.MessagingTemplate
-
- receive(String) - Method in class org.springframework.integration.core.MessagingTemplate
-
- receive() - Method in interface org.springframework.integration.core.PollableChannel
-
Receive a message from this channel, blocking indefinitely if necessary.
- receive(long) - Method in interface org.springframework.integration.core.PollableChannel
-
Receive a message from this channel, blocking until either a message is
available or the specified timeout period elapses.
- receive() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
-
- receive() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
-
- receive() - Method in class org.springframework.integration.file.FileReadingMessageSource
-
- receive() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
Polls from the file source.
- receive() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- receive() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- receive() - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
Executes the query.
- receive() - Method in class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
-
Executes the query.
- receive() - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
-
Will receive a JMS
Message
converting and returning it as
a Spring Integration
Message
.
- receive() - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- receive(long) - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- receive() - Method in class org.springframework.integration.jpa.inbound.JpaPollingChannelAdapter
-
- receive() - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- receive() - Method in interface org.springframework.integration.mail.MailReceiver
-
- receive() - Method in class org.springframework.integration.mail.MailReceivingMessageSource
-
- receive() - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
Will execute a Query
returning its results as the Message payload.
- receive() - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
- receive() - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
-
- receive() - Method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
-
- receiveAndConvert() - Method in interface org.springframework.integration.core.MessagingOperations
-
Receive a message synchronously from the default channel, but only
wait up to a specified time for delivery.
- receiveAndConvert(PollableChannel) - Method in interface org.springframework.integration.core.MessagingOperations
-
Receive a message synchronously from the specified channel, but only
wait up to a specified time for delivery.
- receiveAndConvert(String) - Method in interface org.springframework.integration.core.MessagingOperations
-
Receive a message synchronously from the specified channel, but only
wait up to a specified time for delivery.
- receiveAndConvert() - Method in class org.springframework.integration.core.MessagingTemplate
-
- receiveAndConvert(PollableChannel) - Method in class org.springframework.integration.core.MessagingTemplate
-
- receiveAndConvert(String) - Method in class org.springframework.integration.core.MessagingTemplate
-
- RECEIVED_EXCHANGE - Static variable in class org.springframework.integration.amqp.AmqpHeaders
-
- RECEIVED_ROUTING_KEY - Static variable in class org.springframework.integration.amqp.AmqpHeaders
-
- receiveMessage() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
Obtain the next message (if one is available).
- receiveMessage() - Method in class org.springframework.integration.endpoint.PollingConsumer
-
- receiveMessage() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
- RecipientListRouter - Class in org.springframework.integration.router
-
<recipient-list-router id="simpleRouter" input-channel="routingChannelA">
<recipient channel="channel1"/>
<recipient channel="channel2"/>
</recipient-list-router>
- RecipientListRouter() - Constructor for class org.springframework.integration.router.RecipientListRouter
-
- RecipientListRouter.Recipient - Class in org.springframework.integration.router
-
- RecipientListRouter.Recipient(MessageChannel) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
-
- RecipientListRouter.Recipient(MessageChannel, MessageSelector) - Constructor for class org.springframework.integration.router.RecipientListRouter.Recipient
-
- RecipientListRouterParser - Class in org.springframework.integration.config.xml
-
Parser for the <recipient-list-router/> element.
- RecipientListRouterParser() - Constructor for class org.springframework.integration.config.xml.RecipientListRouterParser
-
- recover(RetryContext) - Method in class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
-
- RecursiveLeafOnlyDirectoryScanner - Class in org.springframework.integration.file
-
DirectoryScanner that lists all files inside a directory and subdirectories,
without limit.
- RecursiveLeafOnlyDirectoryScanner() - Constructor for class org.springframework.integration.file.RecursiveLeafOnlyDirectoryScanner
-
- REDELIVERED - Static variable in class org.springframework.integration.amqp.AmqpHeaders
-
- REDELIVERED - Static variable in class org.springframework.integration.jms.JmsHeaders
-
- RedisChannelParser - Class in org.springframework.integration.redis.config
-
Parser for the 'channel' and 'publish-subscribe-channel' elements of the
Spring Integration Redis namespace.
- RedisChannelParser() - Constructor for class org.springframework.integration.redis.config.RedisChannelParser
-
- RedisExceptionEvent - Class in org.springframework.integration.redis.event
-
- RedisExceptionEvent(Object, Throwable) - Constructor for class org.springframework.integration.redis.event.RedisExceptionEvent
-
- RedisHeaders - Class in org.springframework.integration.redis.support
-
Pre-defined names and prefixes to be used for
for dealing with headers required by Redis components
- RedisHeaders() - Constructor for class org.springframework.integration.redis.support.RedisHeaders
-
- RedisInboundChannelAdapter - Class in org.springframework.integration.redis.inbound
-
- RedisInboundChannelAdapter(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- RedisInboundChannelAdapterParser - Class in org.springframework.integration.redis.config
-
- RedisInboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisInboundChannelAdapterParser
-
- RedisIntegrationEvent - Class in org.springframework.integration.redis.event
-
- RedisIntegrationEvent(Object) - Constructor for class org.springframework.integration.redis.event.RedisIntegrationEvent
-
- RedisIntegrationEvent(Object, Throwable) - Constructor for class org.springframework.integration.redis.event.RedisIntegrationEvent
-
- RedisMessageStore - Class in org.springframework.integration.redis.store
-
- RedisMessageStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.store.RedisMessageStore
-
- RedisMetadataStore - Class in org.springframework.integration.redis.metadata
-
- RedisMetadataStore(RedisProperties) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
-
- RedisMetadataStore(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
-
Initializes the
RedisProperties
by provided
RedisConnectionFactory
and default hash key -
RedisMetadataStore.KEY
.
- RedisMetadataStore(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
-
Initializes the RedisProperties
by provided RedisConnectionFactory
and key.
- RedisMetadataStore(RedisOperations<String, ?>) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
-
Initializes the
RedisProperties
by provided
RedisConnectionFactory
and default hash key -
RedisMetadataStore.KEY
.
- RedisMetadataStore(RedisOperations<String, ?>, String) - Constructor for class org.springframework.integration.redis.metadata.RedisMetadataStore
-
Initializes the RedisProperties
by provided RedisConnectionFactory
and key.
- RedisNamespaceHandler - Class in org.springframework.integration.redis.config
-
Namespace handler for Spring Integration's 'redis' namespace.
- RedisNamespaceHandler() - Constructor for class org.springframework.integration.redis.config.RedisNamespaceHandler
-
- RedisOutboundChannelAdapterParser - Class in org.springframework.integration.redis.config
-
Parser for the <outbound-channel-adapter/>
component.
- RedisOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisOutboundChannelAdapterParser
-
- RedisPublishingMessageHandler - Class in org.springframework.integration.redis.outbound
-
- RedisPublishingMessageHandler(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- RedisQueueInboundChannelAdapterParser - Class in org.springframework.integration.redis.config
-
Parser for the <queue-inbound-channel-adapter> element of the 'redis' namespace.
- RedisQueueInboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueInboundChannelAdapterParser
-
- RedisQueueMessageDrivenEndpoint - Class in org.springframework.integration.redis.inbound
-
- RedisQueueMessageDrivenEndpoint(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- RedisQueueOutboundChannelAdapter - Class in org.springframework.integration.redis.outbound
-
- RedisQueueOutboundChannelAdapter(String, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
- RedisQueueOutboundChannelAdapter(Expression, RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
- RedisQueueOutboundChannelAdapterParser - Class in org.springframework.integration.redis.config
-
Parser for the <int-redis:queue-outbound-channel-adapter> element.
- RedisQueueOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisQueueOutboundChannelAdapterParser
-
- RedisStoreInboundChannelAdapterParser - Class in org.springframework.integration.redis.config
-
Parser for Redis store inbound adapters
- RedisStoreInboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisStoreInboundChannelAdapterParser
-
- RedisStoreMessageSource - Class in org.springframework.integration.redis.inbound
-
Inbound channel adapter which returns a Message representing a view into
a Redis store.
- RedisStoreMessageSource(RedisTemplate<String, ?>, Expression) - Constructor for class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
Creates an instance with the provided RedisTemplate
and SpEL expression
which should resolve to a 'key' name of the collection to be used.
- RedisStoreMessageSource(RedisConnectionFactory, Expression) - Constructor for class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
Creates an instance with the provided RedisConnectionFactory
and SpEL expression
which should resolve to a 'key' name of the collection to be used.
- RedisStoreOutboundChannelAdapterParser - Class in org.springframework.integration.redis.config
-
Parser for the <redis:store-outbound-channel-adapter> element.
- RedisStoreOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.redis.config.RedisStoreOutboundChannelAdapterParser
-
- RedisStoreWritingMessageHandler - Class in org.springframework.integration.redis.outbound
-
Implementation of
MessageHandler
which writes Message data into a Redis store
identified by a key
String
.
- RedisStoreWritingMessageHandler(RedisTemplate<String, ?>) - Constructor for class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Constructs an instance using the provided RedisTemplate
.
- RedisStoreWritingMessageHandler(RedisConnectionFactory) - Constructor for class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Constructs an instance using the provided RedisConnectionFactory
.
- REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
-
- REF_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- REFRESH_CHECK_DELAY_ATTRIBUTE - Static variable in class org.springframework.integration.scripting.config.AbstractScriptParser
-
- RefreshableResourceScriptSource - Class in org.springframework.integration.scripting
-
- RefreshableResourceScriptSource(Resource, long) - Constructor for class org.springframework.integration.scripting.RefreshableResourceScriptSource
-
- RegexPatternFileListFilter - Class in org.springframework.integration.file.filters
-
Implementation of AbstractRegexPatternMatchingFileListFilter for java.io.File instances.
- RegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.RegexPatternFileListFilter
-
- RegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.file.filters.RegexPatternFileListFilter
-
- RegexTestXPathMessageSelector - Class in org.springframework.integration.xml.selector
-
XPath
MessageSelector
that tests if a provided String value
matches a given Regular Expression.
- RegexTestXPathMessageSelector(String, Map<String, String>, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
-
Creates a selector which attempts to match the given regex and supports multiple namespaces.
- RegexTestXPathMessageSelector(String, String, String, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
-
Creates a selector which attempts to match the given regex and supports a single namespace.
- RegexTestXPathMessageSelector(String, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
-
Creates a non-namespaced selector which attempts to match the given regex.
- RegexTestXPathMessageSelector(XPathExpression, String) - Constructor for class org.springframework.integration.xml.selector.RegexTestXPathMessageSelector
-
Creates a selector which attempts to match the given regex against the evaluation result
of the provided XPathExpression
.
- RegexUtils - Class in org.springframework.integration.ip.util
-
Regular Expression Utilities.
- registerBeanDefinition(BeanDefinitionHolder, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
-
- registerBeanDefinitionDecorator(String, BeanDefinitionDecorator) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
-
- registerBeanDefinitionDecoratorForAttribute(String, BeanDefinitionDecorator) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
-
- registerBeanDefinitionParser(String, BeanDefinitionParser) - Method in class org.springframework.integration.config.xml.AbstractIntegrationNamespaceHandler
-
- registerBeans() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- registerChannel(String, MessageChannel) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
-
- registerEndpoint(String, AbstractEndpoint) - Method in class org.springframework.integration.test.util.TestUtils.TestApplicationContext
-
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Registers a TcpListener to receive messages after
the payload has been converted from the input data.
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
Delegate TCP Client Connection factories that are used to receive
data need a Listener to send the messages to.
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
Delegate TCP Client Connection factories that are used to receive
data need a Listener to send the messages to.
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- registerListener(TcpListener) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
Sets the listener that will receive incoming Messages.
- registerMessageGroupExpiryCallback(MessageGroupStore.MessageGroupCallback) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
- registerMessageGroupExpiryCallback(MessageGroupStore.MessageGroupCallback) - Method in interface org.springframework.integration.store.MessageGroupStore
-
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Registers a TcpSender; for server sockets, used to
provide connection information so a sender can be used
to reply to incoming messages.
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- registerSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
Registers a sender.
- registerSpelFunctionBean(BeanDefinitionRegistry, String, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- release() - Method in class org.springframework.integration.util.UpperBound
-
Releases one lock on the underlying semaphore.
- release(int) - Method in class org.springframework.integration.util.UpperBound
-
Releases several locks on the underlying semaphore.
- releaseItem(T) - Method in interface org.springframework.integration.util.Pool
-
Releases an item back into the pool.
- releaseItem(T) - Method in class org.springframework.integration.util.SimplePool
-
Returns an item to the pool.
- ReleaseStrategy - Interface in org.springframework.integration.aggregator
-
Strategy for determining when a group of messages reaches a state of
completion (i.e.
- ReleaseStrategy - Annotation Type in org.springframework.integration.annotation
-
Indicates that a method is capable of asserting if a list of messages or
payload objects is complete.
- ReleaseStrategyFactoryBean - Class in org.springframework.integration.config
-
- ReleaseStrategyFactoryBean(Object) - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
-
Create a factory and set up the delegate which clients of the factory will see as its product.
- ReleaseStrategyFactoryBean(Object, String) - Constructor for class org.springframework.integration.config.ReleaseStrategyFactoryBean
-
Create a factory and set up the delegate which clients of the factory will see as its product.
- ReloadableResourceBundleExpressionSource - Class in org.springframework.integration.expression
-
ExpressionSource
implementation that accesses resource bundles using specified basenames.
- ReloadableResourceBundleExpressionSource() - Constructor for class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
- remainingCapacity() - Method in class org.springframework.integration.store.MessageGroupQueue
-
- REMOTE_DIRECTORY - Static variable in class org.springframework.integration.file.FileHeaders
-
- REMOTE_FILE - Static variable in class org.springframework.integration.file.FileHeaders
-
- REMOTE_PORT - Static variable in class org.springframework.integration.ip.IpHeaders
-
The remote port from which a TCP message was received.
- REMOTE_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- RemoteFileOperations<F> - Interface in org.springframework.integration.file.remote
-
Strategy for performing operations on remote files.
- RemoteFileOutboundChannelAdapterParser - Class in org.springframework.integration.file.config
-
- RemoteFileOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.RemoteFileOutboundChannelAdapterParser
-
- RemoteFileTemplate<F> - Class in org.springframework.integration.file.remote
-
- RemoteFileTemplate(SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.RemoteFileTemplate
-
- RemoteFileUtils - Class in org.springframework.integration.file.remote
-
Utility methods for supporting remote file operations.
- remove(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
-
- remove(String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Remove a remote file.
- remove(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- remove(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- remove(String) - Method in interface org.springframework.integration.file.remote.session.Session
-
- remove(String) - Method in class org.springframework.integration.ftp.session.FtpSession
-
- remove(int) - Method in class org.springframework.integration.history.MessageHistory
-
- remove(Object) - Method in class org.springframework.integration.history.MessageHistory
-
- remove(Object) - Method in class org.springframework.integration.MessageHeaders
-
Since MessageHeaders are immutable the call to this method will result in UnsupportedOperationException
- remove(String) - Method in interface org.springframework.integration.metadata.MetadataStore
-
Remove a value for the given key from this MetadataStore.
- remove(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
-
- remove(String) - Method in class org.springframework.integration.metadata.SimpleMetadataStore
-
- remove(String) - Method in class org.springframework.integration.redis.metadata.RedisMetadataStore
-
- remove(UUID) - Method in class org.springframework.integration.store.MessageGroupMetadata
-
- remove(Message<?>) - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- removeAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
-
- removeAllIdleItems() - Method in interface org.springframework.integration.util.Pool
-
Removes all idle items from the pool.
- removeAllIdleItems() - Method in class org.springframework.integration.util.SimplePool
-
- removeChannelMapping(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Remove a channel mapping for the given key if present.
- removeChannelMapping(String) - Method in interface org.springframework.integration.router.MappingMessageRouterManagement
-
Remove a channel mapping for the given key if present.
- removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- removeDeadConnection(TcpConnection) - Method in interface org.springframework.integration.ip.tcp.connection.TcpSender
-
When we are using sockets owned by a
TcpListener
, this
method is called each time a connection is closed.
- removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- removeDeadConnection(TcpConnection) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- removedFromPool(T) - Method in interface org.springframework.integration.util.SimplePool.PoolItemCallback
-
Called by the pool when an item is forcibly removed from the pool - for example
when the pool size is reduced.
- removeFromIdCache(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Remove a Message Id from the idCache.
- removeHandler(MessageHandler) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
-
Remove the handler from the internal handler Set.
- removeHandler(MessageHandler) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
-
- removeHeader(String) - Method in class org.springframework.integration.support.MessageBuilder
-
Remove the value for the given header name.
- removeHeaders(String...) - Method in class org.springframework.integration.support.MessageBuilder
-
Removes all headers provided via array of 'headerPatterns'.
- removeMessage(UUID) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
- removeMessage(UUID) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- removeMessage(UUID) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- removeMessage(UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- removeMessage(UUID) - Method in interface org.springframework.integration.store.MessageStore
-
Remove the Message with the given id from the MessageStore, if present, and return it.
- removeMessage(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
- removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Remove a single message from the database.
- removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
Remove a Message from the group with the provided group ID.
- removeMessageFromGroup(Object, Message<?>) - Method in interface org.springframework.integration.store.MessageGroupStore
-
Persist a deletion on a single message from the group.
- removeMessageFromGroup(Object, Message<?>) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- removeMessageGroup(Object) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
- removeMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Will remove all messages from the message channel.
- removeMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- removeMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- removeMessageGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
Remove the MessageGroup with the provided group ID.
- removeMessageGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
-
Remove the message group with this id.
- removeMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- rename(String, String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Rename a remote file, creating directories if needed.
- rename(String, String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- rename(String, String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
-
- rename(String, String) - Method in interface org.springframework.integration.file.remote.session.Session
-
- rename(String, String) - Method in class org.springframework.integration.ftp.session.FtpSession
-
- RENAME_TO - Static variable in class org.springframework.integration.file.FileHeaders
-
- RendezvousChannel - Class in org.springframework.integration.channel
-
A zero-capacity version of
QueueChannel
that delegates to a
SynchronousQueue
internally.
- RendezvousChannel() - Constructor for class org.springframework.integration.channel.RendezvousChannel
-
- REPLY_CHANNEL - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- REPLY_CHANNEL - Static variable in class org.springframework.integration.MessageHeaders
-
- REPLY_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- REPLY_TO - Static variable in class org.springframework.integration.amqp.AmqpHeaders
-
- REPLY_TO - Static variable in class org.springframework.integration.jms.JmsHeaders
-
- REPLY_TO - Static variable in class org.springframework.integration.mail.MailHeaders
-
- ReplyRequiredException - Exception in org.springframework.integration.handler
-
Exception that indicates no reply message is produced by a handler
that does have a value of true for the 'requiresReply' property.
- ReplyRequiredException(Message<?>, String) - Constructor for exception org.springframework.integration.handler.ReplyRequiredException
-
- REQUEST_HANDLER_ADVICE_CHAIN - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- REQUEST_METHOD - Static variable in class org.springframework.integration.http.HttpHeaders
-
- REQUEST_TIMEOUT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- REQUEST_URL - Static variable in class org.springframework.integration.http.HttpHeaders
-
- RequestHandlerCircuitBreakerAdvice - Class in org.springframework.integration.handler.advice
-
A circuit breaker that stops calling a failing service after threshold
failures, until halfOpenAfter milliseconds has elapsed.
- RequestHandlerCircuitBreakerAdvice() - Constructor for class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
-
- RequestHandlerRetryAdvice - Class in org.springframework.integration.handler.advice
-
Uses spring-retry to perform stateless or stateful retry.
- RequestHandlerRetryAdvice() - Constructor for class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- RequestMapping - Class in org.springframework.integration.http.inbound
-
- RequestMapping() - Constructor for class org.springframework.integration.http.inbound.RequestMapping
-
- RequestReplyExchanger - Interface in org.springframework.integration.gateway
-
Interface for a request/reply Message exchange.
- RequestReplyHeaderMapper<T> - Interface in org.springframework.integration.mapping
-
Request/Reply strategy interface for mapping
MessageHeaders
to and from other
types of objects.
- RequestResponseScenario - Class in org.springframework.integration.test.support
-
Defines a Spring Integration request response test scenario.
- RequestResponseScenario(String, String) - Constructor for class org.springframework.integration.test.support.RequestResponseScenario
-
Create an instance
- reschedulePersistedMessages() - Method in class org.springframework.integration.handler.DelayHandler
-
Used for reading persisted Messages in the 'messageStore'
to reschedule them e.g.
- reschedulePersistedMessages() - Method in interface org.springframework.integration.handler.DelayHandlerManagement
-
- ResequencerParser - Class in org.springframework.integration.config.xml
-
Parser for the <resequencer> element.
- ResequencerParser() - Constructor for class org.springframework.integration.config.xml.ResequencerParser
-
- ResequencingMessageGroupProcessor - Class in org.springframework.integration.aggregator
-
This class implements all the strategy interfaces needed for a default resequencer.
- ResequencingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.ResequencingMessageGroupProcessor
-
- ResequencingMessageHandler - Class in org.springframework.integration.aggregator
-
- ResequencingMessageHandler(MessageGroupProcessor, MessageGroupStore, CorrelationStrategy, ReleaseStrategy) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
-
- ResequencingMessageHandler(MessageGroupProcessor, MessageGroupStore) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
-
- ResequencingMessageHandler(MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.ResequencingMessageHandler
-
- reset() - Method in class org.springframework.integration.monitor.DirectChannelMetrics
-
- reset() - Method in class org.springframework.integration.monitor.ExponentialMovingAverage
-
- reset() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRate
-
- reset() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
-
- reset() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- reset() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
-
- reset() - Method in interface org.springframework.integration.monitor.MessageChannelMetrics
-
- reset() - Method in interface org.springframework.integration.monitor.MessageHandlerMetrics
-
- reset() - Method in interface org.springframework.integration.monitor.MessageSourceMetrics
-
- reset() - Method in class org.springframework.integration.monitor.PollableChannelMetrics
-
- reset() - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- reset() - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
-
- reset() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
-
- resetCache() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
-
Clear the cache of sessions; also any in-use sessions will be closed when
returned to the cache.
- resetSharedSession() - Method in interface org.springframework.integration.file.remote.session.SharedSessionCapable
-
Resets the shared session so the next #getSession()
will return a session
using a new connection.
- resetSharedSession() - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
- resolveChannelName(String) - Method in class org.springframework.integration.core.MessagingTemplate
-
- resolveChannelName(String) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
-
- resolveChannelName(String) - Method in interface org.springframework.integration.support.channel.ChannelResolver
-
Return the MessageChannel for the given name.
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.ChainParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.MessageHistoryParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.config.xml.PollerParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
-
- resolvePrimitiveType(Class<?>) - Static method in class org.springframework.integration.util.ClassUtils
-
Resolve the given class if it is a primitive wrapper class,
returning the corresponding primitive type instead.
- ResourceInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
-
Parser for 'resource-inbound-channel-adapter'
- ResourceInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.ResourceInboundChannelAdapterParser
-
- ResourceRetrievingMessageSource - Class in org.springframework.integration.resource
-
Implementation of MessageSource
based on ResourcePatternResolver
which will
attempt to resolve Resource
s based on the pattern specified.
- ResourceRetrievingMessageSource(String) - Constructor for class org.springframework.integration.resource.ResourceRetrievingMessageSource
-
- restartAckThread() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
If exposed as an MBean, can be used to restart the ack thread if a fatal
(bind) error occurred, without bouncing the JVM.
- ResultFactory - Interface in org.springframework.integration.xml.result
-
Factory to create a Result
possibly taking into account the
provided message payload instance.
- ResultToDocumentTransformer - Class in org.springframework.integration.xml.transformer
-
Creates a Document
from a Result
payload.
- ResultToDocumentTransformer(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
-
- ResultToDocumentTransformer() - Constructor for class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
-
- ResultToStringTransformer - Class in org.springframework.integration.xml.transformer
-
Converts the passed Result
to an instance of String
.
- ResultToStringTransformer() - Constructor for class org.springframework.integration.xml.transformer.ResultToStringTransformer
-
- ResultTransformer - Interface in org.springframework.integration.xml.transformer
-
Implementations of this class allow for the transformation of Result
objects to other formats.
- retainAll(Collection<?>) - Method in class org.springframework.integration.history.MessageHistory
-
- retrieveMBeanNames() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
- RetrievingJpaOutboundGatewayParser - Class in org.springframework.integration.jpa.config.xml
-
The Parser for the Retrieving Jpa Outbound Gateway.
- RetrievingJpaOutboundGatewayParser() - Constructor for class org.springframework.integration.jpa.config.xml.RetrievingJpaOutboundGatewayParser
-
- RETRY_INTERVAL - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- retryConnection() - Method in interface org.springframework.integration.ip.tcp.connection.ClientModeCapable
-
Immediately attempt to establish the connection.
- retryConnection() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- retryConnection() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- retryConnection() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- RetryStateGenerator - Interface in org.springframework.integration.handler.advice
-
Strategy interface for generating a RetryState
instance
based on a message.
- RETURN_EXCHANGE - Static variable in class org.springframework.integration.amqp.AmqpHeaders
-
- RETURN_REPLY_CODE - Static variable in class org.springframework.integration.amqp.AmqpHeaders
-
- RETURN_REPLY_TEXT - Static variable in class org.springframework.integration.amqp.AmqpHeaders
-
- RETURN_ROUTING_KEY - Static variable in class org.springframework.integration.amqp.AmqpHeaders
-
- returnedMessage(Message, int, String, String, String) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- RmiInboundGateway - Class in org.springframework.integration.rmi
-
An inbound Messaging Gateway for RMI-based remoting.
- RmiInboundGateway() - Constructor for class org.springframework.integration.rmi.RmiInboundGateway
-
- RmiInboundGatewayParser - Class in org.springframework.integration.rmi.config
-
Parser for the <inbound-gateway/> element of the 'rmi' namespace.
- RmiInboundGatewayParser() - Constructor for class org.springframework.integration.rmi.config.RmiInboundGatewayParser
-
- RmiNamespaceHandler - Class in org.springframework.integration.rmi.config
-
Namespace handler for Spring Integration's rmi namespace.
- RmiNamespaceHandler() - Constructor for class org.springframework.integration.rmi.config.RmiNamespaceHandler
-
- RmiOutboundGateway - Class in org.springframework.integration.rmi
-
An outbound Messaging Gateway for RMI-based remoting.
- RmiOutboundGateway(String) - Constructor for class org.springframework.integration.rmi.RmiOutboundGateway
-
- RmiOutboundGatewayParser - Class in org.springframework.integration.rmi.config
-
Parser for the <outbound-gateway/> element of the 'rmi' namespace.
- RmiOutboundGatewayParser() - Constructor for class org.springframework.integration.rmi.config.RmiOutboundGatewayParser
-
- RoundRobinLoadBalancingStrategy - Class in org.springframework.integration.dispatcher
-
- RoundRobinLoadBalancingStrategy() - Constructor for class org.springframework.integration.dispatcher.RoundRobinLoadBalancingStrategy
-
- Router - Annotation Type in org.springframework.integration.annotation
-
Indicates that a method is capable of resolving to a channel or channel name
based on a message, message header(s), or both.
- RouterAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
-
Post-processor for Methods annotated with
@Router
.
- RouterAnnotationPostProcessor(ListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.RouterAnnotationPostProcessor
-
- RouterFactoryBean - Class in org.springframework.integration.config
-
Factory bean for creating a Message Router.
- RouterFactoryBean() - Constructor for class org.springframework.integration.config.RouterFactoryBean
-
- run() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- run() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
-
Reads lines from stdout and sends in a message to the output channel.
- run() - Method in class org.springframework.integration.ip.tcp.connection.ClientModeConnectionManager
-
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
-
If there is no listener, and this connection is not for single use,
this method exits.
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
If no listener registers, exits.
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
If there is no listener, and this connection is not for single use,
this method exits.
- run() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
If no listener registers, exits.
- run() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- run() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
Process acknowledgments, if requested.
- run() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- run() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
Expire all message groups older than the
timeout
provided.
- runReaper() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
Cancel the scheduled reap task and run immediately; then reschedule.
- runReaper() - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
-
Cancel the scheduled reap task and run immediately; then reschedule.
- 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.
- SAVED_KEY - Static variable in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
The name of the message header that stores a flag to indicate that the message has been saved.
- SAVED_KEY - Static variable in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
The name of the message header that stores a flag to indicate that the message has been saved.
- SCHEDULER - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- SCHEMA_RELAX_NG - Static variable in class org.springframework.integration.xml.config.XmlPayloadValidatingFilterParser
-
Constant that defines a RELAX NG Schema.
- SCHEMA_W3C_XML - Static variable in class org.springframework.integration.xml.config.XmlPayloadValidatingFilterParser
-
Constant that defines a W3C XML Schema.
- ScriptExecutingMessageProcessor - Class in org.springframework.integration.scripting.jsr223
-
- ScriptExecutingMessageProcessor(ScriptSource, ScriptExecutor) - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
-
Create a processor for the
ScriptSource
using the provided
ScriptExecutor
using the DefaultScriptVariableGenerator
- ScriptExecutingMessageProcessor(ScriptSource, ScriptVariableGenerator, ScriptExecutor) - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
-
Create a processor for the
ScriptSource
using the provided
ScriptExecutor
- ScriptExecutingMessageProcessor(ScriptSource, ScriptExecutor, Map<String, Object>) - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
-
Create a processor for the
ScriptSource
using the provided
ScriptExecutor
using the DefaultScriptVariableGenerator
- ScriptExecutor - Interface in org.springframework.integration.scripting
-
- ScriptExecutorFactory - Class in org.springframework.integration.scripting.jsr223
-
- ScriptExecutorFactory() - Constructor for class org.springframework.integration.scripting.jsr223.ScriptExecutorFactory
-
- ScriptingException - Exception in org.springframework.integration.scripting
-
- ScriptingException(String) - Constructor for exception org.springframework.integration.scripting.ScriptingException
-
- ScriptingException(String, Throwable) - Constructor for exception org.springframework.integration.scripting.ScriptingException
-
- ScriptNamespaceHandler - Class in org.springframework.integration.scripting.config.jsr223
-
- ScriptNamespaceHandler() - Constructor for class org.springframework.integration.scripting.config.jsr223.ScriptNamespaceHandler
-
- ScriptParser - Class in org.springframework.integration.scripting.config.jsr223
-
- ScriptParser() - Constructor for class org.springframework.integration.scripting.config.jsr223.ScriptParser
-
- ScriptVariableGenerator - Interface in org.springframework.integration.scripting
-
Strategy interface to provide a Map
of variables to the script execution context.
- 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
-
- SearchReceivingMessageSource - Class in org.springframework.integration.twitter.inbound
-
- SearchReceivingMessageSource(Twitter, String) - Constructor for class org.springframework.integration.twitter.inbound.SearchReceivingMessageSource
-
- SearchTermStrategy - Interface in org.springframework.integration.mail
-
- SecuredChannelsParser - Class in org.springframework.integration.security.config
-
- 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.NullChannel
-
- send(Message<?>, long) - Method in class org.springframework.integration.channel.NullChannel
-
- send(Message<P>) - Method in interface org.springframework.integration.core.MessagingOperations
-
Send a message to the default channel.
- send(MessageChannel, Message<P>) - Method in interface org.springframework.integration.core.MessagingOperations
-
Send a message to the specified channel.
- send(String, Message<P>) - Method in interface org.springframework.integration.core.MessagingOperations
-
Send a message to the specified channel.
- send(Message<P>) - Method in class org.springframework.integration.core.MessagingTemplate
-
- send(MessageChannel, Message<P>) - Method in class org.springframework.integration.core.MessagingTemplate
-
- send(String, Message<P>) - Method in class org.springframework.integration.core.MessagingTemplate
-
- send(Message<?>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Send a file to a remote server, based on information in a message.
- send(Message<?>, String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
-
Send a file to a remote server, based on information in a message.
- send(Message<?>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- send(Message<?>, String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- send(String) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
- send(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- send(Message<?>) - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
-
Converts and sends the message.
- send(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- send(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
-
- send(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- send(DatagramPacket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- send(Message<?>) - Method in interface org.springframework.integration.MessageChannel
-
- send(Message<?>, long) - Method in interface org.springframework.integration.MessageChannel
-
Send a message, blocking until either the message is accepted or the
specified timeout period elapses.
- sendAck(Message<byte[]>) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- sendAndReceive(Message<?>) - Method in interface org.springframework.integration.core.MessagingOperations
-
Send a message to the default channel and receive a reply.
- sendAndReceive(MessageChannel, Message<?>) - Method in interface org.springframework.integration.core.MessagingOperations
-
Send a message to the specified channel and receive a reply.
- sendAndReceive(String, Message<?>) - Method in interface org.springframework.integration.core.MessagingOperations
-
Send a message to the specified channel and receive a reply.
- sendAndReceive(Message<?>) - Method in class org.springframework.integration.core.MessagingTemplate
-
- sendAndReceive(MessageChannel, Message<?>) - Method in class org.springframework.integration.core.MessagingTemplate
-
- sendAndReceive(String, Message<?>) - Method in class org.springframework.integration.core.MessagingTemplate
-
- sendAndReceive(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- sendAndReceiveMessage(Object) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
- sendExceptionToListener(Exception) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- sendMessage(Message<?>) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- sendToPipe(ByteBuffer) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- sendToPipe(ByteBuffer) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
-
Overrides super class method to perform decryption and/or participate
in handshaking.
- SEQUENCE_DETAILS - Static variable in class org.springframework.integration.MessageHeaders
-
- SEQUENCE_NUMBER - Static variable in class org.springframework.integration.MessageHeaders
-
- SEQUENCE_SIZE - Static variable in class org.springframework.integration.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
-
- serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
-
Writes the byte[] to the stream and appends \r\n.
- serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
Writes the byte[] to the output stream, preceded by a 4 byte
length in network byte order (big endian).
- serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
-
- serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArraySingleTerminatorSerializer
-
Writes the byte[] to the stream and appends the terminator.
- serialize(byte[], OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
-
Writes the byte[] to the stream, prefixed by an ASCII STX character and
terminated with an ASCII ETX character.
- serialize(Map<?, ?>, OutputStream) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
-
- SerializingHttpMessageConverter - Class in org.springframework.integration.http.converter
-
An HttpMessageConverter
implementation for Serializable
instances.
- SerializingHttpMessageConverter() - Constructor for class org.springframework.integration.http.converter.SerializingHttpMessageConverter
-
Creates a new instance of the SerializingHttpMessageConverter
.
- 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
-
- ServiceActivatingHandler(MessageProcessor<T>) - Constructor for class org.springframework.integration.handler.ServiceActivatingHandler
-
- ServiceActivator - Annotation Type in org.springframework.integration.annotation
-
Indicates that a method is capable of handling a message or message payload.
- ServiceActivatorAnnotationPostProcessor - Class in org.springframework.integration.config.annotation
-
- ServiceActivatorAnnotationPostProcessor(ListableBeanFactory) - Constructor for class org.springframework.integration.config.annotation.ServiceActivatorAnnotationPostProcessor
-
- ServiceActivatorFactoryBean - Class in org.springframework.integration.config
-
- ServiceActivatorFactoryBean() - Constructor for class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- ServiceActivatorParser - Class in org.springframework.integration.config.xml
-
Parser for the <service-activator> element.
- ServiceActivatorParser() - Constructor for class org.springframework.integration.config.xml.ServiceActivatorParser
-
- Session<T> - Interface in org.springframework.integration.file.remote.session
-
Common abstraction for a Session with a remote File system.
- SessionCallback<F,T> - Interface in org.springframework.integration.file.remote
-
Callback invoked by RemoteFileOperations.execute()
- allows multiple operations
on a session.
- SessionCallbackWithoutResult<F> - Class in org.springframework.integration.file.remote
-
Simple convenience implementation of
SessionCallback
for cases where
no result is returned.
- SessionCallbackWithoutResult() - Constructor for class org.springframework.integration.file.remote.SessionCallbackWithoutResult
-
- SessionFactory<F> - Interface in org.springframework.integration.file.remote.session
-
Factory for acquiring
Session
instances.
- SessionFactoryFactoryBean<T> - Class in org.springframework.integration.file.remote.session
-
Deprecated.
- SessionFactoryFactoryBean(SessionFactory<T>, boolean) - Constructor for class org.springframework.integration.file.remote.session.SessionFactoryFactoryBean
-
Deprecated.
- set(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
-
- set(int, Properties) - Method in class org.springframework.integration.history.MessageHistory
-
- SET_COOKIE - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- setAcceptMessagesWhileStopping(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setAckAddress(String) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
-
- setAckCounter(int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setAcknowledge(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
-
- setAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setActive(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setAdditionalFlags(Message) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Optional method allowing you to set additional flags.
- setAdditionalFlags(Message) - Method in class org.springframework.integration.mail.ImapMailReceiver
-
- setAdviceChain(Advice[]) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
- setAdviceChain(List<Advice>) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setAdviceChainIfPresent(String, T, MessageHandler) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- setAfterCommitChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setAfterCommitExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setAfterRollbackChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setAfterRollbackExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setAlwaysUseResultFactory(boolean) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
Specify whether to always use result factory even for directly supported payload types
- setAlwaysUseSourceFactory(boolean) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
-
- setAlwaysUseSourceFactory(boolean) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
Specify whether to always use source factory even for directly supported payload types.
- setAmqpAdmin(AmqpAdmin) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
Provide an instance of AmqpAdmin for implicitly declaring Queues if the queueName is not provided.
- setAmqpAdmin(AmqpAdmin) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
This is an optional reference to an AmqpAdmin to use when
declaring a Queue implicitly for a PollableAmqpChannel.
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.event.outbound.ApplicationEventPublishingMessageHandler
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
-
- setApplySequence(boolean) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
-
Specify whether to apply the sequence number and size headers to the
messages prior to invoking the subscribed handlers.
- setApplySequence(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- setApplySequence(boolean) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- setApplySequence(boolean) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
Specify whether to apply sequence numbers to the messages prior to sending to the handlers.
- setApplySequence(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setApplySequence(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
- setApplySequence(boolean) - Method in class org.springframework.integration.router.AbstractMessageRouter
-
Specify whether to apply the sequence number and size headers to the messages prior to sending to the recipient
channels.
- setApplySequence(boolean) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
-
Set the applySequence flag to the specified value.
- setAsyncExecutor(Executor) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setAttributeName(String) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
-
Specify the name of the attribute to be retrieved.
- setAuthenticator(Authenticator) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setAuthValue(String) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- 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.
- setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
- setAutoCreateDirectory(boolean) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- setAutoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- setAutoCreateLocalDirectory(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- 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.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setBacklog(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setBacklog(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
The number of sockets in the connection backlog.
- setBaseDirectory(String) - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
-
- setBasename(String) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set a single basename, following the basic ResourceBundle convention of
not specifying file extension or language codes, but referring to a Spring
resource location: e.g.
- setBasenames(String[]) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set an array of basenames, each following the basic ResourceBundle convention
of not specifying file extension or language codes, but referring to a Spring
resource location: e.g.
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.json.JsonToObjectTransformer
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.annotation.MessagingAnnotationPostProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.core.MessagingTemplate
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.expression.IntegrationEvaluationContextAwareBeanPostProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.handler.MethodInvokingMessageProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
Allows to set the optional BeanFactory
which is used to add a
BeanResolver
to the StandardEvaluationContext
.
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.support.channel.BeanFactoryChannelResolver
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
Specify a BeanFactory in order to enable resolution via @beanName
in the expression.
- setBeanFactory(BeanFactory) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
-
- setBeanName(String) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
- setBeanName(String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setBeanName(String) - Method in class org.springframework.integration.transformer.HeaderEnricher
-
- setBeforeCommitChannel(MessageChannel) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setBeforeCommitExpression(Expression) - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
-
- setBufferSize(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setBytesPerMessage(int) - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
-
- setCacheEntries(Map<String, String>) - Method in class org.springframework.integration.gemfire.outbound.CacheWritingMessageHandler
-
- setCacheLevel(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setCacheLevelName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setCacheSeconds(int) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set the number of seconds to cache loaded properties files.
- 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.MethodAnnotationPublisherMetadataSource
-
- setChannelMap(Map<String, String>) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
-
- setChannelMapping(String, String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Add a channel mapping from the provided key to channel name.
- setChannelMapping(String, String) - Method in interface org.springframework.integration.router.MappingMessageRouterManagement
-
Add a channel mapping from the provided key to channel name.
- setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- setChannelMappings(Map<String, String>) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Provide mappings from channel keys to channel names.
- setChannelMessageStoreQueryProvider(ChannelMessageStoreQueryProvider) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
- setChannelName(String) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
-
- setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
-
- setChannelResolver(ChannelResolver) - Method in class org.springframework.integration.core.MessagingTemplate
-
- 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.AbstractMappingMessageRouter
-
- setChannels(List<MessageChannel>) - Method in class org.springframework.integration.router.RecipientListRouter
-
Set the channels for this router.
- setChannelTransacted(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- 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.remote.handler.FileTransferringMessageHandler
-
- setCharset(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- 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(Charset) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
-
Sets the character set used for writing form data.
- setCharset(String) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Specify the charset name to use for converting String-typed payloads to
bytes.
- setCharset(String) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
- 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.
- setCipherSuites(String[]) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setClassifier(Classifier<? super Throwable, Boolean>) - Method in class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
-
- setClearOnFlush(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
If set to true
the EntityManager.clear()
will be called,
and only if the EntityManager.flush()
was called after performing persistence operations.
- setClientId(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setClientMode(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
ACTIVE_LOCAL_DATA_CONNECTION_MODE = 0
A constant indicating the FTP session is expecting all transfers
to occur between the client (local) and server and that the server
should connect to the client's data port to initiate a data transfer.
- setClientMode(boolean) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- setClientMode(boolean) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- setClientMode(boolean) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- setClientVersion(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Allows you to set the client version property.
- setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
Sets the SpEL Expression
that should resolve to a collection name
used by the Query
.
- setCollectionNameExpression(Expression) - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
-
Sets the SpEL Expression
that should resolve to a collection name
used by MongoOperations
to store data
- setCollectionType(RedisCollectionFactoryBean.CollectionType) - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
- setCollectionType(RedisCollectionFactoryBean.CollectionType) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Sets the collection type for this handler as per RedisCollectionFactoryBean.CollectionType
.
- setComparator(Comparator<File>) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setComponentName(String) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
Sets the name of the handler component.
- setComponentName(String) - Method in class org.springframework.integration.context.IntegrationObjectSupport
-
Sets the name of this component.
- setComponentName(String) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setComponentName(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setComponentName(String) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
Sets the name of the handler component.
- setComponentNamePatterns(String[]) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
- setComponentNamePatterns(String[]) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- setComponentType(String) - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
-
- setComponentType(String) - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
-
- setConcurrency(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setConcurrentConsumers(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setConcurrentConsumers(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setConcurrentConsumers(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setConfig(FTPClientConfig) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setConfirmAckChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- setConfirmCorrelationExpression(String) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- setConfirmNackChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
Sets the client or server connection factory; for this (an inbound adapter), if
the factory is a client connection factory, the sockets are owned by a sending
channel adapter and this adapter is used to receive replies.
- setConnectionFactory(AbstractConnectionFactory) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
Sets the client or server connection factory; for this (an outbound adapter), if
the factory is a server connection factory, the sockets are owned by a receiving
channel adapter and this adapter is used to send replies.
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setConnectionFactory(ConnectionFactory) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the JMS ConnectionFactory that this gateway should use.
- setConnectionFactory(AbstractServerConnectionFactory) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setConnectionFactory(AbstractServerConnectionFactory) - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
-
- setConnectionWaitTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setConsumes(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setContainerType(Class<? extends AbstractMessageListenerContainer>) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setContentType(String) - Method in class org.springframework.integration.json.ObjectToJsonTransformer
-
Sets the content-type header value
- setControlEncoding(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.MethodInvokingMessageGroupProcessor
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.aggregator.MethodInvokingReleaseStrategy
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.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.MethodInvokingMessageProcessor
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
-
- setConversionService(ConversionService) - Method in class org.springframework.integration.util.BeanFactoryTypeConverter
-
- setConverter(MessageConverter) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setConverter(MessageConverter) - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
-
- setConverter(Converter<T, U>) - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
-
Specify the converter to use.
- setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.router.XPathRouter
-
Specify the Converter to use when converting payloads prior to XPath evaluation.
- setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
-
Specify the converter used to convert payloads prior to XPath testing.
- setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
-
Specify the Converter to use when converting payloads prior to validation.
- setConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
-
Specify the
XmlPayloadConverter
to use when converting a Message payload prior to XPath evaluation.
- setConvertExceptions(boolean) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingMessagingGateway
-
Flag to determine if conversion and writing out of message handling exceptions should be attempted (default
false, in which case they will simply be re-thrown).
- setCorrelationId(Object) - Method in class org.springframework.integration.support.MessageBuilder
-
- setCorrelationKey(String) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Provide the name of a JMS property that should be copied from the request
Message to the reply Message.
- setCorrelationKey(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Provide the name of a JMS property that should hold a generated UUID that
the receiver of the JMS Message would expect to represent the CorrelationID.
- setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setCorrelationStrategy(CorrelationStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
-
Set the CorrelationStrategy to be used to determine the correlation key for incoming messages
- setCreateDocuments(boolean) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
-
- setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
-
- setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
-
Sets a GroovyObjectCustomizer
for this processor.
- setCustomizer(GroovyObjectCustomizer) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
Sets a GroovyObjectCustomizer
for this processor.
- setDataSource(DataSource) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
The JDBC DataSource
to use when interacting with the database.
- setDataSource(DataSource) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
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.core.MessagingTemplate
-
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.
- setDefaultDomain(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
The JMX domain to use for MBeans registered.
- setDefaultEncoding(String) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set the default charset to use for parsing properties files.
- setDefaultErrorChannel(MessageChannel) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
-
- setDefaultMultipartCharset(String) - Method in class org.springframework.integration.http.multipart.SimpleMultipartFileReader
-
Specify the default charset name to use when converting multipart file
content into Strings if the multipart itself does not provide a charset.
- 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.
- 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.
- setDefaultTopic(String) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- setDelay(Long) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setDelayedAdviceChain(List<Advice>) - Method in class org.springframework.integration.handler.DelayHandler
-
Specify the List<Advice>
to advise DelayHandler.ReleaseMessageHandler
proxy.
- setDelayExpression(Expression) - Method in class org.springframework.integration.handler.DelayHandler
-
Specify the Expression
that should be checked for a delay period
(in milliseconds) or a Date to delay until.
- setDelayHeaderName(String) - Method in class org.springframework.integration.handler.DelayHandler
-
- setDeleteAfterPoll(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
If set to 'true', the retrieved objects are deleted from the database upon
being polled.
- setDeleteFiles(boolean) - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
-
Specify whether to delete the File after transformation.
- setDeleteInBatch(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
If not set, this property defaults to false
, which means that
deletion occurs on a per object basis if a collection of entities is being
deleted.
- setDeleteRemoteFiles(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- 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.config.SplitterFactoryBean
-
- 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.JmsOutboundGateway
-
Deprecated.
use JmsOutboundGateway.setDeliveryPersistent(boolean)
This should have been deprecated in 2.0 when the attribute was
deprecated in the schema. As of 3.0, the attribute has been
removed but this remains to allow users of the API to migrate.
TODO: Remove in 3.1/4.0
- setDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setDeliveryPersistent(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set whether message delivery should be persistent or non-persistent,
specified as a boolean value ("true" or "false").
- setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- setDeserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- setDeserializer(Deserializer<? extends Message<?>>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
A converter for deserializing byte arrays to messages.
- setDeserializer(Deserializer<? extends Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
A converter for deserializing byte arrays to messages.
- setDeserializer(Deserializer<Object>) - Method in class org.springframework.integration.transformer.PayloadDeserializingTransformer
-
- setDestination(Destination) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setDestination(Destination) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
-
- setDestination(Destination) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
- setDestinationExpression(Expression) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
- setDestinationName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setDestinationName(String) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
-
- setDestinationName(String) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
- 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.config.JmsChannelFactoryBean
-
- 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(File) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setDirectory(File) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
Specify the input directory.
- setDirectoryExpression(Expression) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setDiscardChannel(MessageChannel) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- 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.
- setDiscardWithinAdvice(boolean) - Method in class org.springframework.integration.config.FilterFactoryBean
-
- setDiscardWithinAdvice(boolean) - Method in class org.springframework.integration.filter.MessageFilter
-
Set to 'true' if you wish the discard processing to occur within any
request handler advice applied to this filter.
- setDocumentBuilder(DocumentBuilderFactory) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
-
- setDurable(boolean) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
-
- setDurableSubscriptionName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setEnableDaemonThread(Boolean) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
If true, all threads will be daemon threads.
- setEncodeUri(boolean) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Specify whether the real URI should be encoded after uriVariables
expanding and before send request via RestTemplate
.
- setEncoding(String) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setEnd(Boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setEnd(boolean) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
-
If true, tail from the end of the file, otherwise
include all lines from the beginning.
- setEntityClass(Class<?>) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Sets the class type which is being used for retrieving entities from the
database.
- setEntityClass(Class<?>) - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
Allows you to set the type of the entityClass that will be passed to the
MongoTemplate.find(Query, Class)
or MongoTemplate.findOne(Query, Class)
method.
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set the error channel.
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set the error channel.
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.support.MessageBuilder
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setErrorChannelName(String) - Method in class org.springframework.integration.support.MessageBuilder
-
- setErrorCode(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
The error code to use to signal an error in the message handling.
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
-
Provide an ErrorHandler
strategy for handling Exceptions that
occur downstream from this channel.
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setErrorHandler(ResponseErrorHandler) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Set the ResponseErrorHandler
for the underlying RestTemplate
.
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setErrorHandler(ErrorHandler) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setErrorsKey(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
The key used to expose Errors
in the core, in the case that message handling fails.
- setEvaluateAsString(boolean) - Method in class org.springframework.integration.xml.router.XPathRouter
-
- setEvaluationType(XPathEvaluationType) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
-
- setEventTypes(Class<? extends ApplicationEvent>...) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
Set the list of event types (classes that extend ApplicationEvent) that
this adapter should send to the message channel.
- setEventTypes(Class<? extends TcpConnectionEvent>[]) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionEventListeningMessageProducer
-
Set the list of event types (classes that extend TcpConnectionEvent) that
this adapter should send to the message channel.
- setExceptionListener(ExceptionListener) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setExchange(FanoutExchange) - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
-
Configure the FanoutExchange instance.
- setExchange(FanoutExchange) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
Set the FanoutExchange to use.
- setExchangeName(String) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- setExchangeNameExpression(String) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- setExcludedInboundStandardResponseHeaderNames(String[]) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Provide header names from the list of standard headers that should be suppressed when
mapping inbound endopoint response headers.
- setExcludedOutboundStandardRequestHeaderNames(String[]) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Provide header names from the list of standard headers that should be suppressed when
mapping outbound endpoint request headers.
- setExecutor(Executor) - Method in class org.springframework.integration.core.AsyncMessagingTemplate
-
- setExpectedResponseType(Class<?>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Specify the expected response type for the REST request
otherwise the default response type is ResponseEntity
and will
be returned as a payload of the reply Message.
- setExpectedResponseTypeExpression(Expression) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
- setExpectedType(Class<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
-
- setExpectedType(Class<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
-
Set the result type expected from evaluation of the expression.
- setExpectMessage(boolean) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
When data is retrieved from the Redis queue, does the returned data represent
just the payload for a Message, or does the data represent a serialized
Message
?.
- setExpectReply(boolean) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- setExpectReply(boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setExpectReply(boolean) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Specify whether a reply Message is expected.
- setExpectReply(boolean) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Specify whether a reply Message is expected.
- setExpectReply(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Specify whether a JMS reply Message is expected.
- setExpectReply(boolean) - Method in class org.springframework.integration.rmi.RmiInboundGateway
-
Specify whether the gateway should be expected to return a reply.
- setExpectSingleResult(boolean) - Method in class org.springframework.integration.jdbc.StoredProcOutboundGateway
-
This parameter indicates that only one result object shall be returned from
the Stored Procedure/Function Call.
- setExpectSingleResult(boolean) - Method in class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
-
This parameter indicates that only one result object shall be returned from
the Stored Procedure/Function Call.
- setExpectSingleResult(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
This parameter indicates that only one result object shall be returned as
a result from the executed JPA operation.
- setExpectSingleResult(boolean) - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
Allows you to manage which find* method to invoke on MongoTemplate
.
- setExpirationDate(Long) - Method in class org.springframework.integration.support.MessageBuilder
-
- setExpirationDate(Date) - Method in class org.springframework.integration.support.MessageBuilder
-
- setExpireGroupsUponCompletion(boolean) - Method in class org.springframework.integration.aggregator.AggregatingMessageHandler
-
Will set the 'expireGroupsUponCompletion' flag
- setExpireOnDestroy(boolean) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
Flag to indicate that the stores should be expired when this component is destroyed (i.e.
- setExpiryCallbacks(Collection<MessageGroupStore.MessageGroupCallback>) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
Convenient injection point for expiry callbacks in the message store.
- setExplicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- 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).
- setExposeListenerChannel(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setExposeListenerSession(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setExpression(String) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
-
Specify an expression to be evaluated against the Message
in order to generate a file name.
- setExpression(String) - Method in class org.springframework.integration.handler.LoggingHandler
-
- setExpression(String) - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
- setExpression(String) - Method in class org.springframework.integration.jpa.support.JpaParameter
-
- setExtractPayload(boolean) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Specify whether the outbound message's payload should be extracted
when preparing the request body.
- setExtractPayload(boolean) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
Specify whether the payload should be extracted from each integration
Message to be used as the JMS Message body.
- setExtractPayload(boolean) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
- 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.
- setExtractPayload(boolean) - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
-
Specify whether the text message body should be extracted when mapping to a
Spring Integration Message payload.
- setExtractPayloadElements(boolean) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Sets the flag signifying that if the payload is a "multivalue" (i.e., Collection or Map),
it should be saved using addAll/putAll semantics.
- setExtractReplyPayload(boolean) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Specify whether only 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 describes what to do with a JMS reply Message.
- 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 describes how a JMS Message should be generated from the
Spring Integration Message.
- setFailedMessage(Message<?>) - Method in exception org.springframework.integration.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.
- setFailureChannel(MessageChannel) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
- setFallbackToSystemLocale(boolean) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set whether to fall back to the system Locale if no files for a specific
Locale have been found.
- setFaultMessageResolver(FaultMessageResolver) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setFile(File) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setFile(File) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
The name of the file you wish to tail.
- setFileDelay(Long) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setFileEncodings(Properties) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set per-file charsets to use for parsing properties files.
- setFileExistsMode(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setFileExistsMode(FileExistsMode) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
Will set the
FileExistsMode
that specifies what will happen in
case the destination exists.
- setFileNameExpression(Expression) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- 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.
- setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
- setFileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- setFilenamePattern(String) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
-
- setFilenameRegex(String) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
-
- setFileType(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
File types defined by FTP
constants:
FTP.ASCII_FILE_TYPE
FTP.EBCDIC_FILE_TYPE
FTP.BINARY_FILE_TYPE
(DEFAULT)
FTP.LOCAL_FILE_TYPE
- setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
-
- setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.DefaultDirectoryScanner
-
- setFilter(FileListFilter<File>) - Method in interface org.springframework.integration.file.DirectoryScanner
-
Sets a custom filter to be used by this scanner.
- setFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.FileReadingMessageSource
-
- setFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- setFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- setFilter(NotificationFilter) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
Specify a NotificationFilter
to be passed to the server
when registering this listener.
- setFilter(CollectionFilter<Resource>) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
-
- setFilterHeadersInToMessage(boolean) - Method in class org.springframework.integration.support.converter.MapMessageConverter
-
- setFirstResultExpression(Expression) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Sets the expression that will be evaluated to get the first result in the query executed.
- setFlush(boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
If set to true
the EntityManager.flush()
will be called
after persistence operation.
- setFlushSize(int) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
If the provided value is greater than 0
, then EntityManager.flush()
will be called after persistence operations as well as within batch operations.
- setFunctions(Map<String, Method>) - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
-
- setGatewayType(OutboundGatewayType) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
-
- setGatewayType(OutboundGatewayType) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- setGlobalMethodMetadata(GatewayMethodMetadata) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setHalfOpenAfter(long) - Method in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
-
- 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.support.MessageBuilder
-
Set the value for the given header name.
- setHeaderExpressionMap(Map<String, Map<String, String>>) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
-
- setHeaderExpressions(Map<String, String>) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
-
- setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
-
- setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Specifies a Map of SpEL expressions to evaluate in order to generate the Message headers.
- setHeaderExpressions(Map<String, HeaderValueMessageProcessor<?>>) - Method in class org.springframework.integration.transformer.ContentEnricher
-
- setHeaderIfAbsent(String, Object) - Method in class org.springframework.integration.support.MessageBuilder
-
Set the value for the given header name only if the header name is not already associated with a value.
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
- setHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- setHeaderMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Set the
HeaderMapper
to use when mapping between HTTP headers and MessageHeaders.
- setHeaderMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Set the
HeaderMapper
to use when mapping between HTTP headers and MessageHeaders.
- 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.JmsDestinationPollingSource
-
- 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.
- setHeaderMapper(JmsHeaderMapper) - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
-
- setHeaderMapper(SoapHeaderMapper) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
-
- setHeaderMapper(SoapHeaderMapper) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setHeaderMapper(XmppHeaderMapper) - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
-
- setHeaderMapper(XmppHeaderMapper) - Method in class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
-
- setHeaderName(String) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
-
Specify a custom header name to check for the file name.
- setHeaderNames(String...) - Method in class org.springframework.integration.support.converter.MapMessageConverter
-
- setHeaders(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setHeaderTypes(Map<String, Class<?>>) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
-
- setHost(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setHost(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setHost(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
The url of the host you want connect to.
- setHostKeyAlias(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Sets the host key alias, used when comparing the host key to the known
hosts list.
- setHttpMethod(HttpMethod) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Specify the HttpMethod
for requests.
- setHttpMethodExpression(Expression) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Specify the SpEL Expression
to determine HttpMethod
dynamically
- setIdleConsumerLimit(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setIdleTaskExecutionLimit(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setIdleTaskExecutionLimit(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setIgnoreColumnMetaData(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
For fully supported databases, the underlying SimpleJdbcCall
can
retrieve the parameter information for the to be invoked Stored Procedure
from the JDBC Meta-data.
- setIgnoreEmptyResponses(boolean) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
Specify whether empty String response payloads should be ignored.
- setIgnoreExpressionFailures(boolean) - Method in class org.springframework.integration.handler.DelayHandler
-
- 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.
- setIgnoreJta(boolean) - Method in class org.springframework.integration.gemfire.store.GemfireMessageStore
-
- 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.
- setImplicit(boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setInboundHeaderNames(String[]) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Provide the header names that should be mapped from an HTTP request (for inbound adapters)
or HTTP response (for outbound adapters) to a Spring Integration Message's headers.
- setInboundMessageMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
-
- setInboundPrefix(String) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
-
Specify a prefix to be appended to the integration message header name
for any JMS property that is being mapped into the MessageHeaders.
- setInputChannel(MessageChannel) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setInputChannelName(String) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in interface org.springframework.integration.expression.IntegrationEvaluationContextAware
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Sets the evaluation context for evaluating the expression to get the from record of the
result set retrieved by the retrieving gateway.
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.transformer.ContentEnricher
-
- setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setInterceptorFactoryChain(TcpConnectionInterceptorFactoryChain) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Set the list of channel interceptors.
- setInterceptors(TcpConnectionInterceptorFactory[]) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorFactoryChain
-
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setInterceptors(ClientInterceptor...) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setIsFunction(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
Indicates whether a Stored Procedure or a Function is being executed.
- 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
-
A new Session
will be created with these properties (and the JavaMailAuthenticator if provided).
- setJavaMailProperties(Properties) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setJdbcCallOperationsCacheSize(int) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- setJdbcTemplate(JdbcOperations) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
The JdbcOperations
to use when interacting with the database.
- setJdbcTemplate(JdbcTemplate) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
The JdbcOperations
to use when interacting with the database.
- setJpaParameters(List<JpaParameter>) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setJpaQuery(String) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setJsonObjectMapper(JsonObjectMapper<?>) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
-
- setKey(String) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Specifies the key for the Redis store.
- setKeyExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Specifies a SpEL Expression to be used to determine the key for the Redis store.
- setKeyManager(KeyManager) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setKeysGenerated(boolean) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
-
Flag to indicate that the update query is an insert with autogenerated keys, which will be logged at debug level.
- setKeysGenerated(boolean) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
Flag to indicate that the update query is an insert with autogenerated keys, which will be logged at debug level.
- setKnownHosts(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Specifies the filename that will be used to create a host key repository.
- setLastModified(long) - Method in class org.springframework.integration.store.MessageGroupMetadata
-
- setLastModified(long) - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- setLastRead(long) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- setLastReleasedMessageSequenceNumber(int) - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Method not implemented.
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
-
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
-
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
-
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in interface org.springframework.integration.store.MessageGroupStore
-
Allows you to set the sequence number of the last released Message.
- setLastReleasedSequenceNumberForGroup(Object, int) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- setLengthCheck(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
-
- setLevel(LoggingHandler.Level) - Method in class org.springframework.integration.handler.LoggingHandler
-
- setListening(boolean) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setListening(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
- setLoadBalancingStrategy(LoadBalancingStrategy) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
-
- 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.
- setLobHandler(LobHandler) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Override the LobHandler
that is used to create and unpack large objects in SQL queries.
- setLocalAddress(String) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setLocalAddress(String) - Method in interface org.springframework.integration.ip.CommonSocketOptions
-
On a multi-homed system, specifies the ip address of the network interface used to communicate.
- setLocalAddress(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setLocalAddress(String) - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
Used on multi-homed systems to enforce the server to listen
on a specfic network address instead of all network adapters.
- setLocalAddress(String) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
- setLocalAddress(String) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setLocalDirectory(File) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- setLocalDirectory(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
- setLocalDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- setLocalFilenameGeneratorExpression(Expression) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- setLocalFilenameGeneratorExpression(Expression) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- setLocalFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
A
FileListFilter
used to determine which files will generate messages
after they have been synchronized.
- 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.
- setLockRegistry(LockRegistry) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setLockRegistry(LockRegistry) - Method in class org.springframework.integration.store.SimpleMessageStore
-
- setLoggerName(String) - Method in class org.springframework.integration.handler.LoggingHandler
-
- setLookupHost(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setLookupHost(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
If true, DNS reverse lookup is done on the remote ip address.
- setLookupHost(boolean) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setLookupHost(boolean) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
-
- setLookupHost(boolean) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- setMapKeyExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
-
Sets the expression used as the key for Map and Properties entries.
- setMapper(MethodArgsMessageMapper) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- setMapper(TcpMessageMapper) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- setMapToPayload(boolean) - Method in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
-
- setMarshaller(Marshaller) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
-
- setMaxConcurrentConsumers(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMaxConcurrentConsumers(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- 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.serializer.AbstractByteArraySerializer
-
The maximum supported message size for this serializer.
- setMaxMessagesPerPoll(long) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setMaxMessagesPerPoll(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
Set the maximum number of messages to receive for each poll.
- setMaxMessagesPerTask(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMaxMessagesPerTask(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setMaxNumberOfResults(int) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Set the max number of results to retrieve from the database.
- setMaxResultsExpression(Expression) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Sets the expression for maximum number of results expression.
- setMaxRowsPerPoll(Integer) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
The maximum number of rows to pull out of the query results per poll (if
greater than zero, otherwise all rows will be packed into the outgoing
message).
- setMaxRowsPerPoll(int) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
The maximum number of rows to pull out of the query results per poll (if
greater than zero, otherwise all rows will be packed into the outgoing
message).
- setMaxSubscribers(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setMaxSubscribers(int) - Method in class org.springframework.integration.channel.DirectChannel
-
Specify the maximum number of subscribers supported by the
channel's dispatcher.
- setMaxSubscribers(int) - Method in class org.springframework.integration.channel.ExecutorChannel
-
Specify the maximum number of subscribers supported by the
channel's dispatcher.
- setMaxSubscribers(int) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
-
Specify the maximum number of subscribers supported by the
channel's dispatcher.
- setMaxSubscribers(int) - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
-
Set the maximum subscribers allowed by this dispatcher.
- setMaxSubscribers(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMaxSubscribers(int) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
Specify the maximum number of subscribers supported by the
channel's dispatcher.
- setMaxSubscribers(int) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
Specify the maximum number of subscribers supported by the
channel's dispatcher.
- setMergeWithDefaultConverters(boolean) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Flag which determines if the default converters should be available after
custom converters.
- setMessage(Message<?>) - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
Set the request message (as an alternative to setPayload())
- setMessage(Message<?>) - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.core.MessagingTemplate
-
Set the
MessageConverter
that is to be used to convert
between Messages and objects for this template.
- 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.config.JmsChannelFactoryBean
-
- 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.
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- setMessageConverters(List<HttpMessageConverter<?>>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Set the message body converters to use.
- setMessageConverters(List<HttpMessageConverter<?>>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Set a list of HttpMessageConverter
s to be used by the underlying RestTemplate
.
- setMessageFactory(WebServiceMessageFactory) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setMessageGroupStore(MessageGroupStore) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
A message group store to expire according the other configurations.
- setMessageIdEnabled(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMessageProcessor(MessageProcessor<T>) - Method in class org.springframework.integration.transformer.HeaderEnricher
-
- setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setMessageRowMapper(MessageRowMapper) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
- setMessageSelector(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMessageSelector(String) - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
-
Specify a JMS Message Selector expression to use when receiving Messages.
- setMessageSelector(String) - Method in class org.springframework.integration.jms.PollableJmsChannel
-
- 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.AbstractCorrelatingMessageHandler
-
- setMessageStore(MessageGroupStore) - Method in class org.springframework.integration.handler.DelayHandler
-
Specify the
MessageGroupStore
that should be used to store Messages
while awaiting the delay.
- setMessageTimestampEnabled(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setMetadataStore(MetadataStore) - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
-
- setMethod(Method) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
-
- setMethodMetadataMap(Map<String, GatewayMethodMetadata>) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setMethodName(String) - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
-
- setMethods(HttpMethod...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setMinAcksForSuccess(int) - Method in class org.springframework.integration.ip.udp.MulticastSendingMessageHandler
-
If acknowledge = true; how many acks needed for success.
- setMinimumTimeoutForEmptyGroups(long) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
By default, when a MessageGroupStoreReaper is configured to expire partial
groups, empty groups are also removed.
- setMinSubscribers(int) - Method in class org.springframework.integration.channel.PublishSubscribeChannel
-
- setMinSubscribers(int) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
-
- setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
Allows you to provide a custom MongoConverter
used to assist in deserialization
data read from MongoDb.
- setMongoConverter(MongoConverter) - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
-
Allows you to provide custom MongoConverter
used to assist in serialization
of data written to MongoDb.
- setMputFilter(FileListFilter<File>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- setMultipartFileReader(MultipartFileReader<?>) - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
-
- setMultipartResolver(MultipartResolver) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Specify the MultipartResolver
to use when checking requests.
- setName(String) - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
- setName(String) - Method in class org.springframework.integration.jpa.support.JpaParameter
-
- setName(String) - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- setName(String) - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
-
- setName(String) - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
set the scenario name (optional)
- setNamedQuery(String) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
A named query can either refer to a named JPQL based query or a native SQL
query.
- setNativeOptions(String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setNativeQuery(String) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
You can also use native Sql queries to poll data from the database.
- setNeedClientAuth(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setNioConnectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
Rare property - not exposed through namespace
- setNioHarvestInterval(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
How often we clean up closed NIO connections if soTimeout is 0.
- setNodeMapper(NodeMapper<?>) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
-
Set a NodeMapper
to use for generating the result object.
- setNoReadErrorOnClose(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- 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.endpoint.MethodInvokingMessageSource
-
- setObjectMapper(ObjectMapper) - Method in class org.springframework.integration.json.JsonPropertyAccessor
-
- 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 ObjectNames (or patterns)
of the notification publisher
to which this notification listener should be subscribed.
- setObjectName(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.
- setObjectNameStaticProperties(Map<String, String>) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
Static properties that will be added to all object names.
- setOffendingJPAQl(String) - Method in exception org.springframework.integration.jpa.core.JpaOperationFailedException
-
- setOnFailureExpression(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
- setOnSuccessExpression(String) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
- setOperationName(String) - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
-
Specify an operation name to be invoked when no such
header is available on the Message being handled.
- setOptions(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- setOptions(String) - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
-
- setOrder(int) - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
-
- setOrder(int) - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
-
- setOrder(Integer) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- setOrder(int) - Method in interface org.springframework.integration.context.Orderable
-
Set the order for this component.
- setOrder(int) - Method in class org.springframework.integration.handler.AbstractMessageHandler
-
- setOrder(int) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- setOutboundHeaderNames(String[]) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Provide the header names that should be mapped to an HTTP request (for outbound adapters)
or HTTP response (for inbound adapters) from a Spring Integration Message's headers.
- setOutboundMessageMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
-
- setOutboundPrefix(String) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
-
Specify a prefix to be appended to the JMS property name for any
integration message header that is being mapped into the JMS Message.
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
-
- 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
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setOutputProperties(Properties) - Method in class org.springframework.integration.xml.transformer.ResultToStringTransformer
-
- setPacketDeserializer(Deserializer<byte[]>) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
-
A Deserializer
that will construct the full JSON content from
the stream which is then passed to the JsonObjectMapper.
- setPacketSerializer(Serializer<byte[]>) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
-
A Serializer
that will delimit the full JSON content in
the stream.
- setParameterExpressions(Map<String, String>) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
-
Optionally maps parameter names to explicit expressions.
- setParameters(List<JpaParameter>) - Method in class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
-
Define the (optional) parameter values.
- setParameterSource(ParameterSource) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
Specifies the
ParameterSource
that would be used to provide
additional parameters.
- setParameterSourceFactory(ParameterSourceFactory) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setParams(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setParserConfiguration(SpelParserConfiguration) - Method in class org.springframework.integration.config.ExpressionFactoryBean
-
- setPassword(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setPassword(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
The password to authenticate against the remote host.
- setPassword(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setPath(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
- setPathPatterns(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setPattern(Pattern) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
-
- setPattern(String) - Method in class org.springframework.integration.file.filters.AbstractRegexPatternFileListFilter
-
- setPatternMatch(boolean) - Method in class org.springframework.integration.transformer.HeaderFilter
-
- setPatternResolver(ResourcePatternResolver) - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
-
- setPatterns(String[]) - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
-
- setPayload(Object) - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
set the payload of the request message
- setPayloadExpression(String) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
-
- setPayloadExpression(String) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
-
- setPayloadExpression(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- setPayloadExpression(Expression) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Specifies a SpEL expression to evaluate in order to generate the Message payload.
- setPersistMode(PersistMode) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setPhase(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- setPhase(int) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
- setPhase(int) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- setPhase(int) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- setPhase(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setPhase(int) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
- setPhase(int) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setPipeTimeout(long) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- setPollerMetadata(PollerMetadata) - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
-
- setPollerMetadata(PollerMetadata) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setPollingDelay(long) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
-
The delay between checks of the file for new content in milliseconds.
- setPoolSize(int) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
-
Modify the target session pool size; the actual pool size will adjust up/down
to this size as and when sessions are requested or retrieved.
- setPoolSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setPoolSize(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setPoolSize(int) - Method in class org.springframework.integration.util.SimplePool
-
Adjusts the current pool size.
- setPort(int) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setPort(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setPort(int) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
The port over which the SFTP connection shall be established.
- setPort(int) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setPort(int) - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
-
Sets the port on which the adapter listens; default is 514; note that
the RFC does not specify a well known port for TCP; 514 is the well-known
port for UDP.
- setPostProcessWithinAdvice(boolean) - Method in class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
-
Specify whether the post processing should occur within
the scope of any configured advice classes.
- setPrefetchCount(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setPrefix(String) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
-
Specify the prefix to use for temporary files.
- setPrefix(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Specify a prefix to be added to each channel name prior to resolution.
- setPreserveTimestamp(boolean) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- setPreventDuplicates(Boolean) - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
-
- setPriority(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setPriority(int) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Specify the JMS priority to use when sending request Messages.
- setPriority(Integer) - Method in class org.springframework.integration.support.MessageBuilder
-
- setPrivateKey(Resource) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Allows you to set a Resource
, which represents the location of the
private key used for authenticating against the remote host.
- setPrivateKeyPassphrase(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
The password for the private key.
- setProcedureParameters(List<ProcedureParameter>) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
Custom Stored Procedure parameters that may contain static values
or Strings representing an Expression
.
- setProduces(String...) - Method in class org.springframework.integration.http.inbound.RequestMapping
-
- setProducesReply(boolean) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
-
If set to 'false', this component will act as an Outbound Channel Adapter.
- setProducesReply(boolean) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- setPropagateEvaluationFailures(boolean) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
If true and an onSuccess expression evaluation fails with an exception, the exception will be thrown to the
caller.
- setPropertiesPersister(PropertiesPersister) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set the PropertiesPersister to use for parsing properties files.
- setPropertyAccessors(Map<String, PropertyAccessor>) - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
-
- setPropertyExpressions(Map<String, Expression>) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Provide the map of expressions to evaluate when enriching the target payload.
- setProt(String) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setProtocol(String) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setProtocol(String) - Method in class org.springframework.integration.ip.tcp.connection.DefaultTcpSSLContextSupport
-
The protocol used in SSLContext.getInstance(String)
; default "TLS".
- setProtocol(String) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- setProtocol(String) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setProtocols(String[]) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setProxy(Proxy) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Allows for specifying a JSch-based Proxy
.
- setPublisherMetadataSource(PublisherMetadataSource) - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
-
- setPubSub(boolean) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setPubSubDomain(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setPubSubNoLocal(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setQuery(String) - Method in class org.springframework.integration.twitter.inbound.SearchReceivingMessageSource
-
- setQueryExpression(String) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
-
- setQueryExpressionReference(QueryExp) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
-
- setQueryName(String) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
-
- setQueryName(String) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
-
- setQueryNameReference(ObjectName) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
-
- setQueueName(String) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
-
Provide a Queue name to be used.
- setQueueName(String) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
-
Provide an explicitly configured queue name.
- setQueueName(String) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
Set the Queue name to use.
- setQueueSize(Integer) - Method in class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
-
- setReaperDelay(long) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
Set the reaper delay.
- setReceiveBufferSize(int) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setReceiveTimeout(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setReceiveTimeout(long) - Method in class org.springframework.integration.core.MessagingTemplate
-
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.config.JmsChannelFactoryBean
-
- setReceiveTimeout(Long) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- 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.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- setReceiveTimeout(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setRecipients(List<RecipientListRouter.Recipient>) - Method in class org.springframework.integration.router.RecipientListRouter
-
Set the recipients for this router.
- setRecoveryCallback(RecoveryCallback<Object>) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- setRecoveryInterval(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setRecoveryInterval(long) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setRecoveryInterval(Long) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setRecoveryInterval(long) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Configures the provided bean definition builder with a property reference to a bean.
- setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Configures the provided bean definition builder with a property reference to a bean.
- setReferenceIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
- setRegion(String) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
A unique grouping identifier for all messages persisted with this store.
- setRegion(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
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.AbstractCorrelatingMessageHandler
-
- setReleasePartialSequences(boolean) - Method in class org.springframework.integration.aggregator.SequenceSizeReleaseStrategy
-
Flag that determines if partial sequences are allowed.
- setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setReleaseStrategy(ReleaseStrategy) - Method in class org.springframework.integration.aggregator.CorrelatingMessageBarrier
-
Set the ReleaseStrategy that should be used when deciding if a group in this barrier may be released.
- setReliabilityAttributes(boolean, boolean, String, int, int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setRemoteDirectory(String) - Method in class org.springframework.integration.file.remote.AbstractFileInfo
-
- setRemoteDirectory(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Specify the full path to the remote directory.
- setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
- setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
- setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- setRemoteFileSeparator(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- setRemoteInvocationExecutor(RemoteInvocationExecutor) - Method in class org.springframework.integration.rmi.RmiInboundGateway
-
- setRemoteTimeout(long) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- setRemoveMessage(boolean) - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
-
- setRenameExpression(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- setReopen(Boolean) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setReopen(boolean) - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
-
If true, close and reopen the file between reading chunks;
default false.
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set the reply channel.
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
Specify the Spring Integration reply channel.
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Specify the Spring Integration reply channel.
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.rmi.RmiOutboundGateway
-
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.support.MessageBuilder
-
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Sets the content enricher's reply channel.
- setReplyChannel(MessageChannel) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
- setReplyChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- setReplyChannelName(String) - Method in class org.springframework.integration.support.MessageBuilder
-
- setReplyContainerProperties(JmsOutboundGateway.ReplyContainerProperties) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- 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.
- setReplyDestinationExpression(Expression) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the SpEL Expression to be used for determining the reply Destination instance
or reply destination name.
- setReplyDestinationName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the name of the JMS Destination from which reply Messages should be received.
- setReplyHeaderNames(String[]) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
Provide the header names that should be mapped to a response (for inbound/outbound adapters)
FROM a Spring Integration Message's headers.
- setReplyKey(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
- setReplyMapper(OutboundMessageMapper<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Provide an
OutboundMessageMapper
for mapping to objects from
any reply Messages received in receive or sendAndReceive operations.
- setReplyPriority(int) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
Specify the priority value for JMS reply Messages.
- setReplyPubSubDomain(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Specify whether the reply destination is a Topic.
- setReplySqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
- setReplyTimeout(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- setReplyTimeout(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set the timeout value for receiving reply messages.
- setReplyTimeout(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setReplyTimeout(long) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
Specifies the time the gateway will wait to send the result to the reply channel.
- setReplyTimeout(Long) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Set the timeout value for receiving reply messages.
- 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.MessagingGatewaySupport
-
Set the request channel.
- setRequestChannel(MessageChannel) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- 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.transformer.ContentEnricher
-
Sets the content enricher's request channel.
- setRequestChannelName(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- setRequestDestination(Destination) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the JMS Destination to which request Messages should be sent.
- setRequestDestinationExpression(Expression) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the SpEL Expression to be used for determining the request Destination instance
or request destination name.
- setRequestDestinationName(String) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Set the name of the JMS Destination to which request Messages should be sent.
- setRequestFactory(ClientHttpRequestFactory) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Set the ClientHttpRequestFactory
for the underlying RestTemplate
.
- setRequestHeaderNames(String[]) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
Provide the header names that should be mapped from a request (for inbound/outbound adapters)
TO a Spring Integration Message's headers.
- setRequestMapper(InboundMessageMapper<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Provide an
InboundMessageMapper
for creating request Messages
from any object passed in a send or sendAndReceive operation.
- setRequestMapping(RequestMapping) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Set the
RequestMapping
which allows you to specify a flexible RESTFul-mapping for this endpoint.
- setRequestPayloadExpression(Expression) - Method in class org.springframework.integration.transformer.ContentEnricher
-
By default the original message's payload will be used as the actual payload
that will be send to the request-channel.
- setRequestPayloadType(Class<?>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Specify the type of payload to be generated when the inbound HTTP request content is read by the
HttpMessageConverter
s.
- setRequestPubSubDomain(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Specify whether the request destination is a Topic.
- setRequestSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
- setRequestTimeout(String) - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
-
- setRequestTimeout(long) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Set the timeout value for sending request messages.
- setRequestTimeout(long) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- setRequestTimeout(long) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setRequestTimeout(Long) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Set the timeout value for sending request messages.
- setRequiresReply(Boolean) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- setRequiresReply(boolean) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- setRequiresReply(Boolean) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setRequiresReply(boolean) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
Flag whether a reply is required.
- setRequiresReply(boolean) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- setResolutionRequired(Boolean) - Method in class org.springframework.integration.config.RouterFactoryBean
-
- setResolutionRequired(boolean) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Specify whether this router should ignore any failure to resolve a channel name to
an actual MessageChannel instance when delegating to the ChannelResolver strategy.
- setResource(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setResourceLoader(ResourceLoader) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
-
Set the ResourceLoader to use for loading bundle properties files.
- setResponseValidator(AbstractResponseValidator<?>) - Method in class org.springframework.integration.test.support.RequestResponseScenario
-
Set the response validator
- setResultFactory(ResultFactory) - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
-
- setResultFactory(ResultFactory) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
Sets the ResultFactory
- setRetryInterval(long) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
- setRetryInterval(long) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
-
- setRetryInterval(long) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- setRetryStateGenerator(RetryStateGenerator) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
-
- setReturnChannel(MessageChannel) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- setReturnFailureExpressionResult(boolean) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
If true, the result of evaluating the onFailureExpression will
be returned as the result of AbstractReplyProducingMessageHandler.handleRequestMessage(Message).
- setReturningResultSetRowMappers(Map<String, RowMapper<?>>) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
If the Stored Procedure returns ResultSets you may provide a map of
RowMapper
to convert the ResultSet
to meaningful objects.
- setReturnValueRequired(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
Indicates the procedure's return value should be included in the results
returned.
- setRoutingKey(String) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- setRoutingKeyExpression(String) - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
-
- setRowMapper(RowMapper<?>) - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
-
- 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
-
- setSearchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setSearchTermStrategy(SearchTermStrategy) - Method in class org.springframework.integration.mail.ImapMailReceiver
-
Provides a way to set custom
SearchTermStrategy
to compile a
SearchTerm
to be applied when retrieving mail
- setSelectorExpression(Expression) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
- setSelectorExpression(Expression) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setSelectors(List<MessageSelector>) - Method in class org.springframework.integration.selector.MessageSelectorChain
-
Initialize the selector chain.
- setSelectSqlParameterSource(SqlParameterSource) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
A source of parameters for the select query used for polling.
- setSendingTaskExecutor(Executor) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
Specify an Executor
used to send messages received by the
adapter.
- setSendPartialResultOnExpiry(boolean) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setSendTimeout(long) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
-
- setSendTimeout(long) - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
-
- setSendTimeout(Long) - Method in class org.springframework.integration.config.ExpressionControlBusFactoryBean
-
- setSendTimeout(Long) - Method in class org.springframework.integration.config.FilterFactoryBean
-
- setSendTimeout(Long) - Method in class org.springframework.integration.config.ServiceActivatorFactoryBean
-
- setSendTimeout(long) - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
-
- setSendTimeout(Long) - Method in class org.springframework.integration.config.SplitterFactoryBean
-
- setSendTimeout(Long) - Method in class org.springframework.integration.config.TransformerFactoryBean
-
- setSendTimeout(long) - Method in class org.springframework.integration.core.MessagingTemplate
-
Specify the timeout value to use for send operations.
- 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.groovy.config.GroovyControlBusFactoryBean
-
- 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.advice.ErrorMessageSendingRecoverer
-
- setSendTimeout(long) - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- setSendTimeout(long) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- setSendTimeout(long) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setSendTimeout(long) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setSequenceNumber(Integer) - Method in class org.springframework.integration.support.MessageBuilder
-
- setSequenceSize(Integer) - Method in class org.springframework.integration.support.MessageBuilder
-
- setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- setSerializer(Serializer<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- setSerializer(Serializer<? super Message<?>>) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
A converter for serializing messages to byte arrays for storage.
- setSerializer(Serializer<? super Message<?>>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
A converter for serializing messages to byte arrays for storage.
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
-
- setSerializer(Serializer<Object>) - Method in class org.springframework.integration.transformer.PayloadSerializingTransformer
-
- setServer(MBeanServerConnection) - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
-
Provide the MBeanServer where the JMX MBean has been registered.
- setServer(MBeanServerConnection) - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
-
Provide the MBeanServer where the JMX MBean has been registered.
- setServer(MBeanServerConnection) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
Provide a reference to the MBeanServer where the notification
publishing MBeans are registered.
- setServer(MBeanServerConnection) - 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.
- setServerAliveCountMax(Integer) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Specifies the number of server-alive messages, which will be sent without
any reply from the server before disconnecting.
- setServerAliveInterval(Integer) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Sets the timeout interval (milliseconds) before a server alive message is
sent, in case no message is received from the server.
- setServiceInterface(Class<?>) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
Set the interface class that the generated proxy should implement.
- setSession(Session) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Set the Session
.
- setSession(Session) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setSessionAcknowledgeMode(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setSessionAcknowledgeMode(Integer) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setSessionConfig(Properties) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Using Properties
, you can set additional configuration settings on
the underlying JSch Session
.
- setSessionCreation(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setSessionTransacted(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setSessionTransacted(Boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setSessionWaitTimeout(long) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
-
Sets the limit of how long to wait for a session to become available.
- setShouldAppendNewLine(boolean) - Method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
-
- setShouldClonePayload(boolean) - Method in class org.springframework.integration.transformer.ContentEnricher
-
Specify whether to clone payload objects to create the target object.
- setShouldDeleteMessages(boolean) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Specify whether mail messages should be deleted after retrieval.
- setShouldDeleteMessages(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setShouldExtractPayload(boolean) - Method in class org.springframework.integration.support.json.JsonOutboundMessageMapper
-
- setShouldFlattenKeys(boolean) - Method in class org.springframework.integration.transformer.ObjectToMapTransformer
-
- setShouldLogFullMessage(boolean) - Method in class org.springframework.integration.handler.LoggingHandler
-
Specify whether to log the full Message.
- setShouldMarkMessagesAsRead(Boolean) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setShouldMarkMessagesAsRead(Boolean) - Method in class org.springframework.integration.mail.ImapMailReceiver
-
Specify if messages should be marked as read.
- 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.
- setShouldSkipNulls(boolean) - Method in class org.springframework.integration.transformer.HeaderEnricher
-
Specify whether null
values, such as might be returned from
an expression evaluation, should be skipped.
- setShouldTrack(boolean) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
- setShouldTrack(boolean) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
- setShouldTrack(boolean) - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
-
Specify whether this component should be tracked in the Message History.
- setShouldTrack(boolean) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setShouldTrack(boolean) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Specify whether this gateway should be tracked in the Message History
of Messages that originate from its send or sendAndReceive operations.
- setShouldTrack(boolean) - Method in class org.springframework.integration.handler.AbstractMessageHandler
-
- setShouldTrack(boolean) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
-
- setShouldTrack(boolean) - Method in interface org.springframework.integration.history.TrackableComponent
-
- setShouldTrack(boolean) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- setShouldTruncate(boolean) - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
-
- setShutdownExecutor(Executor) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- setShutdownTimeout(long) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setSingleUse(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSingleUse(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
If true, sockets created by this factory will be used once.
- setSingleUse(boolean) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSingleUse(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
- setSingleUse(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
-
- setSkipUndeclaredResults(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
If this variable is set to true
then all results from a stored
procedure call that don't have a corresponding SqlOutParameter
declaration will be bypassed.
- setSocket(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- setSocket(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setSocketAttributes(Socket) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Sets socket attributes on the socket.
- setSocketAttributes(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
Sets timeout and receive buffer size
- setSocketAttributes(DatagramSocket) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setSocketFactory(SocketFactory) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Allows you to pass in a SocketFactory
.
- setSocketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSocketSupport(TcpSocketSupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoKeepAlive(boolean) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSoLinger(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSoLinger(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoLinger(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- 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.config.TcpConnectionFactoryFactoryBean
-
- setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSoReceiveBufferSize(int) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- 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.config.TcpConnectionFactoryFactoryBean
-
- setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSoSendBufferSize(int) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
-
- setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoTcpNoDelay(boolean) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- 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.config.TcpConnectionFactoryFactoryBean
-
- setSoTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoTimeout(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setSoTrafficClass(int) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setSoTrafficClass(int) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setSoTrafficClass(int) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- 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.
- setSource(String) - Method in class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- setSource(String) - Method in class org.springframework.integration.monitor.SimpleMessageSourceMetrics
-
- setSourceFactory(SourceFactory) - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
-
Provide the SourceFactory to be used.
- setSourceFactory(SourceFactory) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
Sets the SourceFactory.
- setSqlParameters(List<SqlParameter>) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
If you database system is not fully supported by Spring and thus obtaining
parameter definitions from the JDBC Meta-data is not possible, you must define
the SqlParameter
explicitly.
- setSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
-
- setSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- setSslContextSupport(TcpSSLContextSupport) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setStaticParameters(Map<String, Object>) - Method in class org.springframework.integration.jdbc.BeanPropertySqlParameterSourceFactory
-
If the input is a List or a Map, the output is a map parameter source, and in that case some static parameters
can be added (default is empty).
- setStaticParameters(Map<String, ?>) - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
-
Define some static parameter values.
- setStaticParameters(Map<String, Object>) - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSourceFactory
-
If the input is a List or a Map, the output is a map parameter source, and in that case some static parameters
can be added (default is empty).
- setStoredProcedureName(String) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
The name of the Stored Procedure or Stored Function to be executed.
- setStoredProcedureNameExpression(Expression) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
- setStoreUri(String) - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
-
- setStringToBytes(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
Sets whether outbound String payloads are to be converted
to byte[].
- setSubscriptionDurable(boolean) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setSubscriptionMode(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setSuccessChannel(MessageChannel) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
- setSuffix(String) - Method in class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
-
Specify the suffix to use for temporary files.
- setSuffix(String) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
-
Specify a suffix to be added to each channel name prior to resolution.
- setSupportedEventTypes(EventType...) - Method in class org.springframework.integration.gemfire.inbound.CacheListeningMessageProducer
-
- setSupportedEventTypes(CqEventType...) - Method in class org.springframework.integration.gemfire.inbound.ContinuousQueryMessageProducer
-
- setSupportedMethods(HttpMethod...) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
- setTablePrefix(String) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
-
Public setter for the table prefix property.
- setTablePrefix(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Public setter for the table prefix property.
- setTailAttemptsDelay(long) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
The delay in milliseconds between attempts to tail a non-existent file,
or between attempts to execute a process if it fails for any reason.
- setTaskExecutor(Executor) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
A task executor; default is a SimpleAsyncTaskExecutor
.
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
-
- setTaskExecutor(Executor) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- 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.file.config.FileTailInboundChannelAdapterFactoryBean
-
- setTaskScheduler(TaskScheduler) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- setTcpNioConnectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
- setTcpNioConnectionSupport(TcpNioConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
- setTcpSocketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
-
- setTcpSocketFactorySupport(TcpSocketFactorySupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
-
- setTcpSocketSupport(TcpSocketSupport) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- setTemporaryDirectory(File) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
Deprecated.
This property is no longer used; byte[] and String payloads are written directly
- setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
-
- setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.FileWritingMessageHandler
-
By default, every file that is in the process of being transferred will
appear in the file system with an additional suffix, which by default is
".writing".
- setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
- setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
- setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- setTemporaryFileSuffix(String) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- setTemporaryRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
- setTemporaryRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- setTheConnection(TcpConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
-
- setTheConnection(TcpConnectionSupport) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
-
Sets the underlying connection (or next interceptor)
- setThreshold(int) - Method in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
-
- setThrowExceptionOnLateReply(boolean) - Method in class org.springframework.integration.core.MessagingTemplate
-
Specify whether or not an attempt to send on the reply channel throws an exception
if no receiving thread will actually receive the reply.
- setThrowExceptionOnRejection(Boolean) - Method in class org.springframework.integration.config.FilterFactoryBean
-
- setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.filter.MessageFilter
-
- setThrowExceptionOnRejection(boolean) - Method in class org.springframework.integration.xml.selector.XmlValidatingMessageSelector
-
- 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(Integer) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
The timeout property is used as the socket timeout parameter, as well as
the default connection timeout.
- setTimeout(long) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
Timeout in milliseconds (default -1).
- setTimeoutOnIdle(boolean) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
Allows you to override the rule for the timeout calculation.
- 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.config.JmsChannelFactoryBean
-
- setTimeToLive(long) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
Specify the timeToLive for each sent Message.
- setTopic(String) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- setTopicExpression(Expression) - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
-
- setTopicPatterns(String...) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- setTopics(String...) - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
-
- setTrackableComponent(TrackableComponent) - Method in class org.springframework.integration.history.HistoryWritingMessagePostProcessor
-
- setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setTransactionName(String) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setTransactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setTransactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
-
- setTransactionSynchronizationFactory(TransactionSynchronizationFactory) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setTransactionTimeout(int) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- setTransferCookies(boolean) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Set to true if you wish 'Set-Cookie' headers in responses to be
transferred as 'Cookie' headers in subsequent interactions for
a message.
- setTransformOnSend(boolean) - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
-
Deprecated.
- setTrapException(boolean) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
-
If true, any exception will be caught and null returned.
- setTrigger(Trigger) - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
- setTrigger(Trigger) - Method in class org.springframework.integration.scheduling.PollerMetadata
-
- setTrustManager(TrustManager) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setTxAdviceChain(List<Advice>) - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGatewayFactoryBean
-
- setTxSize(int) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- setType(String) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setTypeConverter(TypeConverter) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
-
- setUdpAdapter(UnicastReceivingChannelAdapter) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- setUdpAdapter(UnicastReceivingChannelAdapter) - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
-
- setUnmarshaller(Unmarshaller) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
-
- setUp() - Method in class org.springframework.integration.test.support.AbstractRequestResponseScenarioTests
-
- 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
-
- setUpdateSqlParameterSourceFactory(SqlParameterSourceFactory) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
- setupResponseAndConvertReply(ServletServerHttpResponse, Message<?>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Converts the reply message to the appropriate HTTP reply object and
sets up the ServletServerHttpResponse
.
- setUriVariableExpressions(Map<String, Expression>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Set the Map of URI variable expressions to evaluate against the outbound message
when replacing the variable placeholders in a URI template.
- setUriVariableExpressions(Map<String, Expression>) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
-
Set the Map of URI variable expressions to evaluate against the outbound message
when replacing the variable placeholders in a URI template.
- setUriVariablesExpression(Expression) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
-
Set the Expression
to evaluate against the outbound message; the expression
must evaluate to a Map of URI variable expressions to evaluate against the outbound message
when replacing the variable placeholders in a URI template.
- setUseClientMode(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setUsePayloadAsParameterSource(boolean) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
-
If set to 'true', the payload of the Message will be used as a source for
providing parameters.
- setUsePayloadAsParameterSource(Boolean) - Method in class org.springframework.integration.jpa.core.JpaExecutor
-
- setUser(String) - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
The remote user to use.
- setUser(String) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- setUserDefinedHeaderPrefix(String) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
-
Sets the prefix to use with user-defined (non-standard) headers.
- setUserDefinedHeaderPrefix(String) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
-
Specify a prefix to be prepended to the header name for any integration
message header that is being mapped to or from a user-defined value.
- setUseReplyContainer(boolean) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- setUsername(String) - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
-
- setUseTemporaryFileName(boolean) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
- setUseTemporaryFileName(boolean) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
-
- setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
When set to true, connections created by this factory attempt
to use direct buffers where possible.
- setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
-
If true, connection will attempt to use direct buffers where
possible.
- setUsingDirectBuffers(boolean) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
-
- setUsingIdCache(boolean) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Consider using this property when polling the database transactionally
using multiple parallel threads, meaning when the configured poller is configured
using a task executor.
- setUsingNio(boolean) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- setValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
-
- setValue(Object, Object) - Method in class org.springframework.integration.expression.DynamicExpression
-
- setValue(EvaluationContext, Object, Object) - Method in class org.springframework.integration.expression.DynamicExpression
-
- setValue(Object) - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
-
- setValue(Object) - Method in class org.springframework.integration.jpa.support.JpaParameter
-
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Configures the provided bean definition builder with a property value corresponding to the attribute whose name
is provided if that attribute is defined in the given element.
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Configures the provided bean definition builder with a property value corresponding to the attribute whose name
is provided if that attribute is defined in the given element.
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Configures the provided bean definition builder with a property value corresponding to the attribute whose name
is provided if that attribute is defined in the given element.
- setValueIfAttributeDefined(BeanDefinitionBuilder, Element, String, boolean) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
-
Configures the provided bean definition builder with a property value corresponding to the attribute whose name
is provided if that attribute is defined in the given element.
- setValueSerializer(RedisSerializer<?>) - Method in class org.springframework.integration.redis.store.RedisMessageStore
-
- setViewExpression(Expression) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
Specifies a SpEL expression to evaluate in order to generate the view name.
- setViewName(String) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
Specify the view name.
- setVotingStrategy(MessageSelectorChain.VotingStrategy) - Method in class org.springframework.integration.selector.MessageSelectorChain
-
Specify the voting strategy for this selector chain.
- setWaitTimeout(long) - Method in class org.springframework.integration.util.SimplePool
-
Adjusts the wait timeout - the time for which getItem() will wait if no idle
entries are available.
- setWantsClientAuth(Boolean) - Method in class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
-
- setXmlPayloadConverter(XmlPayloadConverter) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
-
- setXslParameterMappings(Map<String, Expression>) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
- setXsltParamHeaders(String[]) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
-
- SEVERITY - Static variable in class org.springframework.integration.syslog.SyslogHeaders
-
- SEVERITY - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
-
- SftpFileInfo - Class in org.springframework.integration.sftp.session
-
- SftpFileInfo(ChannelSftp.LsEntry) - Constructor for class org.springframework.integration.sftp.session.SftpFileInfo
-
- SftpInboundChannelAdapterParser - Class in org.springframework.integration.sftp.config
-
Parser for 'sftp:inbound-channel-adapter'
- SftpInboundChannelAdapterParser() - Constructor for class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
-
- SftpInboundFileSynchronizer - Class in org.springframework.integration.sftp.inbound
-
Handles the synchronization between a remote SFTP directory and a local mount.
- SftpInboundFileSynchronizer(SessionFactory<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
-
- SftpInboundFileSynchronizingMessageSource - Class in org.springframework.integration.sftp.inbound
-
A
MessageSource
implementation for SFTP
that delegates to an InboundFileSynchronizer.
- SftpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<ChannelSftp.LsEntry>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
-
- SftpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<ChannelSftp.LsEntry>, Comparator<File>) - Constructor for class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
-
- SftpNamespaceHandler - Class in org.springframework.integration.sftp.config
-
Provides namespace support for using SFTP.
- SftpNamespaceHandler() - Constructor for class org.springframework.integration.sftp.config.SftpNamespaceHandler
-
- SftpOutboundGateway - Class in org.springframework.integration.sftp.gateway
-
Outbound Gateway for performing remote file operations via SFTP.
- SftpOutboundGateway(SessionFactory<ChannelSftp.LsEntry>, String, String) - Constructor for class org.springframework.integration.sftp.gateway.SftpOutboundGateway
-
- SftpOutboundGatewayParser - Class in org.springframework.integration.sftp.config
-
- SftpOutboundGatewayParser() - Constructor for class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
-
- SftpPersistentAcceptOnceFileListFilter - Class in org.springframework.integration.sftp.filters
-
Since the super class deems files as 'not seen' if the timestamp is different, remote file
users should use the adapter's preserve-timestamp option.
- SftpPersistentAcceptOnceFileListFilter(MetadataStore, String) - Constructor for class org.springframework.integration.sftp.filters.SftpPersistentAcceptOnceFileListFilter
-
- SftpRegexPatternFileListFilter - Class in org.springframework.integration.sftp.filters
-
- SftpRegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
-
- SftpRegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
-
- SftpSimplePatternFileListFilter - Class in org.springframework.integration.sftp.filters
-
- SftpSimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.sftp.filters.SftpSimplePatternFileListFilter
-
- SharedSessionCapable - Interface in org.springframework.integration.file.remote.session
-
A
SessionFactory
that implements this interface is capable of supporting a shared session.
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.filter.MessageFilter
-
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
-
Subclasses may override this.
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
-
- shouldCreateEndpoint(T) - Method in class org.springframework.integration.config.annotation.AbstractMethodAnnotationPostProcessor
-
- shouldDeleteMessages() - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Indicates whether the mail messages should be deleted after being received.
- shouldGenerateId() - Method in class org.springframework.integration.config.xml.MessageHistoryParser
-
- 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.jdbc.config.StoredProcMessageHandlerParser
-
- shouldGenerateId() - Method in class org.springframework.integration.jdbc.config.StoredProcPollingChannelAdapterParser
-
- 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.jpa.config.xml.JpaOutboundChannelAdapterParser
-
- shouldGenerateId() - Method in class org.springframework.integration.security.config.SecuredChannelsParser
-
- shouldGenerateId() - Method in class org.springframework.integration.xml.config.XPathExpressionParser
-
- shouldGenerateId() - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.config.xml.GatewayParser
-
- 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.jdbc.config.StoredProcMessageHandlerParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jdbc.config.StoredProcPollingChannelAdapterParser
-
- 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.jmx.config.AttributePollingChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.MBeanTreePollingChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.NotificationPublishingChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jmx.config.OperationInvokingChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.jpa.config.xml.JpaOutboundChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.scripting.config.AbstractScriptParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xml.config.XPathExpressionParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
-
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.xmpp.config.XmppConnectionParser
-
- shutDown() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
-
Deprecated.
Use stop() instead.
- SI_USER_FLAG - Static variable in class org.springframework.integration.mail.AbstractMailReceiver
-
- SIMPLE_CALLBACK - Static variable in class org.springframework.integration.expression.ExpressionEvalMap
-
- SimpleMessageConverter - Class in org.springframework.integration.support.converter
-
- SimpleMessageConverter() - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
-
- SimpleMessageConverter(InboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
-
- SimpleMessageConverter(OutboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
-
- SimpleMessageConverter(InboundMessageMapper<?>, OutboundMessageMapper<?>) - Constructor for class org.springframework.integration.support.converter.SimpleMessageConverter
-
- SimpleMessageGroup - Class in org.springframework.integration.store
-
Represents a mutable group of correlated messages that is bound to a certain
MessageStore
and group id.
- SimpleMessageGroup(Object) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
-
- SimpleMessageGroup(Collection<? extends Message<?>>, Object) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
-
- SimpleMessageGroup(Collection<? extends Message<?>>, Object, long, boolean) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
-
- SimpleMessageGroup(MessageGroup) - Constructor for class org.springframework.integration.store.SimpleMessageGroup
-
- SimpleMessageHandlerMetrics - Class in org.springframework.integration.monitor
-
- SimpleMessageHandlerMetrics(MessageHandler) - Constructor for class org.springframework.integration.monitor.SimpleMessageHandlerMetrics
-
- SimpleMessageSourceMetrics - Class in org.springframework.integration.monitor
-
- SimpleMessageSourceMetrics(MessageSource<?>) - Constructor for class org.springframework.integration.monitor.SimpleMessageSourceMetrics
-
- SimpleMessageStore - Class in org.springframework.integration.store
-
- SimpleMessageStore(int, int) - Constructor for class org.springframework.integration.store.SimpleMessageStore
-
Creates a SimpleMessageStore with a maximum size limited by the given capacity, or unlimited size if the given
capacity is less than 1.
- SimpleMessageStore(int, int, LockRegistry) - Constructor for class org.springframework.integration.store.SimpleMessageStore
-
- SimpleMessageStore(int) - Constructor for class org.springframework.integration.store.SimpleMessageStore
-
Creates a SimpleMessageStore with the same capacity for individual and grouped messages.
- SimpleMessageStore() - Constructor for class org.springframework.integration.store.SimpleMessageStore
-
Creates a SimpleMessageStore with unlimited capacity
- SimpleMetadataStore - Class in org.springframework.integration.metadata
-
Simple implementation of
MetadataStore
that uses an in-memory map only.
- SimpleMetadataStore() - Constructor for class org.springframework.integration.metadata.SimpleMetadataStore
-
- SimpleMultipartFileReader - Class in org.springframework.integration.http.multipart
-
MultipartFileReader
implementation that does not maintain metadata from
the original
MultipartFile
instance.
- SimpleMultipartFileReader() - Constructor for class org.springframework.integration.http.multipart.SimpleMultipartFileReader
-
- SimplePatternFileListFilter - Class in org.springframework.integration.file.filters
-
Filter that supports ant style path expressions, which are less powerful but more readable than regular expressions.
- SimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.SimplePatternFileListFilter
-
- SimplePool<T> - Class in org.springframework.integration.util
-
Implementation of
Pool
supporting dynamic resizing and a variable
timeout when attempting to obtain an item from the pool.
- SimplePool(int, SimplePool.PoolItemCallback<T>) - Constructor for class org.springframework.integration.util.SimplePool
-
Creates a SimplePool with a specific limit.
- SimplePool.PoolItemCallback<T> - Interface in org.springframework.integration.util
-
User of the pool provide an implementation of this interface; called during
various pool operations.
- SimplePublisherMetadataSource - Class in org.springframework.integration.aop
-
Simple implementation of PublisherMetadataSource
that allows for
configuration of a single channel name, payload expression, and
array of header key=value expressions.
- SimplePublisherMetadataSource() - Constructor for class org.springframework.integration.aop.SimplePublisherMetadataSource
-
- 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
-
- SimpleWebServiceOutboundGateway(String) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
-
- SimpleWebServiceOutboundGateway(String, SourceExtractor<?>) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
-
- SimpleWebServiceOutboundGateway(String, SourceExtractor<?>, WebServiceMessageFactory) - Constructor for class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
-
- SingleRequestResponseScenarioTests - Class in org.springframework.integration.test.support
-
- SingleRequestResponseScenarioTests() - Constructor for class org.springframework.integration.test.support.SingleRequestResponseScenarioTests
-
- size() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- size() - Method in class org.springframework.integration.expression.ExpressionEvalMap
-
- size() - Method in class org.springframework.integration.history.MessageHistory
-
- size() - Method in class org.springframework.integration.MessageHeaders
-
- size() - Method in interface org.springframework.integration.store.MessageGroup
-
- size() - Method in class org.springframework.integration.store.MessageGroupMetadata
-
- size() - Method in class org.springframework.integration.store.MessageGroupQueue
-
- size() - Method in class org.springframework.integration.store.SimpleMessageGroup
-
- size() - Method in interface org.springframework.integration.support.channel.HeaderChannelRegistry
-
- SOAP_ACTION - Static variable in class org.springframework.integration.ws.WebServiceHeaders
-
- SoapHeaderMapper - Interface in org.springframework.integration.ws
-
A convenience interface that extends
HeaderMapper
but parameterized with
SoapHeader
.
- SOCKET_FACTORY_SUPPORT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- SOCKET_SUPPORT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- SocketUtils - Class in org.springframework.integration.test.util
-
Contains several socket-specific utility methods.
- SocketUtils() - Constructor for class org.springframework.integration.test.util.SocketUtils
-
The constructor is intentionally public.
- SoftEndOfStreamException - Exception in org.springframework.integration.ip.tcp.serializer
-
Used to communicate that a stream has closed, but between logical
messages.
- SoftEndOfStreamException() - Constructor for exception org.springframework.integration.ip.tcp.serializer.SoftEndOfStreamException
-
- SoftEndOfStreamException(String) - Constructor for exception org.springframework.integration.ip.tcp.serializer.SoftEndOfStreamException
-
- SourceCreatingTransformer - Class in org.springframework.integration.xml.transformer
-
- 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
-
- 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
-
- SpelExpressionRetryStateGenerator - Class in org.springframework.integration.handler.advice
-
Creates a DefaultRetryState from a
Message
.
- SpelExpressionRetryStateGenerator(String) - Constructor for class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
-
- SpelExpressionRetryStateGenerator(String, String) - Constructor for class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
-
- SpelFunctionFactoryBean - Class in org.springframework.integration.config
-
- SpelFunctionFactoryBean(Class<?>, String) - Constructor for class org.springframework.integration.config.SpelFunctionFactoryBean
-
- SpelFunctionParser - Class in org.springframework.integration.config.xml
-
Parser for the <spel-function> element.
- SpelFunctionParser() - Constructor for class org.springframework.integration.config.xml.SpelFunctionParser
-
- SpelPropertyAccessorsParser - Class in org.springframework.integration.config.xml
-
Parser for the <spel-property-accessors> element.
- SpelPropertyAccessorsParser() - Constructor for class org.springframework.integration.config.xml.SpelPropertyAccessorsParser
-
- splitMessage(Message<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
-
Subclasses must override this method to split the received Message.
- splitMessage(Message<?>) - Method in class org.springframework.integration.splitter.DefaultMessageSplitter
-
- splitMessage(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
-
- SPRING_REPLY_CORRELATION - Static variable in class org.springframework.integration.amqp.AmqpHeaders
-
- SPRING_REPLY_TO_STACK - Static variable in class org.springframework.integration.amqp.AmqpHeaders
-
- SqlParameterSourceFactory - Interface in org.springframework.integration.jdbc
-
Collaborator for JDBC adapters which allows creation of
instances of SqlParameterSource
for use in update operations.
- SSL_CONTEXT_SUPPORT - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
-
- STACKED_CORRELATION_HEADER - Static variable in class org.springframework.integration.amqp.AmqpHeaders
-
- STACKED_REPLY_TO_HEADER - Static variable in class org.springframework.integration.amqp.AmqpHeaders
-
Deprecated.
No longer used by Spring-AMQP 1.2 and above.
- StackTraceUtils - Class in org.springframework.integration.util
-
Utility methods for analyzing stack traces.
- STANDARD_REPLY_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.mapping.AbstractHeaderMapper
-
- STANDARD_REQUEST_HEADER_NAME_PATTERN - Static variable in class org.springframework.integration.mapping.AbstractHeaderMapper
-
- 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.amqp.config.AmqpChannelFactoryBean
-
- start() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- start() - Method in class org.springframework.integration.channel.interceptor.WireTap
-
Restart the wire tap if it has been stopped.
- start() - Method in class org.springframework.integration.config.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.file.config.FileTailInboundChannelAdapterFactoryBean
-
- start() - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- start() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
- start() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- start() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
-
- start() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- start() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- start() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- start() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- start() - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- start() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
- start() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- start() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- start() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
-
- start() - Method in class org.springframework.integration.monitor.ManagedEndpoint
-
- start() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- start() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
- start() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- start() - Method in class org.springframework.integration.transformer.ContentEnricher
-
Lifecycle implementation.
- start() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- Statistics - Class in org.springframework.integration.monitor
-
- Statistics(int, double, double, double, double) - Constructor for class org.springframework.integration.monitor.Statistics
-
- STATUS_CODE - Static variable in class org.springframework.integration.http.HttpHeaders
-
- StatusUpdatingMessageHandler - Class in org.springframework.integration.twitter.outbound
-
MessageHandler for sending regular status updates as well as 'replies' or 'mentions'.
- StatusUpdatingMessageHandler(Twitter) - Constructor for class org.springframework.integration.twitter.outbound.StatusUpdatingMessageHandler
-
- 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.amqp.config.AmqpChannelFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
-
- stop() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- stop(Runnable) - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
- stop() - Method in class org.springframework.integration.channel.interceptor.WireTap
-
Stop the wire tap.
- stop() - Method in class org.springframework.integration.config.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.file.config.FileTailInboundChannelAdapterFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
-
- stop() - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- stop(Runnable) - Method in class org.springframework.integration.handler.MessageHandlerChain
-
- stop() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
- stop(Runnable) - Method in class org.springframework.integration.history.MessageHistoryConfigurer
-
- stop() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
-
- stop() - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.ip.config.TcpConnectionFactoryFactoryBean
-
- stop() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
Stops the server.
- stop(Runnable) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
-
- stop() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- stop(Runnable) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
-
- stop() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
-
- stop() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- stop(Runnable) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
-
- stop() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- stop(Runnable) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
- stop() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
-
- stop() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
-
- stop() - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- stop(Runnable) - Method in class org.springframework.integration.jms.JmsOutboundGateway
-
- stop() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
- stop(Runnable) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
- stop() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- stop(Runnable) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- stop() - Method in class org.springframework.integration.monitor.LifecycleMessageHandlerMetrics
-
- stop() - Method in class org.springframework.integration.monitor.LifecycleMessageSourceMetrics
-
- stop() - Method in class org.springframework.integration.monitor.ManagedEndpoint
-
- stop() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- stop(Runnable) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- stop() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
- stop(Runnable) - Method in class org.springframework.integration.store.MessageGroupStoreReaper
-
- stop() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- stop() - Method in class org.springframework.integration.transformer.ContentEnricher
-
Lifecycle implementation.
- stop() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- stop(Runnable) - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
-
- stopActiveChannels() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- stopActiveComponents(boolean, long) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
Shutdown active components.
- stopExecutors() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- stopMessageSources() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
Stops all message sources - may cause interrupts.
- stopNonSpringExecutors() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- stopSchedulers() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
-
- store - Variable in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
-
- StoredProcExecutor - Class in org.springframework.integration.jdbc
-
This class is used by all Stored Procedure (Stored Function) components and
provides the core functionality to execute those.
- StoredProcExecutor(DataSource) - Constructor for class org.springframework.integration.jdbc.StoredProcExecutor
-
Constructor taking DataSource
from which the DB Connection can be
obtained.
- StoredProcMessageHandler - Class in org.springframework.integration.jdbc
-
A message handler that executes Stored Procedures for update purposes.
- StoredProcMessageHandler(StoredProcExecutor) - Constructor for class org.springframework.integration.jdbc.StoredProcMessageHandler
-
- StoredProcMessageHandlerParser - Class in org.springframework.integration.jdbc.config
-
- StoredProcMessageHandlerParser() - Constructor for class org.springframework.integration.jdbc.config.StoredProcMessageHandlerParser
-
- StoredProcOutboundGateway - Class in org.springframework.integration.jdbc
-
- StoredProcOutboundGateway(StoredProcExecutor) - Constructor for class org.springframework.integration.jdbc.StoredProcOutboundGateway
-
- StoredProcOutboundGatewayParser - Class in org.springframework.integration.jdbc.config
-
- StoredProcOutboundGatewayParser() - Constructor for class org.springframework.integration.jdbc.config.StoredProcOutboundGatewayParser
-
- StoredProcParserUtils - Class in org.springframework.integration.jdbc.config
-
- StoredProcPollingChannelAdapter - Class in org.springframework.integration.jdbc
-
A polling channel adapter that creates messages from the payload returned by
executing a stored procedure or Sql function.
- StoredProcPollingChannelAdapter(StoredProcExecutor) - Constructor for class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
-
- StoredProcPollingChannelAdapterParser - Class in org.springframework.integration.jdbc.config
-
- StoredProcPollingChannelAdapterParser() - Constructor for class org.springframework.integration.jdbc.config.StoredProcPollingChannelAdapterParser
-
- StreamNamespaceHandler - Class in org.springframework.integration.stream.config
-
- StreamNamespaceHandler() - Constructor for class org.springframework.integration.stream.config.StreamNamespaceHandler
-
- STRING - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
-
- 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 a
Document
,
File
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 a 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 class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
-
- SUBJECT - Static variable in class org.springframework.integration.mail.MailHeaders
-
- SUBJECT - Static variable in class org.springframework.integration.xmpp.XmppHeaders
-
- subList(int, int) - Method in class org.springframework.integration.history.MessageHistory
-
- SubscribableChannel - Interface in org.springframework.integration.core
-
Interface for any MessageChannel implementation that accepts subscribers.
- SubscribableJmsChannel - Class in org.springframework.integration.jms
-
- SubscribableJmsChannel(AbstractMessageListenerContainer, JmsTemplate) - Constructor for class org.springframework.integration.jms.SubscribableJmsChannel
-
- SubscribableRedisChannel - Class in org.springframework.integration.redis.channel
-
- SubscribableRedisChannel(RedisConnectionFactory, String) - Constructor for class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- subscribe(MessageHandler) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
-
- subscribe(MessageHandler) - Method in interface org.springframework.integration.core.SubscribableChannel
-
- subscribe(MessageHandler) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
-
- subscribe(MessageHandler) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
-
- success() - Method in class org.springframework.integration.monitor.ExponentialMovingAverageRatio
-
Add a new event with successful outcome.
- suggestedClassName() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
-
- supplyCustomHeaders(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
-
Override to provide additional headers.
- supportedJsonTypes - Static variable in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
-
- supports(Class<?>) - Method in class org.springframework.integration.http.converter.SerializingHttpMessageConverter
-
- supports(Class<?>) - Method in class org.springframework.integration.security.channel.ChannelSecurityMetadataSource
-
- supportsEventType(Class<? extends ApplicationEvent>) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- supportsSourceType(Class<?>) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
-
- synchronizeToLocalDirectory(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
- synchronizeToLocalDirectory(File) - Method in interface org.springframework.integration.file.remote.synchronizer.InboundFileSynchronizer
-
- SYSLOG_PAYLOAD_ENTRIES - Static variable in class org.springframework.integration.syslog.DefaultMessageConverter
-
- SyslogHeaders - Class in org.springframework.integration.syslog
-
- SyslogHeaders() - Constructor for class org.springframework.integration.syslog.SyslogHeaders
-
- SyslogInboundChannelAdapterParser - Class in org.springframework.integration.syslog.config
-
Parses a <int-syslog:inbound-channel-adapter/>
.
- SyslogInboundChannelAdapterParser() - Constructor for class org.springframework.integration.syslog.config.SyslogInboundChannelAdapterParser
-
- SyslogNamespaceHandler - Class in org.springframework.integration.syslog.config
-
Namspace handler for spring-integration-syslog.
- SyslogNamespaceHandler() - Constructor for class org.springframework.integration.syslog.config.SyslogNamespaceHandler
-
- SyslogReceivingChannelAdapterFactoryBean - Class in org.springframework.integration.syslog.config
-
Factory bean to create syslog inbound adapters (UDP or TCP).
- SyslogReceivingChannelAdapterFactoryBean(SyslogReceivingChannelAdapterFactoryBean.Protocol) - Constructor for class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
-
- SyslogReceivingChannelAdapterFactoryBean.Protocol - Enum in org.springframework.integration.syslog.config
-
- SyslogReceivingChannelAdapterSupport - Class in org.springframework.integration.syslog.inbound
-
Base support class for inbound channel adapters.
- SyslogReceivingChannelAdapterSupport() - Constructor for class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
-
- SyslogToMapTransformer - Class in org.springframework.integration.transformer
-
Transforms a packet in Syslog (RFC5424) format to a Map.
- SyslogToMapTransformer() - Constructor for class org.springframework.integration.transformer.SyslogToMapTransformer
-
- SyslogToMapTransformerParser - Class in org.springframework.integration.config.xml
-
- SyslogToMapTransformerParser() - Constructor for class org.springframework.integration.config.xml.SyslogToMapTransformerParser
-