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

G

Gateway - Annotation Type in org.springframework.integration.annotation
Indicates that a method is capable of mapping its parameters to a message or message payload.
GatewayMethodDefinition - Class in org.springframework.integration.gateway
Represents the definition of Gateway methods, when using multiple methos per Gateway interface
GatewayMethodDefinition() - Constructor for class org.springframework.integration.gateway.GatewayMethodDefinition
 
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.
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
 
generateFileName(Message<?>) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
 
generateFileName(Message<?>) - Method in interface org.springframework.integration.file.FileNameGenerator
 
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, Class<T>) - Method in class org.springframework.integration.core.MessageHeaders
 
get(Object) - Method in class org.springframework.integration.core.MessageHeaders
 
getAddress() - Method in class org.springframework.integration.ip.tcp.NetSocketReader
 
getAddress() - Method in class org.springframework.integration.ip.tcp.NioSocketReader
 
getAddress() - Method in interface org.springframework.integration.ip.tcp.SocketReader
Returns the InetAddress of the underlying socket.
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
 
getArgumentMapVariableName(Method) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
getArgumentMapVariableName(Method) - Method in class org.springframework.integration.aop.MethodAnnotationExpressionSource
 
getArgumentVariableNames(Method) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
getArgumentVariableNames(Method) - Method in class org.springframework.integration.aop.MethodAnnotationExpressionSource
 
getArgumentVariableNames(Method) - Method in class org.springframework.integration.aop.MethodNameMappingExpressionSource
 
getArgumentVariableNames(Method) - Method in class org.springframework.integration.aop.SimpleExpressionSource
 
getAssembledData() - Method in class org.springframework.integration.ip.tcp.NetSocketReader
 
getAssembledData() - Method in class org.springframework.integration.ip.tcp.NioSocketReader
 
getAssembledData() - Method in interface org.springframework.integration.ip.tcp.SocketReader
Retrieves the assembled tcp data or null if the data is not yet assembled.
getAttributes(Object) - Method in class org.springframework.integration.security.channel.ChannelInvocationDefinitionSource
 
getBeanClass(Element) - Method in class org.springframework.integration.ip.config.IpInboundGatewayParser
 
getBeanClass(Element) - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.AnnotationConfigParser
 
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.SelectorChainParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.config.xml.SelectorParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.httpinvoker.config.HttpInvokerInboundGatewayParser
Deprecated.  
getBeanClassName(Element) - Method in class org.springframework.integration.jms.config.JmsChannelParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.jmx.config.ControlBusParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.rmi.config.RmiInboundGatewayParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.security.config.SecuredChannelsParser
 
getBeanClassName(Element) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
 
getBeanFactory() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getBody() - Method in interface org.springframework.integration.http.HttpRequest
Return the request body as a ByteArrayOutputStream, or null if this request has no body content.
getBody() - Method in interface org.springframework.integration.http.HttpResponse
Return the body of the response as an InputStream.
getBuffer() - Method in class org.springframework.integration.ip.tcp.NioSocketWriter
 
getChannel() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
getChannelIndicatorList(Message<?>) - Method in class org.springframework.integration.router.AbstractChannelNameResolvingMessageRouter
Subclasses must implement this method to return the channel indicators.
getChannelIndicatorList(Message<?>) - Method in class org.springframework.integration.router.AbstractSingleChannelNameRouter
 
getChannelIndicatorList(Message<?>) - Method in class org.springframework.integration.router.HeaderValueRouter
 
getChannelIndicatorList(Message<?>) - Method in class org.springframework.integration.xml.router.XPathMultiChannelRouter
 
getChannelIndicatorList(Message<?>) - Method in class org.springframework.integration.xml.router.XPathSingleChannelRouter
Evaluates the payload using XPathExpression.evaluateAsString(Node)
getChannelName(Method) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
getChannelName(Method) - Method in class org.springframework.integration.aop.MethodAnnotationExpressionSource
 
getChannelName(Method) - Method in class org.springframework.integration.aop.MethodNameMappingExpressionSource
 
getChannelName(Method) - Method in class org.springframework.integration.aop.SimpleExpressionSource
 
getChannelResolver() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getComponentName() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getComponentName() - Method in interface org.springframework.integration.context.NamedComponent
 
getComponentType() - Method in class org.springframework.integration.aggregator.CorrelatingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getComponentType() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Subclasses may implement this method to provide component type information.
getComponentType() - Method in interface org.springframework.integration.context.NamedComponent
 
getComponentType() - Method in class org.springframework.integration.filter.MessageFilter
 
getComponentType() - Method in class org.springframework.integration.handler.BridgeHandler
 
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.ServiceActivatingHandler
 
getComponentType() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
 
getComponentType() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
getComponentType() - Method in class org.springframework.integration.router.RecipientListRouter
 
getComponentType() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
getComponentType() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
getConfigAttributeDefinitionForReceive() - Method in class org.springframework.integration.security.channel.ChannelAccessPolicy
 
getConfigAttributeDefinitionForSend() - Method in class org.springframework.integration.security.channel.ChannelAccessPolicy
 
getConfigAttributeDefinitions() - Method in class org.springframework.integration.security.channel.ChannelInvocationDefinitionSource
 
getContentLength() - Method in interface org.springframework.integration.http.HttpRequest
Return the content length if known, else null.
getContentType() - Method in interface org.springframework.integration.http.HttpRequest
Return the content type for requests.
getConversionService(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getConversionService() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getConverter() - Method in class org.springframework.integration.xml.router.AbstractXPathRouter
 
getConverter() - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
 
getCorrelationId() - Method in class org.springframework.integration.core.MessageHeaders
 
getCorrelationKey(Message<?>) - Method in interface org.springframework.integration.aggregator.CorrelationStrategy
 
getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.CorrelationStrategyAdapter
 
getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.HeaderAttributeCorrelationStrategy
 
getCorrelationKey() - Method in interface org.springframework.integration.store.MessageGroup
 
getCorrelationKey() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getDefaultPollerMetadata(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
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
 
getDocumentBuilder() - Method in class org.springframework.integration.xml.transformer.ResultToDocumentTransformer
 
getErrorChannel(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getErrorChannel() - Method in class org.springframework.integration.core.MessageHeaders
 
getEvaluationContext() - Method in class org.springframework.integration.handler.AbstractMessageProcessor
 
getExceptionVariableName(Method) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
getExceptionVariableName(Method) - Method in class org.springframework.integration.aop.MethodAnnotationExpressionSource
 
getExpirationDate() - Method in class org.springframework.integration.core.MessageHeaders
 
getFailedMessage() - Method in exception org.springframework.integration.core.MessagingException
 
getFirstHeader(String) - Method in interface org.springframework.integration.http.HttpResponse
Return the first header value for a given key, or null if it has no values.
getFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
getGatewayClassName(Element) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
getGatewayClassName(Element) - Method in class org.springframework.integration.httpinvoker.config.HttpInvokerOutboundGatewayParser
Deprecated.  
getGatewayClassName(Element) - Method in class org.springframework.integration.rmi.config.RmiOutboundGatewayParser
 
getGatewayClassName(Element) - Method in class org.springframework.integration.ws.config.WebServiceOutboundGatewayParser
 
getHandlerIterator(Message<?>, List<MessageHandler>) - Method in interface org.springframework.integration.dispatcher.LoadBalancingStrategy
 
getHandlerIterator(Message<?>, List<MessageHandler>) - Method in class org.springframework.integration.dispatcher.RoundRobinLoadBalancingStrategy
Returns an iterator that starts at a new point in the list 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.
getHandlers() - Method in class org.springframework.integration.dispatcher.AbstractDispatcher
Returns a copied, unmodifiable List of this dispatcher's handlers.
getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.MethodAnnotationExpressionSource
 
getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.MethodNameMappingExpressionSource
 
getHeaderExpressions(Method) - Method in class org.springframework.integration.aop.SimpleExpressionSource
 
getHeaders() - Method in interface org.springframework.integration.core.Message
 
getHeaders() - Method in interface org.springframework.integration.http.HttpResponse
Return all response headers as a map.
getHeaders(String) - Method in interface org.springframework.integration.http.HttpResponse
Return all header values for a given key, or null if it has no values.
getHeaders() - Method in class org.springframework.integration.message.GenericMessage
 
getHistory() - Method in class org.springframework.integration.core.MessageHeaders
 
getHttpClient() - Method in class org.springframework.integration.http.CommonsHttpRequestExecutor
Return the HttpClient instance that this request executor uses.
getId() - Method in class org.springframework.integration.core.MessageHeaders
 
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.FileOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.http.config.HttpOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.ip.config.IpOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.jms.config.JmsOutboundGatewayParser
 
getInterceptors() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Exposes the interceptor list for subclasses.
getJmsTemplate() - Method in class org.springframework.integration.jms.AbstractJmsTemplateBasedAdapter
 
getMarked() - Method in interface org.springframework.integration.store.MessageGroup
 
getMarked() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getMaxMessagesPerPoll() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getMessage() - Method in exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
 
getMessage() - Method in class org.springframework.integration.event.MessagingEvent
 
getMessage(UUID) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
getMessage() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
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
 
getMessageGroup(Object) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
 
getMessageGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Return all Messages currently in the MessageStore that were stored using #addMessageToGroup(Object, Collection) with this correlation id.
getMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMethod() - Method in class org.springframework.integration.aggregator.MessageListMethodAdapter
 
getMethodInvocation() - Method in class org.springframework.integration.security.channel.ChannelInvocation
 
getMethodNameVariableName(Method) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
getMethodNameVariableName(Method) - Method in class org.springframework.integration.aop.MethodAnnotationExpressionSource
 
getMethodToChannelMap() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getName() - Method in class org.springframework.integration.history.MessageHistoryEvent
 
getName() - Method in class org.springframework.integration.jms.JmsDestinationBackedMessageChannel
 
getNewDocumentBuilder() - Method in class org.springframework.integration.xml.result.DomResultFactory
 
getNewDocumentBuilder() - Method in class org.springframework.integration.xml.source.DomSourceFactory
 
getNewDocumentBuilder() - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
 
getNewDocumentBuilder() - Method in class org.springframework.integration.xml.transformer.ResultToStringTransformer
 
getNewTransformer() - Method in class org.springframework.integration.xml.transformer.ResultToStringTransformer
 
getObject() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
getObject() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
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.config.FileWritingMessageHandlerFactoryBean
 
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.config.ConsumerEndpointFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
 
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.FileWritingMessageHandlerFactoryBean
 
getObjectType() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getObjectType() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
 
getOne() - Method in interface org.springframework.integration.store.MessageGroup
 
getOne() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getOperationChannel() - Method in class org.springframework.integration.control.ControlBus
Returns the channel to which operation-invoking Messages may be sent.
getOrder() - Method in class org.springframework.integration.aop.PublisherAnnotationBeanPostProcessor
 
getOrder() - Method in class org.springframework.integration.handler.AbstractMessageHandler
 
getOrder() - Method in class org.springframework.integration.handler.DelayHandler
 
getOrder() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
getOrder() - Method in class org.springframework.integration.handler.MethodInvokingMessageHandler
 
getOrder() - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
 
getOutputChannel() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
getPatterns() - Method in class org.springframework.integration.security.channel.ChannelInvocationDefinitionSource
 
getPayload() - Method in interface org.springframework.integration.core.Message
 
getPayload() - Method in class org.springframework.integration.message.GenericMessage
 
getPayloadExpression(Method) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
getPayloadExpression(Method) - Method in class org.springframework.integration.aop.MethodAnnotationExpressionSource
 
getPayloadExpression(Method) - Method in class org.springframework.integration.aop.MethodNameMappingExpressionSource
 
getPayloadExpression(Method) - Method in class org.springframework.integration.aop.SimpleExpressionSource
 
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
 
getPointcut() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
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.SimpleTcpNetInboundGateway
 
getPort() - Method in class org.springframework.integration.ip.tcp.SimpleTcpNetOutboundGateway
 
getPriority() - Method in class org.springframework.integration.core.MessageHeaders
 
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(String) - Method in class org.springframework.integration.jdbc.JdbcMessageStore
Replace patterns in the input to produce a valid SQL query.
getQueueSize() - Method in class org.springframework.integration.channel.QueueChannel
 
getReceiveTimeout() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getRemainingCapacity() - Method in class org.springframework.integration.channel.QueueChannel
 
getReplyChannel() - Method in class org.springframework.integration.core.MessageHeaders
 
getReplyChannelName() - Method in class org.springframework.integration.gateway.GatewayMethodDefinition
 
getReplyTimeout() - Method in class org.springframework.integration.gateway.GatewayMethodDefinition
 
getRequestChannelName() - Method in class org.springframework.integration.gateway.GatewayMethodDefinition
 
getRequestMethod() - Method in interface org.springframework.integration.http.HttpRequest
Return the request method ("GET", "POST", etc).
getRequestTimeout() - Method in class org.springframework.integration.gateway.GatewayMethodDefinition
 
getRequiredTaskScheduler(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getReturnValueVariableName(Method) - Method in class org.springframework.integration.aop.AbstractExpressionSource
 
getReturnValueVariableName(Method) - Method in class org.springframework.integration.aop.MethodAnnotationExpressionSource
 
getSecureObjectClass() - Method in class org.springframework.integration.security.channel.ChannelSecurityInterceptor
 
getSendErrorCount() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Return the current count of errors that have occurred while attempting to send a Message to this channel.
getSendSuccessCount() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Return the current count of Messages that have been sent to this channel successfully.
getSequenceNumber() - Method in class org.springframework.integration.core.MessageHeaders
 
getSequenceSize() - Method in class org.springframework.integration.core.MessageHeaders
 
getSequenceSize() - Method in interface org.springframework.integration.store.MessageGroup
 
getSequenceSize() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getSocket() - Method in class org.springframework.integration.ip.tcp.NetSocketReader
 
getSocket() - Method in class org.springframework.integration.ip.tcp.NioSocketReader
 
getSocket() - Method in interface org.springframework.integration.ip.tcp.SocketReader
 
getSocket() - Method in class org.springframework.integration.ip.tcp.TcpNetSendingMessageHandler
 
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
 
getStaticHeaders() - Method in class org.springframework.integration.gateway.GatewayMethodDefinition
 
getStatusCode() - Method in exception org.springframework.integration.http.ResponseStatusCodeException
 
getTargetUrl() - Method in interface org.springframework.integration.http.HttpRequest
Return the target URL for this request.
getTaskExecutor() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getTaskScheduler(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getTaskScheduler() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getTimestamp() - Method in class org.springframework.integration.core.MessageHeaders
 
getTimestamp() - Method in class org.springframework.integration.history.MessageHistoryEvent
Returns the timestamp generated when this event was created.
getTimestamp() - Method in interface org.springframework.integration.store.MessageGroup
 
getTimestamp() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getTransactionDefinition() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getTransactionManager() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getTransformer() - Method in class org.springframework.integration.xml.source.StringSourceFactory
 
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.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.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.XsltPayloadTransformerParser
 
getTransformOnSend() - Method in class org.springframework.integration.transformer.MessageTransformingChannelInterceptor
 
getTrigger() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getType() - Method in class org.springframework.integration.history.MessageHistoryEvent
 
getTypeConverter() - Method in class org.springframework.integration.util.DefaultMethodInvoker
 
getUnmarked() - Method in interface org.springframework.integration.store.MessageGroup
 
getUnmarked() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getUUID(Object) - Static method in class org.springframework.integration.util.UUIDConverter
Convenient utility to convert an object to a UUID.
getWebServiceTemplate() - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
getWriter() - Method in class org.springframework.integration.ip.tcp.AbstractTcpSendingMessageHandler
Returns the socket writer after instantiating it, if necessary.
getWriter() - Method in class org.springframework.integration.ip.tcp.TcpNetSendingMessageHandler
 
getWriter() - Method in class org.springframework.integration.ip.tcp.TcpNioSendingMessageHandler
 
getXPathExpresion() - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
 
getXPathExpression() - Method in class org.springframework.integration.xml.router.AbstractXPathRouter
 
GlobalChannelInterceptorParser - Class in org.springframework.integration.config.xml
Will parse 'channel-interceptor-chain' element
GlobalChannelInterceptorParser() - Constructor for class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
group - Variable in class org.springframework.integration.ip.udp.MulticastReceivingChannelAdapter
 

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