Index

A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

G

gateway() - Static method in class org.springframework.integration.camel.dsl.Camel
Create an instance of CamelMessageHandlerSpec in a ExchangePattern.InOut mode.
gateway(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided requestChannel to send a request with default options.
gateway(String, Consumer<GatewayEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided requestChannel to send a request with options from GatewayEndpointSpec.
gateway(ProducerTemplate) - Static method in class org.springframework.integration.camel.dsl.Camel
Create an instance of CamelMessageHandlerSpec for the provided ProducerTemplate in a ExchangePattern.InOut mode.
gateway(ExecutionGraphQlService) - Static method in class org.springframework.integration.graphql.dsl.GraphQl
Create an instance of GraphQlMessageHandlerSpec for the provided ExecutionGraphQlService.
gateway(IntegrationFlow) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided subflow.
gateway(IntegrationFlow, Consumer<GatewayEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided subflow with options from GatewayEndpointSpec.
gateway(MessageChannel) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided requestChannel to send a request with default options.
gateway(MessageChannel, Consumer<GatewayEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate the "artificial" GatewayMessageHandler for the provided requestChannel to send a request with options from GatewayEndpointSpec.
Gateway - Annotation Interface in org.springframework.integration.annotation
Indicates that an interface method is capable of mapping its parameters to a message or message payload.
GATEWAY - Enum constant in enum class org.springframework.integration.support.management.observation.IntegrationObservation
Observation for inbound message gateways.
GatewayEndpointSpec - Class in org.springframework.integration.dsl
A ConsumerEndpointSpec implementation for a mid-flow GatewayMessageHandler.
GatewayEndpointSpec(String) - Constructor for class org.springframework.integration.dsl.GatewayEndpointSpec
 
GatewayEndpointSpec(MessageChannel) - Constructor for class org.springframework.integration.dsl.GatewayEndpointSpec
 
GatewayHeader - Annotation Interface in org.springframework.integration.annotation
Provides the message header value or expression.
gatewayInterceptors - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
gatewayMarshaller - Variable in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
 
GatewayMessageHandler - Class in org.springframework.integration.gateway
The AbstractReplyProducingMessageHandler implementation for mid-flow Gateway.
GatewayMessageHandler() - Constructor for class org.springframework.integration.gateway.GatewayMessageHandler
 
gatewayMethodMetadata - Variable in class org.springframework.integration.dsl.GatewayProxySpec
 
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 - Variable in class org.springframework.integration.dsl.GatewayProxySpec
 
GatewayProxyFactoryBean<T> - 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<T>) - Constructor for class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
GatewayProxySpec - Class in org.springframework.integration.dsl
A builder for the GatewayProxyFactoryBean options when MessagingGateway on the service interface cannot be declared.
GatewayProxySpec(Class<?>) - Constructor for class org.springframework.integration.dsl.GatewayProxySpec
 
gatewayRequestChannel - Variable in class org.springframework.integration.dsl.GatewayProxySpec
 
gatewayUnmarshaller - Variable in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
 
gatherChannel(MessageChannel) - Method in class org.springframework.integration.dsl.ScatterGatherSpec
Specify a MessageChannel (optional) which is used internally in the ScatterGatherHandler for gathering (aggregate) results for scattered requests.
gatherTimeout(long) - Method in class org.springframework.integration.dsl.ScatterGatherSpec
Specify a timeout (in milliseconds) for the PollableChannel.receive(long) operation to wait for gathering results to output.
gaugeBuilder(String, Object, ToDoubleFunction<Object>) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor
Create a gauge builder for a gauge with the provided parameters.
gaugeBuilder(String, Object, ToDoubleFunction<Object>) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
 
GaugeFacade - Interface in org.springframework.integration.support.management.metrics
 
generateAlias(Element) - Static method in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
generateBeanName(String, Method, Class<? extends Annotation>) - Method in class org.springframework.integration.config.MessagingAnnotationBeanPostProcessor
 
generateCorrelationData(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
generateExchangeName(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
generateFileName(Message<?>) - Method in class org.springframework.integration.file.DefaultFileNameGenerator
 
generateFileName(Message<?>) - Method in interface org.springframework.integration.file.FileNameGenerator
 
generateHandlerBeanName(String, Method) - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
 
generateHandlerBeanName(String, MergedAnnotations) - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
 
generateHandlerBeanName(String, MergedAnnotations, String) - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
 
generateHandlerBeanName(String, MergedAnnotations, String) - Method in class org.springframework.integration.config.InboundChannelAdapterAnnotationPostProcessor
 
generateId() - Static method in class org.springframework.integration.context.IntegrationObjectSupport
 
generateId() - Method in class org.springframework.integration.support.IdGenerators.JdkIdGenerator
 
generateId() - Method in class org.springframework.integration.support.IdGenerators.SimpleIncrementingIdGenerator
 
generateRoutingKey(Message<?>) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
generateScriptName(Message<?>) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Deprecated.
 
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.
GenericEndpointSpec<H extends MessageHandler> - Class in org.springframework.integration.dsl
A ConsumerEndpointSpec for a MessageHandler implementations.
GenericEndpointSpec(H) - Constructor for class org.springframework.integration.dsl.GenericEndpointSpec
 
GenericHandler<P> - Interface in org.springframework.integration.core
A functional interface to specify MessageHandler logic with Java 8 Lambda expression:
GenericMessageJacksonDeserializer - Class in org.springframework.integration.support.json
The MessageJacksonDeserializer implementation for the GenericMessage.
GenericMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.GenericMessageJacksonDeserializer
 
GenericSelector<S> - Interface in org.springframework.integration.core
Generic (lambda) strategy interface for selector.
GenericTransformer<S,T> - Interface in org.springframework.integration.core
Generic (lambda) strategy interface for transformer.
get() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
get() - Method in class org.springframework.integration.dsl.IntegrationFlowBuilder
 
get() - Method in class org.springframework.integration.dsl.IntegrationFlowExtension
 
get() - Method in interface org.springframework.integration.jdbc.channel.PgConnectionSupplier
Supply an open, un-pooled connection to a Postgres database.
get() - Method in class org.springframework.integration.support.MapBuilder
 
get() - Method in class org.springframework.integration.support.PropertiesBuilder
 
get(int) - Method in class org.springframework.integration.history.MessageHistory
 
get(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
Gets the value(Expression) for the provided key from ExpressionEvalMap.original and returns the result of evaluation using ExpressionEvalMap.evaluationCallback.
get(String) - Method in class org.springframework.integration.hazelcast.metadata.HazelcastMetadataStore
 
get(String) - Method in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
 
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.mongodb.metadata.MongoDbMetadataStore
Get the value for the provided key performing findOne MongoDB operation.
get(String) - Method in class org.springframework.integration.redis.metadata.RedisMetadataStore
Retrieve the persisted value for the provided key.
get(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
get(String, InputStreamCallback) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Retrieve a remote file as an InputStream.
get(String, InputStreamCallback) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
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(Message<?>, Session<F>, String, String, String, F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
Copy a remote file to the configured local directory.
get(Message<?>, Session<FTPFile>, String, String, String, FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
GET - Enum constant in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
(get) Retrieve a remote file.
getAckInfo() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckCallback
 
getAcknowledgment(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getAcknowledgmentCallback() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
Return the acknowledgment callback, if present.
getAcknowledgmentCallback(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getAckPort() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
 
getActiveCount() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getActiveCount() - Method in interface org.springframework.integration.util.Pool
Return the number of allocated items that are currently checked out of the pool.
getActiveCount() - Method in class org.springframework.integration.util.SimplePool
 
getAdmin() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
getAdvice() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
getAdviceChain() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getAdvisedHandler() - Method in interface org.springframework.integration.handler.AbstractReplyProducingMessageHandler.RequestHandler
Utility method, intended for use in message handler advice classes to get information about the advised object.
getAgeDuration() - Method in class org.springframework.integration.file.filters.AbstractLastModifiedFileListFilter
 
getAggregatedExceptions() - Method in exception org.springframework.integration.dispatcher.AggregateMessageDeliveryException
Obtain a list aggregated target exceptions.
getAllocatedCount() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getAllocatedCount() - Method in interface org.springframework.integration.util.Pool
Return the current count of allocated items (in use and idle).
getAllocatedCount() - Method in class org.springframework.integration.util.SimplePool
 
getAllowCredentials() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
getAllowedHeaders() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
getAmqpMessage() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
 
getAmqpTemplate() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
getAnnotatedMethods(String) - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getAnnotationChain(Annotation, Class<? extends Annotation>) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
Get a chain of its meta-annotations for the provided instance and expected type.
getAnnotations() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getApplicationContext() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getApplicationContext() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getApplicationContext() - Method in class org.springframework.integration.graph.IntegrationGraphServer
 
getApplicationContext() - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
 
getApplicationContext() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getApplicationContextId() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Returns the ApplicationContext.getId() if the ApplicationContext is available.
getApplicationContextId() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getApplicationEventPublisher() - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
getApplicationEventPublisher() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
getApplicationEventPublisher() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getApplicationEventPublisher() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getApplicationEventPublisher() - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
 
getApplicationEventPublisher() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getApplicationEventPublisher() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getApplicationEventPublisher() - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
getArgs() - Method in class org.springframework.integration.gateway.MethodArgsHolder
 
getAssignedPartitions() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Return the currently assigned partitions.
getAsyncClientInstance(String, String) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
 
getAsyncClientInstance(String, String) - Method in interface org.springframework.integration.mqtt.core.MqttPahoClientFactory
Retrieve an async client instance.
getAsyncExecutor() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getAttributeAccessor(Message<?>, Message<?>) - Static method in class org.springframework.integration.support.ErrorMessageUtils
Return a AttributeAccessor for the provided arguments.
getAttributes() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
Will return an immutable Map of current attributes.
getAttrs() - Method in class org.springframework.integration.sftp.server.DirectoryCreatedEvent
 
getBackendPort() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Return the port a backend socket is bound or null if this proxy has not been started yet.
getBackendSocketType() - Method in enum class org.springframework.integration.zeromq.ZeroMqProxy.Type
 
getBacklog() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
The number of sockets in the server connection backlog.
getBasePackages(AnnotationAttributes, BeanDefinitionRegistry) - Method in class org.springframework.integration.config.IntegrationComponentScanRegistrar
 
getBatchingStrategy() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
 
getBeanClass(Element) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.config.xml.SelectorChainParser
 
getBeanClass(Element) - Method in class org.springframework.integration.config.xml.SpelFunctionParser
 
getBeanClass(Element) - Method in class org.springframework.integration.groovy.config.GroovyScriptParser
 
getBeanClass(Element) - Method in class org.springframework.integration.hazelcast.config.xml.HazelcastClusterMonitorInboundChannelAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.hazelcast.config.xml.HazelcastContinuousQueryInboundChannelAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.hazelcast.config.xml.HazelcastEventDrivenInboundChannelAdapterParser
 
getBeanClass(Element) - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 
getBeanClass(Element) - Method in class org.springframework.integration.redis.config.RedisQueueInboundGatewayParser
 
getBeanClass(Element) - Method in class org.springframework.integration.rsocket.config.RSocketInboundGatewayParser
 
getBeanClass(Element) - Method in class org.springframework.integration.scripting.config.jsr223.ScriptParser
 
getBeanClass(Element) - Method in class org.springframework.integration.webflux.config.WebFluxInboundEndpointParser
 
getBeanClass(Element) - Method in class org.springframework.integration.websocket.config.ClientWebSocketContainerParser
 
getBeanClass(Element) - Method in class org.springframework.integration.websocket.config.ServerWebSocketContainerParser
 
getBeanClass(Element) - Method in class org.springframework.integration.xml.config.XPathExpressionParser
 
getBeanClass(Element) - Method in class org.springframework.integration.xmpp.config.XmppConnectionParser
 
getBeanClassLoader() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
getBeanClassLoader() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
getBeanClassLoader() - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
 
getBeanClassName(Element) - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
 
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.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.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
 
getBeanDefinition(String, ConfigurableListableBeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
Return a BeanDefinition with the given name, obtained from the given BeanFactory or one of its parents.
getBeanDefinitionBuilderConstructorValue(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
getBeanDefinitionBuilderConstructorValue(Element, ParserContext) - Method in class org.springframework.integration.config.xml.GlobalWireTapParser
 
getBeanDefinitionRegistry() - Method in class org.springframework.integration.config.MessagingAnnotationPostProcessor
 
getBeanDescription() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getBeanFactory() - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
 
getBeanFactory() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
getBeanFactory() - Method in class org.springframework.integration.config.MessagingAnnotationPostProcessor
 
getBeanFactory() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getBeanFactory() - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
getBeanFactory() - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
 
getBeanFactory() - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
 
getBeanFactory() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
getBeanName() - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
getBeanName() - Method in class org.springframework.integration.channel.NullChannel
 
getBeanName() - Method in interface org.springframework.integration.context.ComponentSourceAware
Return the bean name populated by the BeanNameAware.setBeanName(String).
getBeanName() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getBeanName() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
getBeanName() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
getBeanName() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getBeanName() - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
 
getBeanName() - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
 
getBeanName() - Method in interface org.springframework.integration.mqtt.core.MqttComponent
Return this component's bean name.
getBeanName() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getBeanName() - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
 
getBeanName() - Method in interface org.springframework.integration.support.context.NamedComponent
 
getBeanName() - Method in class org.springframework.integration.support.management.ControlBusCommandRegistry.CommandMethod
 
getBeansOfType(Class<T>) - Method in class org.springframework.integration.graph.IntegrationGraphServer
Get beans for the provided type from the application context.
getBoundPort() - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
Return the port this internal server is bound or empty Mono.
getBoundPort() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
Return the port a socket is bound or 0 if this message producer has not been started yet or the socket is connected - not bound.
getBoundPort() - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
Return the port a socket is bound or 0 if this message producer has not been started yet or the socket is connected - not bound.
getBuffer() - Method in class org.springframework.integration.ip.tcp.serializer.TcpDeserializationExceptionEvent
 
getBuilder(Element, ParserContext) - Method in class org.springframework.integration.http.config.HttpOutboundChannelAdapterParser
 
getBuilder(Element, ParserContext) - Method in class org.springframework.integration.http.config.HttpOutboundGatewayParser
 
getBuilder(Element, ParserContext) - Method in class org.springframework.integration.webflux.config.WebFluxOutboundChannelAdapterParser
 
getBuilder(Element, ParserContext) - Method in class org.springframework.integration.webflux.config.WebFluxOutboundGatewayParser
 
getByIdInQuery(Collection<?>) - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
 
getBytes() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
getc() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
getCacheEvents() - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer
 
getCacheLevel() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getCacheListeningPolicy() - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer
 
getCallbacks() - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
 
getCaptureAddress() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Return the address an inproc capture socket is bound or null if this proxy has not been started yet or ZeroMqProxy.captureAddress is false.
getCarrier() - Method in class org.springframework.integration.support.management.observation.MessageReceiverContext
 
getCarrier() - Method in class org.springframework.integration.support.management.observation.MessageRequestReplyReceiverContext
 
getCarrier() - Method in class org.springframework.integration.support.management.observation.MessageSenderContext
 
getCause() - Method in class org.springframework.integration.events.IntegrationEvent
 
getChannel() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
 
getChannel() - Method in exception org.springframework.integration.amqp.support.ManualAckListenerExecutionFailedException
Return the channel.
getChannel() - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
getChannel() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getChannel() - Method in class org.springframework.integration.router.RecipientListRouter.Recipient
 
getChannel(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getChannelCount() - 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.MethodInvokingRouter
 
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.
getChannelMappings() - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
 
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
 
getChannelResolver() - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
 
getChannelResolver() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getChannelResolver() - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
getChannelResolver(BeanFactory) - Static method in class org.springframework.integration.support.channel.ChannelResolverUtils
Obtain a DestinationResolver registered with the "integrationChannelResolver" bean name.
getChannelsMaxBroadcastSubscribers() - Method in class org.springframework.integration.context.IntegrationProperties
getChannelsMaxUnicastSubscribers() - Method in class org.springframework.integration.context.IntegrationProperties
getCharset() - Method in class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
 
getClassLoader() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
getClassLoader() - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
getClassName() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getClient() - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
 
getClient() - Method in interface org.springframework.integration.mqtt.core.ClientManager
Return the managed client.
getClientConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
 
getClientConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
 
getClientId() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getClientId() - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
 
getClientId() - Method in class org.springframework.integration.mqtt.event.MqttMessageDeliveryEvent
 
getClientId() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getClientId() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getClientInstance() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
getClientInstance() - Method in interface org.springframework.integration.file.remote.session.Session
Get the underlying client library's client instance for this session.
getClientInstance() - Method in class org.springframework.integration.ftp.session.FtpSession
 
getClientInstance() - Method in class org.springframework.integration.mqtt.event.MqttMessageDeliveryEvent
 
getClientInstance() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
Incremented each time the client is connected.
getClientInstance() - Method in class org.springframework.integration.sftp.session.SftpSession
 
getClientInstance() - Method in class org.springframework.integration.smb.session.SmbSession
 
getClientInstance(String, String) - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
 
getClientInstance(String, String) - Method in interface org.springframework.integration.mqtt.core.MqttPahoClientFactory
Retrieve a client instance.
getClientManager() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getClientManager() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getClientRSocketRequester(Object) - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
Return connected RSocketRequester mapped by key or null.
getClientRSocketRequester(Object) - Method in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
Obtain a connected RSocketRequester mapped by provided key or null.
getClientRSocketRequesters() - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
Return connected RSocketRequesters mapped by keys.
getClientRSocketRequesters() - Method in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
Get connected RSocketRequesters mapped by the keys from the connect messages.
getClientVersion() - Method in class org.springframework.integration.sftp.server.SessionOpenedEvent
 
getCloseableResource() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
If the payload was created by a Closeable that needs to remain open until the payload is consumed, the resource will be added to this header.
getCloseableResource(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getCode() - Method in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
Get the numerical representation of the JDBC Type enum.
getCollectionNameExpression() - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
 
getCommand() - Method in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Command
 
getCommand() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
 
getCommands() - Method in class org.springframework.integration.http.management.ControlBusController
 
getCommands() - Method in class org.springframework.integration.support.management.ControlBusCommandRegistry
Return registered Control Bus commands.
getCommitTimeout() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getComparator() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
getCompletionTimeout() - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
 
getCompletionTimeout() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getCompletionTimeout() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getComponentDescription() - Method in interface org.springframework.integration.context.ComponentSourceAware
Return a human-readable description of this bean.
getComponentDescription() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getComponentDescription() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
getComponentDescription() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
getComponentName() - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
getComponentName() - Method in class org.springframework.integration.channel.NullChannel
 
getComponentName() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Will return the name of this component identified by IntegrationObjectSupport.componentName field.
getComponentName() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
getComponentName() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getComponentName() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getComponentName() - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
 
getComponentName() - Method in interface org.springframework.integration.support.context.NamedComponent
 
getComponentNamePatternsString() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
getComponentSource() - Method in interface org.springframework.integration.context.ComponentSourceAware
Return the configuration source Object for this bean (maybe null).
getComponentSource() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getComponentSource() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
getComponentSource() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
getComponentsToRegister() - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.amqp.dsl.AmqpInboundGatewaySpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.AggregatorSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.BroadcastPublishSubscribeSpec
 
getComponentsToRegister() - Method in interface org.springframework.integration.dsl.ComponentsRegistration
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.EndpointSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.MessageChannelSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.PollerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.PublishSubscribeSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.ReactiveMessageHandlerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.RouterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.TransformerEndpointSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.dsl.WireTapSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
 
getComponentsToRegister() - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.ip.dsl.TcpInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.ip.dsl.TcpInboundGatewaySpec
 
getComponentsToRegister() - Method in class org.springframework.integration.ip.dsl.TcpOutboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
 
getComponentsToRegister() - Method in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec.JmsInboundChannelSpecTemplateAware
 
getComponentsToRegister() - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec.JmsOutboundChannelSpecTemplateAware
 
getComponentsToRegister() - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.KafkaGatewayMessageHandlerTemplateSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
 
getComponentType() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
 
getComponentType() - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
 
getComponentType() - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
 
getComponentType() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
 
getComponentType() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
 
getComponentType() - Method in class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.cassandra.outbound.CassandraMessageHandler
 
getComponentType() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getComponentType() - Method in class org.springframework.integration.channel.FixedSubscriberChannel
 
getComponentType() - Method in class org.springframework.integration.channel.NullChannel
 
getComponentType() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
 
getComponentType() - Method in class org.springframework.integration.context.IntegrationObjectSupport
Subclasses may implement this method to provide component type information.
getComponentType() - Method in class org.springframework.integration.debezium.inbound.DebeziumMessageProducer
 
getComponentType() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
getComponentType() - Method in class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
 
getComponentType() - Method in class org.springframework.integration.endpoint.MessageProcessorMessageSource
 
getComponentType() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
 
getComponentType() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.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.FileWritingMessageHandler
 
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.gateway.FtpOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizingMessageSource
 
getComponentType() - Method in class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
 
getComponentType() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getComponentType() - Method in class org.springframework.integration.graph.IntegrationNode
 
getComponentType() - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
 
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.MessageHandlerSupport
 
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.hazelcast.inbound.HazelcastClusterMonitorMessageProducer
 
getComponentType() - Method in class org.springframework.integration.hazelcast.inbound.HazelcastContinuousQueryMessageProducer
 
getComponentType() - Method in class org.springframework.integration.hazelcast.inbound.HazelcastDistributedSQLMessageSource
 
getComponentType() - Method in class org.springframework.integration.hazelcast.inbound.HazelcastEventDrivenMessageProducer
 
getComponentType() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getComponentType() - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getComponentType() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
getComponentType() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
getComponentType() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
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.JdbcMessageHandler
 
getComponentType() - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.jdbc.StoredProcMessageHandler
 
getComponentType() - Method in class org.springframework.integration.jdbc.StoredProcOutboundGateway
 
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.JmsInboundGateway
 
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.AttributePollingMessageSource
 
getComponentType() - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
 
getComponentType() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
 
getComponentType() - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.jpa.inbound.JpaPollingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.jpa.outbound.JpaOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.json.JsonToObjectTransformer
 
getComponentType() - Method in class org.springframework.integration.json.ObjectToJsonTransformer
 
getComponentType() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
getComponentType() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getComponentType() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getComponentType() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.mail.MailReceivingMessageSource
 
getComponentType() - Method in class org.springframework.integration.mail.MailSendingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
 
getComponentType() - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
 
getComponentType() - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
 
getComponentType() - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
 
getComponentType() - Method in class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
 
getComponentType() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getComponentType() - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
 
getComponentType() - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
 
getComponentType() - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
 
getComponentType() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
 
getComponentType() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
 
getComponentType() - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
 
getComponentType() - Method in class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
 
getComponentType() - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
 
getComponentType() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
getComponentType() - Method in class org.springframework.integration.router.RecipientListRouter
 
getComponentType() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
getComponentType() - Method in class org.springframework.integration.scripting.ScriptExecutingMessageSource
 
getComponentType() - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizingMessageSource
 
getComponentType() - Method in class org.springframework.integration.sftp.inbound.SftpStreamingMessageSource
 
getComponentType() - Method in class org.springframework.integration.smb.inbound.SmbInboundFileSynchronizingMessageSource
 
getComponentType() - Method in class org.springframework.integration.smb.inbound.SmbStreamingMessageSource
 
getComponentType() - Method in class org.springframework.integration.smb.outbound.SmbOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
getComponentType() - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
 
getComponentType() - Method in class org.springframework.integration.stream.ByteStreamWritingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
 
getComponentType() - Method in class org.springframework.integration.stream.CharacterStreamWritingMessageHandler
 
getComponentType() - Method in interface org.springframework.integration.support.context.NamedComponent
 
getComponentType() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.transformer.ClaimCheckInTransformer
 
getComponentType() - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
 
getComponentType() - Method in class org.springframework.integration.transformer.ContentEnricher
 
getComponentType() - Method in class org.springframework.integration.transformer.HeaderEnricher
 
getComponentType() - Method in class org.springframework.integration.transformer.HeaderFilter
 
getComponentType() - Method in class org.springframework.integration.transformer.MapToObjectTransformer
 
getComponentType() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
getComponentType() - Method in class org.springframework.integration.transformer.ObjectToMapTransformer
 
getComponentType() - Method in class org.springframework.integration.transformer.ObjectToStringTransformer
 
getComponentType() - Method in class org.springframework.integration.webflux.inbound.WebFluxInboundEndpoint
 
getComponentType() - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.websocket.outbound.WebSocketOutboundMessageHandler
 
getComponentType() - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
getComponentType() - Method in class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
 
getComponentType() - Method in class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
 
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.MarshallingTransformer
 
getComponentType() - Method in class org.springframework.integration.xml.transformer.UnmarshallingTransformer
 
getComponentType() - Method in class org.springframework.integration.xml.transformer.XPathTransformer
 
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
 
getComponentType() - Method in class org.springframework.integration.xmpp.outbound.ChatMessageSendingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.xmpp.outbound.PresenceSendingMessageHandler
 
getComponentType() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
 
getComponentType() - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
 
getConcurrentConsumers() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getCondition() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getCondition() - Method in interface org.springframework.integration.store.MessageGroup
Return the condition for this group to consult with, e.g.
getCondition() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
getCondition() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getConfirmAckChannel() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getConfirmCorrelationExpression() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getConfirmNackChannel() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getConfirmTimeout() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getConnectHeaders() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
getConnection() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
 
getConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Obtain a connection - if AbstractConnectionFactory.setSingleUse(boolean) was called with true, a new connection is returned; otherwise a single connection is reused for all requests while the connection remains open.
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
 
getConnection() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getConnection() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
getConnectionFactory() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
getConnectionFactory() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
 
getConnectionFactoryName() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionEvent
 
getConnectionFactoryName() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getConnectionFactoryName() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
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.TcpConnectionFailedCorrelationEvent
 
getConnectionId() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
getConnectionId() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
getConnectionInfo() - Method in interface org.springframework.integration.mqtt.core.MqttComponent
Return information about the connection.
getConnectionInfo() - Method in interface org.springframework.integration.mqtt.core.MqttPahoComponent
 
getConnectionInfo() - Method in class org.springframework.integration.mqtt.core.Mqttv3ClientManager
 
getConnectionInfo() - Method in class org.springframework.integration.mqtt.core.Mqttv5ClientManager
 
getConnectionInfo() - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
 
getConnectionInfo() - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
 
getConnectionInfo() - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
 
getConnectionInfo() - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
 
getConnectionOptions() - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
 
getConnectionOptions() - Method in interface org.springframework.integration.mqtt.core.MqttPahoClientFactory
Retrieve the connection options.
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
 
getConnectionTest() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Get a Predicate that will be invoked to test a new connection; return true to accept the connection, false the reject.
getConnectTimeout() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
 
getConsumer() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
getConsumer() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
getConsumerMonitor() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
getConsumerMonitor() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
getConsumerProperties() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Get a reference to the configured consumer properties; allows further customization of the properties before the source is started.
getConsumes() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getContentDescriptor() - Method in class org.springframework.integration.graph.Graph
 
getContentType() - Method in class org.springframework.integration.http.multipart.UploadedMultipartFile
 
getContentType(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getContext() - Method in class org.springframework.integration.hazelcast.leader.LeaderInitiator
The context of the initiator or null if not running.
getContext() - Method in class org.springframework.integration.leader.event.AbstractLeaderEvent
Get the Context associated with this event.
getContext() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
getContext() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
The context of the initiator.
getContextualName(MessageReceiverContext) - Method in interface org.springframework.integration.support.management.observation.MessageReceiverObservationConvention
 
getContextualName(MessageRequestReplyReceiverContext) - Method in interface org.springframework.integration.support.management.observation.MessageRequestReplyReceiverObservationConvention
 
getContextualName(MessageSenderContext) - Method in interface org.springframework.integration.support.management.observation.MessageSenderObservationConvention
 
getControlAddress() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Return the address an inproc control socket is bound or null if this proxy has not been started yet.
getConversionService() - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
 
getConversionService() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getConversionService() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getConversionService(BeanFactory) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
 
getConverter() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getConverter() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getConverter() - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
Get the configured Converter.
getConverter() - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
 
getConvertibleTypes() - Method in class org.springframework.integration.json.JsonNodeWrapperToJsonNodeConverter
 
getCorrelationData() - Method in exception org.springframework.integration.amqp.support.NackedAmqpMessageException
 
getCorrelationDataGenerator() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getCorrelationId() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getCorrelationId() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getCorrelationId() - Method in class org.springframework.integration.support.BaseMessageBuilder
 
getCorrelationId() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getCorrelationKey(Message<?>) - Method in interface org.springframework.integration.aggregator.CorrelationStrategy
Find the correlation key for the given message.
getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
 
getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.HeaderAttributeCorrelationStrategy
 
getCorrelationKey(Message<?>) - Method in class org.springframework.integration.aggregator.MethodInvokingCorrelationStrategy
 
getCorrelationKey(Message<?>) - Method in class org.springframework.integration.file.aggregator.FileAggregator
 
getCorrelationStrategy() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getCorsConfiguration(Object, HttpServletRequest) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
 
getCount() - Method in class org.springframework.integration.graph.TimerStats
 
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.
getCreatedTime() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getCreateMessageQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Query to add a single message to the database.
getCreateMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.H2ChannelMessageStoreQueryProvider
 
getCreateMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.HsqlChannelMessageStoreQueryProvider
 
getCreateMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
 
getCreateMessageQuery() - Method in class org.springframework.integration.jdbc.store.channel.SqlServerChannelMessageStoreQueryProvider
 
getCrossOrigin() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getCurrent() - Method in interface org.springframework.integration.file.remote.aop.RotationPolicy
Return the current RotationPolicy.KeyDirectory.
getCurrent() - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
getCurrentComponent() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
getCurrentMessageChannel() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
getData() - Method in class org.springframework.integration.rsocket.RSocketConnectedEvent
 
getDataLen() - Method in class org.springframework.integration.sftp.server.FileWrittenEvent
 
getDataMimeType() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
getDefaultDeliveryMode() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getDefaultErrorChannel() - Method in class org.springframework.integration.channel.MessagePublishingErrorHandler
Return the default error channel for this error handler.
getDefaultErrorChannel() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Return the default error channel if the error handler is explicitly provided and it is a MessagePublishingErrorHandler.
getDefaultOutputChannel() - Method in class org.springframework.integration.router.AbstractMessageRouter
Get the default output channel.
getDefaultOutputChannel() - Method in interface org.springframework.integration.router.MessageRouter
Get the default output channel.
getDefaultPollerMetadata(BeanFactory) - Static method in class org.springframework.integration.scheduling.PollerMetadata
Return the default PollerMetadata bean if available.
getDefaultQos() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getDefaultReplyChannel() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getDefaultReplyChannelName() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getDefaultReplyTimeout() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getDefaultRequestChannel() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getDefaultRequestChannelName() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getDefaultRequestTimeout() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getDefaultRetained() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getDefaultTopic() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getDefinitionRegistry() - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
 
getDelayedMessageCount() - Method in class org.springframework.integration.handler.DelayHandler
 
getDelayedMessageCount() - Method in interface org.springframework.integration.handler.DelayHandlerManagement
 
getDelayedReads() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getDelegate() - Method in class org.springframework.integration.handler.ReactiveMessageHandlerAdapter
Get access to the delegate ReactiveMessageHandler.
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 interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Query to delete a single message from the database.
getDeliveryAttempt() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
When a message-driven endpoint supports retry implicitly, this header is incremented for each delivery attempt.
getDeliveryAttempt(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getDeliveryMode() - Method in class org.springframework.integration.jms.DynamicJmsTemplate
 
getDeliveryTag() - Method in exception org.springframework.integration.amqp.support.ManualAckListenerExecutionFailedException
Return the delivery tag for the last failed message.
getDerivedInput() - Method in exception org.springframework.integration.support.PartialSuccessException
getDerivedInput(Class<T>) - Method in exception org.springframework.integration.support.PartialSuccessException
Convenience version of PartialSuccessException.getDerivedInput() to avoid casting.
getDescription() - Method in class org.springframework.integration.support.management.ControlBusCommandRegistry.CommandMethod
 
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
 
getDeserializer() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
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
 
getDestination() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
 
getDestinationAddress() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
 
getDestinations() - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
 
getDirectory() - Method in class org.springframework.integration.file.remote.aop.RotationPolicy.KeyDirectory
 
getDirectoryExpressionProcessor() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
Return the processor for remote directory SpEL expression if any.
getDiscardChannel() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getDiscardChannel() - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
Return the discard message channel for trigger action message.
getDiscardChannel() - Method in class org.springframework.integration.filter.MessageFilter
 
getDiscardChannel() - Method in interface org.springframework.integration.handler.DiscardingMessageHandler
Return the discard channel.
getDiscardChannel() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
getDiscardChannelName() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getDiscards() - Method in class org.springframework.integration.graph.DiscardingMessageHandlerNode
 
getDisconnectCompletionTimeout() - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
 
getDisconnectCompletionTimeout() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getDisconnectCompletionTimeout() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
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.PartitionedChannel
 
getDispatcher() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
 
getDispatcher() - Method in class org.springframework.integration.jdbc.channel.PostgresSubscribableChannel
 
getDocumentBuilder() - Method in class org.springframework.integration.xml.DefaultXmlPayloadConverter
 
getDomain() - Method in class org.springframework.integration.smb.session.SmbConfig
 
getDstPath() - Method in class org.springframework.integration.sftp.server.PathMovedEvent
 
getDuration() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Return the duration.
getDynamicChannelNames() - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
 
getDynamicChannelNames() - Method in interface org.springframework.integration.support.management.MappingMessageRouterManagement
Provide a collection of channel names to which we have routed messages where the channel was not explicitly mapped.
getEnclosingClassName() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getEndpointsDefaultTimeout() - Method in class org.springframework.integration.context.IntegrationProperties
getEndpointsRunningStatus(String) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Return the running status of each endpoint in the role.
getEntityClass() - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
 
getEntityManager() - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
getEntityName(EntityManager, Class<?>) - Static method in class org.springframework.integration.jpa.support.JpaUtils
 
getErrorChannel() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Return the error channel (if provided) to which error messages will be routed.
getErrorChannel() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getErrorChannel() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Return the error channel (if provided) to which error messages will be routed.
getErrorChannel(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getErrorChannelName() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getErrorHandler() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getErrorHandler(BeanFactory) - Static method in class org.springframework.integration.channel.ChannelUtils
Obtain an ErrorHandler registered with the "integrationMessagePublishingErrorHandler" bean name.
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
 
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
 
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Populate an AttributeAccessor to be used when building an error message with the errorMessageStrategy.
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Populate an AttributeAccessor to be used when building an error message with the errorMessageStrategy.
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
getErrorMessageStrategy() - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
getErrorMessageStrategy() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
Get an ErrorMessageStrategy to use to build an error message when a exception occurs.
getErrorMessageStrategy() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Get an ErrorMessageStrategy to use to build an error message when a exception occurs.
getErrors() - Method in class org.springframework.integration.graph.ErrorCapableCompositeMessageHandlerNode
 
getErrors() - Method in class org.springframework.integration.graph.ErrorCapableDiscardingMessageHandlerNode
 
getErrors() - Method in class org.springframework.integration.graph.ErrorCapableEndpointNode
 
getErrors() - Method in class org.springframework.integration.graph.ErrorCapableMessageHandlerNode
 
getErrors() - Method in interface org.springframework.integration.graph.ErrorCapableNode
 
getErrors() - Method in class org.springframework.integration.graph.ErrorCapableRoutingNode
 
getEvaluationContext() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
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.
getEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getEvaluationResult() - Method in exception org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice.MessageHandlingExpressionEvaluatingAdviceException
 
getException() - Method in class org.springframework.integration.mqtt.event.MqttMessageNotDeliveredEvent
 
getExceptions() - Method in exception org.springframework.integration.xml.AggregatedXmlMessageValidationException
 
getExchange() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
 
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
 
getExchangeName() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getExchangeNameExpression() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getExchangeNameGenerator() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getExpirationDate() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getExpirationDate(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getExpired() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
getExpireGroupScheduledFutures() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getExposedHeaders() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
getExpression() - Method in interface org.springframework.integration.context.ExpressionCapable
Return the primary SpEL expression if this component is expression-based.
getExpression() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getExpression() - Method in class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
 
getExpression() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getExpression() - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
 
getExpression() - Method in class org.springframework.integration.jpa.support.JpaParameter
 
getExpression(String, Locale) - Method in interface org.springframework.integration.expression.ExpressionSource
 
getExpression(String, Locale) - Method in class org.springframework.integration.expression.ReloadableResourceBundleExpressionSource
Resolves the given key in the retrieved bundle files to an Expression.
getExpressionFor(String) - Static method in class org.springframework.integration.context.IntegrationProperties
Build the bean property definition expression to resolve the value from Integration properties within the bean building phase.
getExpressionForCommand(String, Class<?>...) - Method in class org.springframework.integration.support.management.ControlBusCommandRegistry
Obtain a SpEL expression for the command to call with parameter types.
getExpressionForPayload(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
getExpressionForPayload(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
getExpressionForPayload(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
getExpressionsForHeaders(Method) - Method in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
getExpressionsForHeaders(Method) - Method in class org.springframework.integration.aop.MethodNameMappingPublisherMetadataSource
 
getExpressionsForHeaders(Method) - Method in class org.springframework.integration.aop.SimplePublisherMetadataSource
 
getExpressionString() - Method in class org.springframework.integration.expression.DynamicExpression
 
getExpressionString() - Method in class org.springframework.integration.expression.FunctionExpression
 
getExpressionString() - Method in class org.springframework.integration.expression.SupplierExpression
 
getExpressionString() - Method in class org.springframework.integration.expression.ValueExpression
 
getExpressionString() - Method in class org.springframework.integration.filter.ExpressionEvaluatingSelector
 
getExpressionString() - Method in class org.springframework.integration.filter.SimpleExpressionEvaluatingSelector
 
getExtractReplyPayload() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getFactory() - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
getFactoryLocator() - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
Return this factory's locator.
getFailures() - Method in class org.springframework.integration.graph.ReceiveCounters
 
getFailures() - Method in class org.springframework.integration.graph.SendTimers
 
getFile() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingEvent
 
getFile() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
 
getFile() - Method in class org.springframework.integration.sftp.server.FileWrittenEvent
 
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
 
getFileInfo() - Method in class org.springframework.integration.smb.session.SmbFileInfo
 
getFileMap() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getFilename() - Method in interface org.springframework.integration.file.remote.FileInfo
 
getFilename() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
 
getFilename() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
 
getFilename() - Method in class org.springframework.integration.smb.session.SmbFileInfo
 
getFilename(F) - Method in class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
Return the name of the file represented by this F.
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(F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
getFilename(F) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
getFilename(File) - Method in class org.springframework.integration.file.filters.FileSystemMarkerFilePresentFileListFilter
 
getFilename(File) - Method in class org.springframework.integration.file.filters.RegexPatternFileListFilter
 
getFilename(File) - Method in class org.springframework.integration.file.filters.SimplePatternFileListFilter
 
getFilename(SmbFile) - Method in class org.springframework.integration.smb.filters.SmbRegexPatternFileListFilter
Gets the specified SMB file's name.
getFilename(SmbFile) - Method in class org.springframework.integration.smb.filters.SmbSimplePatternFileListFilter
Gets the specified SMB file's name.
getFilename(SmbFile) - Method in class org.springframework.integration.smb.filters.SmbSystemMarkerFilePresentFileListFilter
 
getFilename(SmbFile) - Method in class org.springframework.integration.smb.inbound.SmbInboundFileSynchronizer
 
getFilename(SmbFile) - Method in class org.springframework.integration.smb.outbound.SmbOutboundGateway
 
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.filters.FtpSystemMarkerFilePresentFileListFilter
 
getFilename(FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
getFilename(FTPFile) - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizer
 
getFilename(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.filters.SftpRegexPatternFileListFilter
 
getFilename(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.filters.SftpSimplePatternFileListFilter
 
getFilename(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.filters.SftpSystemMarkerFilePresentFileListFilter
 
getFilename(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
getFilename(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
 
getFilename(AbstractFileInfo<F>) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
getFilename(AbstractFileInfo<SmbFile>) - Method in class org.springframework.integration.smb.outbound.SmbOutboundGateway
 
getFilename(AbstractFileInfo<FTPFile>) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
getFilename(AbstractFileInfo<SftpClient.DirEntry>) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
getFileNames() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getFilePath() - Method in class org.springframework.integration.file.splitter.FileSplitter.FileMarker
 
getFiles(String) - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getFilter() - Method in class org.springframework.integration.file.DefaultDirectoryScanner
 
getFirstDate(String, String) - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
getFirstParameterType() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
 
getFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
getFolderOpenMode() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
getForString(String) - Static method in enum class org.springframework.integration.file.support.FileExistsMode
For a given non-null and not-empty input string, this method returns the corresponding FileExistsMode.
getFrameType() - Method in enum class org.springframework.integration.rsocket.RSocketInteractionModel
 
getFrom() - Method in class org.springframework.integration.graph.LinkNode
 
getFrontendPort() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
Return the port a frontend socket is bound or 0 if this proxy has not been started yet.
getFrontendSocketType() - Method in enum class org.springframework.integration.zeromq.ZeroMqProxy.Type
 
getFullChannelName() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Returns the fully qualified channel name including the application context id, if available.
getFullFileName(String, F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
By default, this method contacts the remote directory with the remote file name to build a full remote file path.
getFullFileName(String, SmbFile) - Method in class org.springframework.integration.smb.outbound.SmbOutboundGateway
 
getFunctionName() - Method in class org.springframework.integration.config.SpelFunctionFactoryBean
 
getFunctions() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getFuture() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint.CorrelationDataWrapper
 
getFuturesChannel() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getGatewayClassName() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
getGatewayClassName() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
getGatewayClassName() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
 
getGatewayClassName() - Method in class org.springframework.integration.smb.config.SmbOutboundGatewayParser
 
getGatewayClassName(Element) - Method in class org.springframework.integration.config.xml.AbstractOutboundGatewayParser
 
getGatewayClassName(Element) - Method in class org.springframework.integration.ws.config.WebServiceOutboundGatewayParser
 
getGatewayName() - Method in class org.springframework.integration.support.management.observation.MessageRequestReplyReceiverContext
 
getGateways() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
Return the Map of Method to MessagingGatewaySupport generated by this factory bean.
getGetResponse() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource.AmqpAckInfo
 
getGlobalMethodMetadata() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getGraph() - Method in class org.springframework.integration.graph.IntegrationGraphServer
Return the cached graph.
getGraph() - Method in class org.springframework.integration.http.management.IntegrationGraphController
 
getGroupConditionSupplier() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getGroupConditionSupplier() - Method in interface org.springframework.integration.aggregator.GroupConditionProvider
 
getGroupConditionSupplier() - Method in class org.springframework.integration.file.aggregator.FileAggregator
 
getGroupConditionSupplier() - Method in class org.springframework.integration.file.aggregator.FileMarkerReleaseStrategy
 
getGroupCreatedTime() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getGroupId() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
getGroupId() - Method in interface org.springframework.integration.jdbc.channel.PostgresChannelMessageTableSubscriber.Subscription
Return the group id for which this subscription receives notifications.
getGroupId() - Method in class org.springframework.integration.jdbc.channel.PostgresSubscribableChannel
 
getGroupId() - Method in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
 
getGroupId() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getGroupId() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
getGroupId() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
getGroupId() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getGroupId() - Method in interface org.springframework.integration.store.MessageGroup
 
getGroupId() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getGroupMetadata(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getGroupMetadata(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getGroupMetadata(Object) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getGroupMetadata(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Obtain the group metadata without fetching any messages; must supply all other group properties; may include the id of the first message.
getGroupMetadata(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getGroupPrefix() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Return the configured prefix for message group keys to distinguish between different store instances in the same target key-value database.
getGroupTimeoutExpression() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getHandler() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
getHandler() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
 
getHandler() - Method in interface org.springframework.integration.endpoint.IntegrationConsumer
Return the consumer's handler.
getHandler() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getHandler() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
 
getHandler(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
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 interface org.springframework.integration.dispatcher.MessageDispatcher
Return the current handler count.
getHandlerCount() - 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.
getHandlerName() - Method in class org.springframework.integration.support.management.observation.MessageReceiverContext
 
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.
getHandlers() - Method in class org.springframework.integration.graph.CompositeMessageHandlerNode
 
getHandlers() - Method in interface org.springframework.integration.handler.CompositeMessageHandler
Return an unmodifiable list of handlers.
getHandlers() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
getHazelcastRegisteredEventListenerId() - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer
 
getHeader(String, Class<T>) - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getHeader(String, Class<V>) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getHeader(String, Class<V>) - Method in class org.springframework.integration.support.BaseMessageBuilder
 
getHeader(String, Class<V>) - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getHeader(Map<?, ?>, String) - Static method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
SpEL Function to retrieve a required header.
getHeaderExpressions() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getHeaderExpressions() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getHeaderIfAvailable(Map<String, Object>, String, Class<V>) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
 
getHeaderMapper() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
 
getHeaderMapper() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getHeaderMapper() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getHeaderMapper() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getHeaderMapper() - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
 
getHeaderPatterns() - Method in class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
 
getHeaders() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
 
getHeaders() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getHeaders() - Method in class org.springframework.integration.rsocket.RSocketConnectedEvent
 
getHeaders() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getHeaders() - Method in class org.springframework.integration.support.BaseMessageBuilder
 
getHeaders() - Method in class org.springframework.integration.support.MutableMessage
 
getHeaders() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getHeadersFunction() - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
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
 
getHost() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getHost() - Method in class org.springframework.integration.smb.session.SmbConfig
 
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
 
getHostPort() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
getHostPort() - Method in interface org.springframework.integration.file.remote.session.Session
Return the host:port pair this session is connected to.
getHostPort() - Method in class org.springframework.integration.ftp.session.FtpSession
 
getHostPort() - Method in class org.springframework.integration.sftp.session.SftpSession
 
getHostPort() - Method in class org.springframework.integration.smb.session.SmbSession
 
getHttpHeader(HttpHeaders, String) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
 
getIChannelInterceptorList() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Exposes the interceptor list instance for subclasses.
getId() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
Return the flow id.
getId() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
 
getId() - Method in class org.springframework.integration.leader.AbstractCandidate
 
getId() - Method in interface org.springframework.integration.leader.Candidate
Gets the identifier.
getId(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getIdentifier() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
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
Return 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
 
getInboundFileSynchronizerClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
getInboundFileSynchronizerClass() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
getInboundFileSynchronizerClass() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getInboundFileSynchronizerClass() - Method in class org.springframework.integration.smb.config.SmbInboundChannelAdapterParser
 
getInboundHeaderMapper() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
getIndex() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
getIndexAccessors() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
Return the map of IndexAccessors to use in the target EvaluationContext
getIndexAccessors() - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
Return the registered IndexAccessor instances.
getInetAddress() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getInitialDuration() - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
Get the initial duration.
getInput() - Method in class org.springframework.integration.graph.MessageHandlerNode
 
getInputChannel() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
Return the flow input channel.
getInputChannel() - Method in interface org.springframework.integration.dsl.IntegrationFlow
Return the first MessageChannel component which is essentially a flow input channel.
getInputChannel() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
getInputChannel() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
getInputChannel() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
 
getInputChannel() - Method in interface org.springframework.integration.endpoint.IntegrationConsumer
Return the input channel.
getInputChannel() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getInputChannel() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
 
getInputChannelAttribute() - Method in interface org.springframework.integration.config.annotation.MethodAnnotationPostProcessor
 
getInputChannelAttribute() - Method in class org.springframework.integration.config.BridgeFromAnnotationPostProcessor
 
getInputChannelAttribute() - Method in class org.springframework.integration.config.InboundChannelAdapterAnnotationPostProcessor
 
getInputChannelAttributeName() - Method in class org.springframework.integration.amqp.config.AmqpOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.cassandra.config.xml.CassandraOutboundGatewayParser
 
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
 
getInputChannelAttributeName() - Method in class org.springframework.integration.kafka.config.xml.KafkaOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.mongodb.config.MongoDbOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.redis.config.RedisOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.redis.config.RedisQueueOutboundGatewayParser
 
getInputChannelAttributeName() - Method in class org.springframework.integration.rsocket.config.RSocketOutboundGatewayParser
 
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
 
getInsertQuery() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
Return the current insert query.
getInt() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
getIntegrationComponents() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
getIntegrationComponents() - Method in interface org.springframework.integration.dsl.IntegrationFlow
Return a map of integration components managed by this flow (if any).
getIntegrationComponents() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
getIntegrationComponents() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
getIntegrationFlow() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
Return the flow.
getIntegrationPatternCategory() - Method in class org.springframework.integration.graph.IntegrationNode
 
getIntegrationPatternType() - Method in class org.springframework.integration.aggregator.AggregatingMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.aggregator.ResequencingMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
 
getIntegrationPatternType() - Method in class org.springframework.integration.channel.AbstractExecutorChannel
 
getIntegrationPatternType() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getIntegrationPatternType() - Method in class org.springframework.integration.channel.AbstractPollableChannel
 
getIntegrationPatternType() - Method in class org.springframework.integration.channel.NullChannel
 
getIntegrationPatternType() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
 
getIntegrationPatternType() - Method in interface org.springframework.integration.channel.ReactiveStreamsSubscribableChannel
 
getIntegrationPatternType() - Method in interface org.springframework.integration.core.MessageSource
 
getIntegrationPatternType() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
getIntegrationPatternType() - Method in class org.springframework.integration.file.FileWritingMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.filter.MessageFilter
 
getIntegrationPatternType() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getIntegrationPatternType() - Method in class org.springframework.integration.graph.IntegrationNode
 
getIntegrationPatternType() - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Deprecated.
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.BridgeHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.ControlBusMessageProcessor
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.DelayHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.ExpressionCommandMessageProcessor
Deprecated.
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.MessageHandlerChain
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.ReplyProducingMessageHandlerWrapper
 
getIntegrationPatternType() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getIntegrationPatternType() - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
getIntegrationPatternType() - Method in interface org.springframework.integration.IntegrationPattern
Return a pattern type this component implements.
getIntegrationPatternType() - Method in class org.springframework.integration.jmx.OperationInvokingMessageHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
getIntegrationPatternType() - Method in class org.springframework.integration.router.RecipientListRouter
 
getIntegrationPatternType() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
 
getIntegrationPatternType() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
 
getIntegrationPatternType() - Method in class org.springframework.integration.transformer.ClaimCheckInTransformer
 
getIntegrationPatternType() - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
 
getIntegrationPatternType() - Method in class org.springframework.integration.transformer.ContentEnricher
 
getIntegrationPatternType() - Method in class org.springframework.integration.transformer.HeaderEnricher
 
getIntegrationPatternType() - Method in class org.springframework.integration.transformer.HeaderFilter
 
getIntegrationPatternType() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
 
getIntegrationProperties() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getIntegrationProperties(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getInteractionModels() - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
 
getInteractionModels() - Method in interface org.springframework.integration.rsocket.IntegrationRSocketEndpoint
Obtain RSocketInteractionModels this ReactiveMessageHandler is going to be mapped onto.
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.ChannelInterceptorList
 
getInterceptors() - Method in class org.springframework.integration.channel.AbstractMessageChannel
Return a read-only list of the configured interceptors.
getInterfaceNames() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getItem() - Method in interface org.springframework.integration.util.Pool
Obtain an item from the pool.
getItem() - Method in class org.springframework.integration.util.SimplePool
Obtain an item from the pool; waits up to waitTime milliseconds (default infinity).
getIterator() - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
getJavaMailProperties() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
getJdbcOperations() - Method in class org.springframework.integration.jdbc.store.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 BeanDefinitions containing parsed JPA Parameters.
getKafkaTemplate() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getKeepAlive() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getKey() - Method in class org.springframework.integration.file.remote.aop.RotationPolicy.KeyDirectory
 
getKeyDirectories() - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
 
getLastMessage() - Method in class org.springframework.integration.test.support.AbstractResponseValidator
 
getLastModified() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
getLastModified() - Method in interface org.springframework.integration.store.MessageGroup
 
getLastModified() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
getLastModified() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getLastModified(F) - Method in class org.springframework.integration.file.filters.AbstractLastModifiedFileListFilter
 
getLastModified(File) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
 
getLastModified(SmbFile) - Method in class org.springframework.integration.smb.filters.SmbLastModifiedFileListFilter
 
getLastModified(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpLastModifiedFileListFilter
 
getLastModified(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.filters.SftpLastModifiedFileListFilter
 
getLastModifiedTime() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getLastRead() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getLastReleasedMessageSequenceNumber() - Method in interface org.springframework.integration.store.MessageGroup
 
getLastReleasedMessageSequenceNumber() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
getLastReleasedMessageSequenceNumber() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getLastReleasedSequence() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getLastSend() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getLeader() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator.CuratorContext
Get the leader
getLevel() - Method in class org.springframework.integration.handler.LoggingHandler
 
getLifecycleMonitor() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getLineCount() - Method in class org.springframework.integration.file.splitter.FileSplitter.FileMarker
 
getLinks() - Method in class org.springframework.integration.graph.Graph
 
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
 
getListener() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getListener() - Method in class org.springframework.integration.jms.JmsInboundGateway
 
getListener() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
 
getLocalAddress() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
getLocalAddress() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
getLocalAddress() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getLocalPort() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getLocalSocketAddress() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getLocker() - Method in class org.springframework.integration.file.DefaultDirectoryScanner
 
getLockRegistry() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getLowCardinalityKeyValues(MessageReceiverContext) - Method in class org.springframework.integration.support.management.observation.DefaultMessageReceiverObservationConvention
 
getLowCardinalityKeyValues(MessageRequestReplyReceiverContext) - Method in class org.springframework.integration.support.management.observation.DefaultMessageRequestReplyReceiverObservationConvention
 
getLowCardinalityKeyValues(MessageSenderContext) - Method in class org.springframework.integration.support.management.observation.DefaultMessageSenderObservationConvention
 
getManagedName() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getManagedName() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getManagedName() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getManagedName() - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
getManagedResource(Class<?>) - Method in class org.springframework.integration.monitor.IntegrationJmxAttributeSource
 
getManagedType() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getManagedType() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getManagedType() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getManagedType() - Method in interface org.springframework.integration.support.management.IntegrationManagement
 
getMapper() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
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
 
getMapper() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getMapper() - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
 
getMappingKeyAttributeName() - Method in class org.springframework.integration.config.xml.AbstractRouterParser
Returns the name of the attribute that provides a key for the channel mappings.
getMappingKeyAttributeName() - Method in class org.springframework.integration.config.xml.ErrorMessageExceptionTypeRouterParser
 
getMappingKeyAttributeName() - Method in class org.springframework.integration.config.xml.PayloadTypeRouterParser
 
getMappingMongoConverter() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getMark() - Method in class org.springframework.integration.file.splitter.FileSplitter.FileMarker
 
getMarkedSegment() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
getMax() - Method in class org.springframework.integration.graph.TimerStats
 
getMaxAge() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
getMaxConcurrentConsumers() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getMaxFetchSize() - Method in class org.springframework.integration.endpoint.AbstractFetchLimitingMessageSource
 
getMaxFetchSize() - Method in interface org.springframework.integration.support.management.MessageSourceManagement
Return the max fetch size.
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.endpoint.AbstractPollingEndpoint
 
getMaxMessagesPerPoll() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getMaxMessagesPerTask() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getMean() - Method in class org.springframework.integration.graph.TimerStats
 
getMemberClassNames() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getMessage() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint.CorrelationDataWrapper
 
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
Return the text message emitted from the underlying tailing producer (Apache Commons or one of OS natives).
getMessage() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
 
getMessage() - Method in exception org.springframework.integration.http.support.IntegrationWebExchangeBindException
 
getMessage() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getMessage() - Method in class org.springframework.integration.mqtt.event.MqttMessageSentEvent
 
getMessage() - Method in class org.springframework.integration.mqtt.event.MqttSubscribedEvent
 
getMessage() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
 
getMessage() - Method in class org.springframework.integration.store.MessageHolder
 
getMessage() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getMessage() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
 
getMessage() - Method in exception org.springframework.integration.xml.AggregatedXmlMessageValidationException
 
getMessage(UUID) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessage(UUID) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getMessage(UUID) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessage(UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessage(UUID) - Method in interface org.springframework.integration.store.MessageStore
 
getMessage(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessageBuilderFactory() - Method in class org.springframework.integration.aggregator.AbstractAggregatingMessageGroupProcessor
 
getMessageBuilderFactory() - Method in class org.springframework.integration.aop.MessagePublishingInterceptor
 
getMessageBuilderFactory() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getMessageBuilderFactory() - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
 
getMessageBuilderFactory() - Method in class org.springframework.integration.file.transformer.AbstractFilePayloadTransformer
 
getMessageBuilderFactory() - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
 
getMessageBuilderFactory() - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
 
getMessageBuilderFactory() - Method in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
 
getMessageBuilderFactory() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getMessageBuilderFactory() - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
 
getMessageBuilderFactory() - Method in class org.springframework.integration.support.converter.MapMessageConverter
 
getMessageBuilderFactory() - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
 
getMessageBuilderFactory() - Method in class org.springframework.integration.support.json.Jackson2JsonMessageParser
 
getMessageBuilderFactory() - Method in class org.springframework.integration.syslog.DefaultMessageConverter
 
getMessageBuilderFactory() - Method in class org.springframework.integration.transformer.AbstractMessageProcessingTransformer
 
getMessageBuilderFactory() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
getMessageBuilderFactory(BeanFactory) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
Returns the context-wide `messageBuilderFactory` bean from the beanFactory, or a DefaultMessageBuilderFactory if not found or the beanFactory is null.
getMessageConverter() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
 
getMessageConverter() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getMessageConverters() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
 
getMessageCount() - Method in class org.springframework.integration.aggregator.MessageGroupExpiredEvent
 
getMessageCount() - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
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.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.store.JdbcMessageStore
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getMessageCountForAllMessageGroups() - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
 
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 interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Query that retrieve a count of all messages for a region.
getMessageFromGroup(Object, UUID) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessageFromGroup(Object, UUID) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
getMessageFromGroup(Object, UUID) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessageFromGroup(Object, UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessageFromGroup(Object, UUID) - Method in interface org.springframework.integration.store.MessageGroupStore
Retrieve a Message from a group by id.
getMessageFromGroup(Object, UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Not fully used.
getMessageGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
Not fully used.
getMessageGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
 
getMessageGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Will create a new instance of SimpleMessageGroup if necessary.
getMessageGroup(Object) - Method in interface org.springframework.integration.store.BasicMessageGroupStore
Return all Messages currently in the MessageStore that were stored using BasicMessageGroupStore.addMessageToGroup(Object, Message) with this group id.
getMessageGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Return the number of message groups in the store for configured region.
getMessageGroupCount() - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.redis.store.RedisChannelPriorityMessageStore
 
getMessageGroupCount() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getMessageGroupCount() - Method in interface org.springframework.integration.store.MessageGroupStore
Optional attribute giving the number of message groups.
getMessageGroupFactory() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
getMessageGroupFactory() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getMessageGroupFactory() - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
 
getMessageGroupFactory() - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
getMessageGroupStore() - Method in class org.springframework.integration.store.MessageGroupQueue
Get the store.
getMessageId() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getMessageId() - Method in class org.springframework.integration.mqtt.event.MqttMessageDeliveryEvent
 
getMessageId() - Method in class org.springframework.integration.store.MessageMetadata
 
getMessageIds() - Method in class org.springframework.integration.store.MessageGroupMetadata
Obtain a LinkedList copy of the MessageGroupMetadata.messageIds stored in the group.
getMessageMetadata() - Method in class org.springframework.integration.store.MessageHolder
 
getMessageMetadata(UUID) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessageMetadata(UUID) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getMessageMetadata(UUID) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessageMetadata(UUID) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessageMetadata(UUID) - Method in interface org.springframework.integration.store.MessageStore
Return a MessageMetadata for the Message by provided id.
getMessageMetadata(UUID) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessagePrefix() - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
Return the configured prefix for message keys to distinguish between different store instances in the same target key-value database.
getMessageProcessor() - Method in class org.springframework.integration.filter.AbstractMessageProcessingSelector
 
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 class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
 
getMessages() - Method in interface org.springframework.integration.store.MessageGroup
Return all available Messages from the group at the time of invocation.
getMessages() - Method in class org.springframework.integration.store.MessageGroupQueue
 
getMessages() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getMessagesForGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getMessagesForGroup(Object) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getMessagesForGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
getMessagesForGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getMessagesForGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getMessagesForGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Retrieve messages for the provided group id.
getMessagesForGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getMessageSource() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
Return this endpoint's source.
getMessageSourceClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
 
getMessageSourceClass() - Method in class org.springframework.integration.ftp.config.FtpStreamingInboundChannelAdapterParser
 
getMessageSourceClass() - Method in class org.springframework.integration.sftp.config.SftpStreamingInboundChannelAdapterParser
 
getMessageSourceClass() - Method in class org.springframework.integration.smb.config.SmbStreamingInboundChannelAdapterParser
 
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
 
getMessageSourceClassname() - Method in class org.springframework.integration.smb.config.SmbInboundChannelAdapterParser
 
getMessageStore() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getMessageStoreNotEmpty() - Method in class org.springframework.integration.store.MessageGroupQueue
Get the not empty condition.
getMessageStoreNotFull() - Method in class org.springframework.integration.store.MessageGroupQueue
Get the not full condition.
getMessagingTemplate() - Method in class org.springframework.integration.core.ErrorMessagePublisher
 
getMessagingTemplate() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
Obtain a MessagingTemplate with its default destination set to the input channel of the IntegrationFlow.
getMessagingTemplate() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
getMessagingTemplate() - Method in class org.springframework.integration.router.AbstractMessageRouter
Provide MessagingTemplate access for subclasses.
getMetadataMimeType() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
getMetadataStore(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getMeter() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.AbstractMeter
Get the meter.
getMeter() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounter
 
getMeter() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGauge
 
getMeter() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimer
 
getMeterRegistry() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor
 
getMethod() - Method in class org.springframework.integration.gateway.MethodArgsHolder
 
getMethod() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
getMethodName() - Method in class org.springframework.integration.support.management.ControlBusCommandRegistry.CommandMethod
 
getMethods() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getMetrics() - Method in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
Obtain the metrics from the rate limiter.
getMetricsCaptor() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getMetricsCaptor() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getMinimumTimeoutForEmptyGroups() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getMissingFileDelay() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
 
getModified() - Method in interface org.springframework.integration.file.remote.FileInfo
 
getModified() - Method in class org.springframework.integration.ftp.session.FtpFileInfo
 
getModified() - Method in class org.springframework.integration.sftp.session.SftpFileInfo
 
getModified() - Method in class org.springframework.integration.smb.session.SmbFileInfo
 
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(SmbFile) - Method in class org.springframework.integration.smb.inbound.SmbInboundFileSynchronizer
 
getModified(SmbFile) - Method in class org.springframework.integration.smb.outbound.SmbOutboundGateway
 
getModified(FTPFile) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
getModified(FTPFile) - Method in class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizer
 
getModified(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
getModified(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.inbound.SftpInboundFileSynchronizer
 
getMongoConverter() - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
 
getMongoTemplate() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getMultiFileMap() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getMultipartContentType(String) - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getNackReason() - Method in exception org.springframework.integration.amqp.support.NackedAmqpMessageException
 
getName() - Method in class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
 
getName() - Method in class org.springframework.integration.graph.CompositeMessageHandlerNode.InnerHandler
 
getName() - Method in class org.springframework.integration.graph.IntegrationNode
 
getName() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
getName() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
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 interface org.springframework.integration.support.management.observation.MessageReceiverObservationConvention
 
getName() - Method in interface org.springframework.integration.support.management.observation.MessageRequestReplyReceiverObservationConvention
 
getName() - Method in interface org.springframework.integration.support.management.observation.MessageSenderObservationConvention
 
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
 
getNextId() - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
Perform MongoDB INC operation for the document, which contains the MessageDocument sequence, and return the new incremented value for the new MessageDocument.
getNextPath(Message<?>, Object) - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
getNextPath(Message<?>, Object) - Method in interface org.springframework.integration.routingslip.RoutingSlipRouteStrategy
Get the next path for this routing slip.
getNoAutoStartupEndpoints() - Method in class org.springframework.integration.context.IntegrationProperties
getNodeId() - Method in class org.springframework.integration.graph.IntegrationNode
 
getNodes() - Method in class org.springframework.integration.graph.Graph
 
getNotPropagatedHeaders() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
Get the header patterns this handler doesn't propagate.
getNotPropagatedHeaders() - Method in interface org.springframework.integration.handler.HeaderPropagationAware
Get the header names this handler doesn't propagate.
getObject() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
 
getObject() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
 
getObject() - Method in class org.springframework.integration.config.CorrelationStrategyFactoryBean
 
getObject() - Method in class org.springframework.integration.config.IntegrationEvaluationContextFactoryBean
 
getObject() - Method in class org.springframework.integration.config.IntegrationSimpleEvaluationContextFactoryBean
 
getObject() - Method in class org.springframework.integration.config.PeriodicTriggerFactoryBean
 
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.dsl.IntegrationComponentSpec
!!! This method must not be called from the target configuration !!!
getObject() - Method in class org.springframework.integration.file.config.FileListFilterFactoryBean
 
getObject() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
 
getObject() - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
getObject() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
getObject() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
getObjectMapper() - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
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.IntegrationSimpleEvaluationContextFactoryBean
 
getObjectType() - Method in class org.springframework.integration.config.PeriodicTriggerFactoryBean
 
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.dsl.IntegrationComponentSpec
 
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.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.mail.config.MailReceiverFactoryBean
 
getObjectType() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
getObjectType() - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
 
getObjectType() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
getObjectType() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
getObjectType() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
getObservationRegistry() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getOffendingJPAQl() - Method in exception org.springframework.integration.jpa.core.JpaOperationFailedException
 
getOffset() - Method in class org.springframework.integration.ip.tcp.serializer.TcpDeserializationExceptionEvent
 
getOffsets() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
getOffsets() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
getOne() - Method in interface org.springframework.integration.store.MessageGroup
 
getOne() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
 
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
 
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.mongodb.store.MongoDbMessageStore
 
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
 
getOneMessageFromGroup(Object) - Method in interface org.springframework.integration.store.MessageGroupStore
Return the one Message from MessageGroup.
getOneMessageFromGroup(Object) - Method in class org.springframework.integration.store.SimpleMessageStore
 
getOOBInline() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
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.
getOpenConnectionIds() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getOption() - Method in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
 
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.MessageHandlerSupport
 
getOrder() - Method in class org.springframework.integration.webflux.inbound.IntegrationHandlerResultHandler
 
getOrigin() - Method in class org.springframework.integration.http.inbound.CrossOrigin
 
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.
getOutput() - Method in class org.springframework.integration.graph.EndpointNode
 
getOutputChannel() - Method in interface org.springframework.integration.core.MessageProducer
Return the output channel.
getOutputChannel() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
 
getOutputChannel() - Method in interface org.springframework.integration.endpoint.IntegrationConsumer
Return the output channel (may be null).
getOutputChannel() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
 
getOutputChannel() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getOutputChannel() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
 
getOutputChannel() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getOutputChannel() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
 
getOutputChannelName() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getOutputProcessor() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
Return a configured MessageGroupProcessor.
getOverrides() - Method in class org.springframework.integration.channel.AbstractMessageChannel
 
getOverrides() - Method in class org.springframework.integration.channel.NullChannel
 
getOverrides() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
 
getOverrides() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
 
getOverrides() - Method in class org.springframework.integration.handler.MessageHandlerSupport
 
getOverrides() - Method in interface org.springframework.integration.support.management.IntegrationManagement
Return the overrides.
getParameterMap() - Method in class org.springframework.integration.http.multipart.MultipartHttpInputMessage
 
getParameterTypes() - Method in class org.springframework.integration.support.management.ControlBusCommandRegistry.CommandMethod
 
getParams() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getPartialResults() - Method in exception org.springframework.integration.support.PartialSuccessException
getPartialResults(Class<T>) - Method in exception org.springframework.integration.support.PartialSuccessException
Convenience version of PartialSuccessException.getPartialResults() to avoid casting.
getParticipants() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator.CuratorContext
Get the list of participants
getPassword() - Method in class org.springframework.integration.smb.session.SmbConfig
 
getPath() - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
Get an array of the path patterns this endpoint is mapped onto.
getPath() - Method in interface org.springframework.integration.rsocket.IntegrationRSocketEndpoint
Obtain path patterns this ReactiveMessageHandler is going to be mapped onto.
getPath() - Method in class org.springframework.integration.sftp.server.DirectoryCreatedEvent
 
getPath() - Method in class org.springframework.integration.sftp.server.PathRemovedEvent
 
getPath(String) - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
getPathPatterns() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getPatternCategory() - Method in enum class org.springframework.integration.IntegrationPatternType
 
getPatterns() - Method in class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
getPatternTypes() - Method in enum class org.springframework.integration.IntegrationPatternType.IntegrationPatternCategory
 
getPayload() - Method in class org.springframework.integration.handler.support.MessagingMethodInvokerHelper.ParametersWrapper
 
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.mqtt.core.DefaultMqttPahoClientFactory.Will
 
getPayload() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getPayload() - Method in class org.springframework.integration.support.BaseMessageBuilder
 
getPayload() - Method in class org.springframework.integration.support.MutableMessage
 
getPayload() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getPayload() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getPayloadExpression() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getPayloadExpression() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getPayloadType() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
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
 
getPermissions() - Method in class org.springframework.integration.smb.session.SmbFileInfo
An Access Control Entry (ACE) is an element in a security descriptor such as those associated with files and directories.
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.ftp.config.FtpStreamingInboundChannelAdapterParser
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.sftp.config.SftpStreamingInboundChannelAdapterParser
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.smb.config.SmbInboundChannelAdapterParser
 
getPersistentAcceptOnceFileListFilterClass() - Method in class org.springframework.integration.smb.config.SmbStreamingInboundChannelAdapterParser
 
getPhase() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
 
getPhase() - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
 
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.dsl.IntegrationComponentSpec
 
getPhase() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
 
getPhase() - Method in class org.springframework.integration.dsl.StandardIntegrationFlow
 
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.hazelcast.leader.LeaderInitiator
 
getPhase() - Method in class org.springframework.integration.history.MessageHistoryConfigurer
 
getPhase() - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
 
getPhase() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
 
getPhase() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
getPhase() - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
The phase of component auto-start in SmartLifecycle.
getPhase() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
 
getPhase() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
getPhase() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
 
getPhase() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
 
getPhase() - Method in class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean
 
getPhase() - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
 
getPhase() - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
getPhase() - Method in class org.springframework.integration.xmpp.config.XmppConnectionFactoryBean
 
getPhase() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
getPhase() - Method in class org.springframework.integration.zookeeper.config.CuratorFrameworkFactoryBean
 
getPhase() - Method in class org.springframework.integration.zookeeper.config.LeaderInitiatorFactoryBean
 
getPhase() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator
 
getPhase() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
getPointcut() - Method in class org.springframework.integration.aop.PublisherAnnotationAdvisor
 
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.H2ChannelMessageStoreQueryProvider
 
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
 
getPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.SqlServerChannelMessageStoreQueryProvider
 
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.H2ChannelMessageStoreQueryProvider
 
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
 
getPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.SqlServerChannelMessageStoreQueryProvider
 
getPollingFlux() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
getPollTimeout() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getPoolSize() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getPoolSize() - Method in interface org.springframework.integration.util.Pool
Return the current size (limit) of the pool.
getPoolSize() - Method in class org.springframework.integration.util.SimplePool
Return 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 class org.springframework.integration.ip.tcp.connection.SocketInfo
 
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.TcpConnectionServerListeningEvent
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getPort() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
getPort() - Method in interface org.springframework.integration.ip.tcp.connection.TcpServerConnectionFactory
Return the port this server is listening on.
getPort() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getPort() - Method in class org.springframework.integration.ip.udp.UdpServerListeningEvent
 
getPort() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
 
getPort() - Method in class org.springframework.integration.smb.session.SmbConfig
 
getPort() - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
 
getPort() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
 
getPort() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
 
getPostProcessors() - Method in class org.springframework.integration.config.MessagingAnnotationPostProcessor
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean
Subclasses can override this to return a more specific type before handler creation.
getPreCreationHandlerType() - Method in class org.springframework.integration.config.AggregatorFactoryBean
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.FilterFactoryBean
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.RouterFactoryBean
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.SplitterFactoryBean
 
getPreCreationHandlerType() - Method in class org.springframework.integration.config.TransformerFactoryBean
 
getPriority() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getPriority() - Method in class org.springframework.integration.jms.DynamicJmsTemplate
 
getPriority() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getPriority(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Get the query used to retrieve the oldest message by priority for a channel excluding messages that match the provided message ids.
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.DerbyChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.H2ChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.HsqlChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.MySqlChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.PostgresChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupExcludeIdsQuery() - Method in class org.springframework.integration.jdbc.store.channel.SqlServerChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in interface org.springframework.integration.jdbc.store.channel.ChannelMessageStoreQueryProvider
Get the query used to retrieve the oldest message by priority for a channel.
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.DerbyChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.H2ChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.HsqlChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.MySqlChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.PostgresChannelMessageStoreQueryProvider
 
getPriorityPollFromGroupQuery() - Method in class org.springframework.integration.jdbc.store.channel.SqlServerChannelMessageStoreQueryProvider
 
getProcedureParameterBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
 
getProducerName() - Method in class org.springframework.integration.support.management.observation.MessageSenderContext
 
getProduces() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getProjectionExpression() - Method in class org.springframework.integration.jpa.support.JpaParameter
 
getProperties() - Method in class org.springframework.integration.graph.IntegrationNode
 
getPropertiesConverter() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
 
getPropertyAccessors() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getPropertyAccessors() - Method in class org.springframework.integration.expression.SpelPropertyAccessorRegistrar
Return the registered PropertyAccessor instances to use in the target EvaluationContext.
getPropertyValue(Object, String) - Static method in class org.springframework.integration.test.util.TestUtils
Obtain a value for the property from the provide object.
getPropertyValue(Object, String, Class<T>) - Static method in class org.springframework.integration.test.util.TestUtils
Obtain a value for the property from the provide object and try to cast it to the provided type.
getPushbackBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.AbstractTcpConnectionSupport
 
getQos() - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory.Will
 
getQos() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getQosProcessor() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getQuery(JdbcChannelMessageStore.Query, Supplier<String>) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Replace patterns in the input to produce a valid SQL query.
getQuery(JdbcMessageStore.Query) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
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
Obtain the current number of queued Messages in this channel.
getQueueSize() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
Returns the size of the Queue specified by RedisQueueInboundGateway.boundListOperations.
getQueueSize() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
Returns the size of the Queue specified by RedisQueueMessageDrivenEndpoint.boundListOperations.
getRabbitTemplate() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
 
getRabbitTemplate() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getRabbitTemplate() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
 
getRabbitTemplate() - Method in class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
 
getRateLimiter() - Method in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
Get the RateLimiter which is configured for this advice.
getRawHeaders() - Method in class org.springframework.integration.support.MutableMessageHeaders
 
getReactorContext() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
Get a ContextView header if present.
getReactorContext(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
Get a ContextView header if present.
getReadablePropertyNames() - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSource
Provide access to the property names of the wrapped bean.
getReadDelay() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getReadOnlyHeaders() - Method in class org.springframework.integration.context.IntegrationProperties
Return the value of IntegrationProperties.READ_ONLY_HEADERS option.
getReaperDelay() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
 
getRebalanceListener() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
getReceiptId() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
 
getReceiveBufferSize() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
 
getReceiveBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getReceiveCounters() - Method in class org.springframework.integration.graph.MessageSourceNode
 
getReceiveCounters() - Method in class org.springframework.integration.graph.PollableChannelNode
 
getReceiveMessageSource() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
getReceiveMessageSource() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getReceiveMessageSource() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
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
 
getRecipients() - Method in class org.springframework.integration.router.RecipientListRouter
 
getRecipients() - Method in interface org.springframework.integration.router.RecipientListRouterManagement
 
getRecord() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
getRecord() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
getRecord() - Method in exception org.springframework.integration.kafka.support.KafkaSendFailureException
 
getRecoveryInterval() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getRecoveryInterval() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
 
getRedisTemplate() - Method in class org.springframework.integration.redis.store.RedisChannelMessageStore
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.ftp.config.FtpStreamingInboundChannelAdapterParser
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.sftp.config.SftpStreamingInboundChannelAdapterParser
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.smb.config.SmbInboundChannelAdapterParser
 
getRegexPatternFileListFilterClass() - Method in class org.springframework.integration.smb.config.SmbStreamingInboundChannelAdapterParser
 
getRegexPatternFileListFilterClassName() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
getRegexPatternFileListFilterClassName() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
getRegexPatternFileListFilterClassName() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
 
getRegexPatternFileListFilterClassName() - Method in class org.springframework.integration.smb.config.SmbOutboundGatewayParser
 
getRegion() - Method in interface org.springframework.integration.jdbc.channel.PostgresChannelMessageTableSubscriber.Subscription
Return the region for which this subscription receives notifications.
getRegion() - Method in class org.springframework.integration.jdbc.channel.PostgresSubscribableChannel
 
getRegion() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Returns the current region that was set or JdbcChannelMessageStore.DEFAULT_REGION, which is the default.
getRegistrationById(String) - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
Obtain an IntegrationFlowContext.IntegrationFlowRegistration for the IntegrationFlow associated with the provided flowId.
getRegistrationById(String) - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
Obtain an IntegrationFlowContext.IntegrationFlowRegistration for the IntegrationFlow associated with the provided flowId.
getRegistrations() - Method in class org.springframework.integration.codec.kryo.CompositeKryoRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.FileKryoRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.KryoClassListRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.KryoClassMapRegistrar
 
getRegistrations() - Method in interface org.springframework.integration.codec.kryo.KryoRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.KryoRegistrationRegistrar
 
getRegistrations() - Method in class org.springframework.integration.codec.kryo.MessageKryoRegistrar
 
getRegistry() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext
Provide the state of the mapping of integration flow names to their IntegrationFlowContext.IntegrationFlowRegistration instances.
getRegistry() - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext
Provide the state of the mapping of integration flow names to their IntegrationFlowContext.IntegrationFlowRegistration instances.
getReleaseStrategy() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
getRemainingCapacity() - Method in class org.springframework.integration.channel.PriorityChannel
 
getRemainingCapacity() - Method in class org.springframework.integration.channel.QueueChannel
 
getRemainingCapacity() - Method in interface org.springframework.integration.channel.QueueChannelOperations
Obtain the remaining capacity of this channel.
getRemoteDirectory() - Method in class org.springframework.integration.file.remote.AbstractFileInfo
 
getRemoteDirectory() - Method in interface org.springframework.integration.file.remote.FileInfo
 
getRemoteFileMetadata(File) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
Obtain a metadata for remote file associated with the provided local file.
getRemoteFilename(String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
getRemoteFileSeparator() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
getRemoteFileTemplate() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
 
getRemoteFileTemplate() - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
getRemoteHandle() - Method in class org.springframework.integration.sftp.server.FileWrittenEvent
 
getRemoteSocketAddress() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getRemoveBatchSize() - Method in class org.springframework.integration.store.AbstractBatchingMessageGroupStore
 
getRenewQuery() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
Return the current renew query.
getReply() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy.RequestAndReply
 
getReply(ResponseEntity<?>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
getReplyChannel() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Return this gateway's reply channel if any.
getReplyChannelName() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getReplyCode() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
 
getReplyText() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
 
getReplyTimeout() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getRequest() - Method in class org.springframework.integration.ftp.server.FtpRequestEvent
 
getRequest() - Method in class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy.RequestAndReply
 
getRequestChannel() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
Return this gateway's request channel.
getRequestChannelName() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getRequestDate() - Method in class org.springframework.integration.handler.DelayHandler.DelayedMessageWrapper
 
getRequester() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
Return the RSocketRequester this connector is built on.
getRequester() - Method in class org.springframework.integration.rsocket.RSocketConnectedEvent
 
getRequestMapping() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getRequestMethods() - Method in class org.springframework.integration.http.inbound.RequestMapping
 
getRequestPayloadType() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getRequestTimeout() - Method in class org.springframework.integration.gateway.GatewayMethodMetadata
 
getRequiredConversionService() - Method in class org.springframework.integration.router.AbstractMessageRouter
 
getRequiredTaskScheduler(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getRequiresReply() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
 
getResourceHolder() - Method in class org.springframework.integration.transaction.IntegrationResourceHolderSynchronization
 
getResourceKey() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Return the key under which the resource will be made available as an attribute on the IntegrationResourceHolder.
getResourceKey() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getResourceKey() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getResourceToBind() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
Return a resource (MessageSource etc.) to bind when using transaction synchronization.
getResourceToBind() - Method in class org.springframework.integration.endpoint.PollingConsumer
 
getResourceToBind() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
 
getResponseValidator() - Method in class org.springframework.integration.test.support.RequestResponseScenario
 
getResultFactory() - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
getResultFactoryName() - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
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) - Method in interface org.springframework.integration.jpa.core.JpaOperations
Execute the provided query to return a list of results.
getResultListForQuery(String, ParameterSource, int, int) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
getResultListForQuery(String, ParameterSource, int, int) - Method in interface org.springframework.integration.jpa.core.JpaOperations
Executes the provided query to return a list of results.
getResultType() - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
 
getRetainedProcessor() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
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
 
getReturnChannel() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getReturningResultsetBeanDefinitions(Element, ParserContext) - Static method in class org.springframework.integration.jdbc.config.StoredProcParserUtils
 
getReuseAddress() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getRole() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
 
getRole() - Method in class org.springframework.integration.hazelcast.leader.LeaderInitiator.HazelcastContext
 
getRole() - Method in class org.springframework.integration.leader.AbstractCandidate
 
getRole() - Method in interface org.springframework.integration.leader.Candidate
Gets the role.
getRole() - Method in interface org.springframework.integration.leader.Context
Get the role for the Candidate.
getRole() - Method in class org.springframework.integration.leader.event.AbstractLeaderEvent
Get the role of the leader.
getRole() - Method in class org.springframework.integration.zookeeper.leader.LeaderInitiator.CuratorContext
 
getRoles() - Method in class org.springframework.integration.support.SmartLifecycleRoleController
Return a collection of the roles currently managed by this controller.
getRoot() - Method in class org.springframework.integration.zookeeper.metadata.ZookeeperMetadataStore
 
getRoutes() - Method in class org.springframework.integration.graph.RoutingMessageHandlerNode
 
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
 
getRoutingKey() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getRoutingKey() - Method in exception org.springframework.integration.amqp.support.ReturnedAmqpMessageException
 
getRoutingKeyExpression() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getRoutingKeyGenerator() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
 
getRSocketStrategies() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
 
getScanner() - Method in class org.springframework.integration.file.FileReadingMessageSource
The FileReadingMessageSource.scanner property accessor to allow to modify its options (filter, locker etc.) at runtime using the FileReadingMessageSource bean.
getScriptAsString() - Method in class org.springframework.integration.scripting.RefreshableResourceScriptSource
 
getScriptEngine() - Method in class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
 
getScriptExecutor(String) - Static method in class org.springframework.integration.scripting.jsr223.ScriptExecutorFactory
 
getScriptSource(Message<?>) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Deprecated.
 
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
 
getScriptVariableGenerator() - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
 
getSendBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
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
 
getSender() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getSenders() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
Return the list of senders.
getSenders() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getSenders() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
Return the list of senders.
getSenders() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getSendFailureChannel() - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
 
getSendFailureChannel() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getSendSuccessChannel() - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
 
getSendSuccessChannel() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getSendTimeout() - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
 
getSendTimeout() - Method in class org.springframework.integration.scheduling.PollerMetadata
Deprecated, for removal: This API element is subject to removal in a future version.
getSendTimers() - Method in class org.springframework.integration.graph.MessageChannelNode
 
getSendTimers() - Method in class org.springframework.integration.graph.MessageHandlerNode
 
getSequence() - Method in class org.springframework.integration.mongodb.store.MessageDocument
 
getSequenceDetails() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getSequenceDetails() - Method in class org.springframework.integration.support.BaseMessageBuilder
 
getSequenceDetails() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getSequenceNumber() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getSequenceNumber() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getSequenceNumber() - Method in class org.springframework.integration.support.BaseMessageBuilder
 
getSequenceNumber() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getSequenceNumber(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getSequenceSize() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
getSequenceSize() - Method in interface org.springframework.integration.store.MessageGroup
 
getSequenceSize() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getSequenceSize() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
 
getSequenceSize() - Method in class org.springframework.integration.support.BaseMessageBuilder
 
getSequenceSize() - Method in class org.springframework.integration.support.MutableMessageBuilder
 
getSequenceSize(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
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
 
getSerializer() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
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
 
getServerSocketAddress() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
 
getServerSocketAddress() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetServerConnectionFactory
 
getServerSocketAddress() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
 
getServerSocketAddress() - Method in interface org.springframework.integration.ip.tcp.connection.TcpServerConnectionFactory
Return the SocketAddress that the underlying ServerSocket is bound to.
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 ServerSockets.
getSession() - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Obtain a raw Session object.
getSession() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
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 class org.springframework.integration.file.remote.session.DelegatingSessionFactory
 
getSession() - Method in interface org.springframework.integration.file.remote.session.SessionFactory
 
getSession() - Method in class org.springframework.integration.ftp.server.ApacheMinaFtpEvent
 
getSession() - Method in class org.springframework.integration.ftp.session.AbstractFtpSessionFactory
 
getSession() - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEvent
 
getSession() - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
 
getSession() - Method in class org.springframework.integration.smb.session.SmbSessionFactory
 
getSession(Object) - Method in class org.springframework.integration.file.remote.session.DelegatingSessionFactory
 
getSession(String) - Method in class org.springframework.integration.websocket.ClientWebSocketContainer
Return the ClientWebSocketContainer.clientSession WebSocketSession.
getSession(String) - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
getSessionAcknowledgeMode() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getSessionAcknowledgeModeName() - Method in class org.springframework.integration.jms.JmsOutboundGateway.ReplyContainerProperties
 
getSessionFactory() - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
getSessionFactory(Object) - Method in class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
 
getSessionFactory(Object) - Method in interface org.springframework.integration.file.remote.session.SessionFactoryLocator
Return a SessionFactory for the key.
getSessions() - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
getShareAndDir() - Method in class org.springframework.integration.smb.session.SmbConfig
 
getSimpleEvaluationContext(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileInboundChannelAdapterParser
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.ftp.config.FtpStreamingInboundChannelAdapterParser
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.sftp.config.SftpInboundChannelAdapterParser
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.sftp.config.SftpStreamingInboundChannelAdapterParser
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.smb.config.SmbInboundChannelAdapterParser
 
getSimplePatternFileListFilterClass() - Method in class org.springframework.integration.smb.config.SmbStreamingInboundChannelAdapterParser
 
getSimplePatternFileListFilterClassName() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
getSimplePatternFileListFilterClassName() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
getSimplePatternFileListFilterClassName() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
 
getSimplePatternFileListFilterClassName() - Method in class org.springframework.integration.smb.config.SmbOutboundGatewayParser
 
getSingleResultForQuery(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
getSingleResultForQuery(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
Execute the provided query to return a single element.
getSize() - Method in class org.springframework.integration.channel.AbstractMessageChannel.ChannelInterceptorList
 
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
 
getSize() - Method in class org.springframework.integration.smb.session.SmbFileInfo
 
getSizeOfIdCache() - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
Return the size of the Message Id Cache, which caches Message Ids for those messages that are currently being processed.
getSmbMaxVersion() - Method in class org.springframework.integration.smb.session.SmbConfig
Gets the desired maximum SMB version value for what the Windows server will allow during protocol transport negotiation.
getSmbMinVersion() - Method in class org.springframework.integration.smb.session.SmbConfig
Gets the desired minimum SMB version value for what the Windows server will allow during protocol transport negotiation.
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 Sockets.
getSocketInfo() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
Provides getters for Socket properties.
getSocketInfo() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getSocketInfo() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
 
getSockJsTaskScheduler() - Method in class org.springframework.integration.websocket.ServerWebSocketContainer
 
getSoLinger() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSoLinger() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getSoLinger() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getSoLinger() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
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.tcp.connection.ThreadAffinityClientConnectionFactory
 
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
 
getSoSendBufferSize() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
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
 
getSoTimeout() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getSoTimeout() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getSoTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSoTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
getSoTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
getSource(String) - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getSourceAsType() - Method in class org.springframework.integration.events.IntegrationEvent
Get the source as a specific type; the receiving variable must be declared with the correct type.
getSourceCount() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getSourceData() - Method in class org.springframework.integration.IntegrationMessageHeaderAccessor
Get the source data header, if present.
getSourceData(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getSourceNames() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
 
getSpecificTargetClasses() - Method in class org.springframework.integration.json.JsonIndexAccessor
 
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
 
getSrcPath() - Method in class org.springframework.integration.sftp.server.PathMovedEvent
 
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.
getSslHandshakeTimeout() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
 
getSslSession() - Method in interface org.springframework.integration.ip.tcp.connection.TcpConnection
 
getSslSession() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
 
getSslSession() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetConnection
 
getSslSession() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioConnection
 
getSslSession() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioSSLConnection
 
getStatusCodeExpression() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getStompCommand() - Method in class org.springframework.integration.stomp.event.StompReceiptEvent
 
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
Create a new BeanDefinitionBuilder for the class StoredProcExecutor.
getStoreLock() - Method in class org.springframework.integration.store.MessageGroupQueue
Get the store lock.
getStreamOperations() - Method in class org.springframework.integration.amqp.outbound.RabbitStreamMessageHandler
getSubProtocols() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
 
getSubProtocols() - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
getSubProtocols() - Method in class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
Return the List of sub-protocols from provided SubProtocolHandler.
getSubscriberCount() - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
 
getSubscriberCount() - Method in interface org.springframework.integration.support.management.SubscribableChannelManagement
The number of message handlers currently subscribed to this channel.
getSuccesses() - Method in class org.springframework.integration.graph.ReceiveCounters
 
getSuccesses() - Method in class org.springframework.integration.graph.SendTimers
 
getSuperClassName() - Method in class org.springframework.integration.config.annotation.AnnotationMetadataAdapter
 
getSupportedMediaTypes() - Method in class org.springframework.integration.http.converter.MultipartAwareFormHttpMessageConverter
 
getSupportedProtocols() - Method in class org.springframework.integration.websocket.support.PassThruSubProtocolHandler
 
getSynchronizer() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
Return the underlying synchronizer.
getTaskExecutor() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
 
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() - Method in class org.springframework.integration.context.IntegrationObjectSupport
 
getTaskScheduler(BeanFactory) - Static method in class org.springframework.integration.context.IntegrationContextUtils
 
getTaskSchedulerPoolSize() - Method in class org.springframework.integration.context.IntegrationProperties
getTcpNoDelay() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
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
 
getTemplate() - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
 
getTemplateClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileOutboundGatewayParser
 
getTemplateClass() - Method in class org.springframework.integration.file.config.AbstractRemoteFileStreamingInboundChannelAdapterParser
 
getTemplateClass() - Method in class org.springframework.integration.file.config.RemoteFileOutboundChannelAdapterParser
 
getTemplateClass() - Method in class org.springframework.integration.ftp.config.FtpOutboundChannelAdapterParser
 
getTemplateClass() - Method in class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
 
getTemplateClass() - Method in class org.springframework.integration.ftp.config.FtpStreamingInboundChannelAdapterParser
 
getTemplateClass() - Method in class org.springframework.integration.sftp.config.SftpOutboundChannelAdapterParser
 
getTemplateClass() - Method in class org.springframework.integration.sftp.config.SftpOutboundGatewayParser
 
getTemplateClass() - Method in class org.springframework.integration.sftp.config.SftpStreamingInboundChannelAdapterParser
 
getTemplateClass() - Method in class org.springframework.integration.smb.config.SmbOutboundChannelAdapterParser
 
getTemplateClass() - Method in class org.springframework.integration.smb.config.SmbOutboundGatewayParser
 
getTemplateClass() - Method in class org.springframework.integration.smb.config.SmbStreamingInboundChannelAdapterParser
 
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
Return 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
 
getThisAs() - Method in interface org.springframework.integration.support.management.IntegrationManagement
Return this IntegrationManagement as its concrete type.
getTimestamp() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
getTimestamp() - Method in interface org.springframework.integration.store.MessageGroup
 
getTimestamp() - Method in class org.springframework.integration.store.MessageGroupMetadata
 
getTimestamp() - Method in class org.springframework.integration.store.MessageMetadata
 
getTimestamp() - Method in class org.springframework.integration.store.SimpleMessageGroup
 
getTimestamp(RFC5424SyslogParser.Reader) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser
Default implementation returns the date as a String (if present).
getTimestamp(Message<?>) - Static method in class org.springframework.integration.StaticMessageHeaderAccessor
 
getTimeToLive() - Method in class org.springframework.integration.jms.DynamicJmsTemplate
 
getTo() - Method in class org.springframework.integration.graph.LinkNode
 
getTopic() - Method in class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory.Will
 
getTopic() - Method in class org.springframework.integration.mqtt.event.MqttMessageSentEvent
 
getTopic() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getTopicPartition() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
getTopicPartition() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
getTopicProcessor() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getTrafficClass() - Method in class org.springframework.integration.ip.tcp.connection.SocketInfo
 
getTransactionSynchronizationFactory() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.AbstractTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ClaimCheckInParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ClaimCheckOutParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.HeaderEnricherParserSupport
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.HeaderFilterParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.JsonToObjectTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.MapToObjectTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ObjectToMapTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.ObjectToStringTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.PayloadDeserializingTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.PayloadSerializingTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.StreamTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.config.xml.SyslogToMapTransformerParser
 
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
 
getTransformerClassName() - Method in class org.springframework.integration.zip.config.xml.UnZipTransformerParser
 
getTransformerClassName() - Method in class org.springframework.integration.zip.config.xml.ZipTransformerParser
 
getTransientHeaderNames() - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Return the transient header names.
getTrigger() - Method in class org.springframework.integration.scheduling.PollerMetadata
 
getType() - Method in class org.springframework.integration.graph.CompositeMessageHandlerNode.InnerHandler
 
getType() - Method in class org.springframework.integration.graph.LinkNode
 
getType() - Method in class org.springframework.integration.history.MessageHistory.Entry
 
getType() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
 
getTypeConverter() - Method in class org.springframework.integration.config.AbstractEvaluationContextFactoryBean
 
getUpdateExpression() - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
 
getUpdateQuery() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
Return the current update query.
getUrl() - Method in class org.springframework.integration.mqtt.core.AbstractMqttClientManager
 
getUrl() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
 
getUrl() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
 
getUrl() - Method in class org.springframework.integration.smb.session.SmbConfig
 
getUrl() - Method in enum class org.springframework.integration.xml.selector.XmlValidatingMessageSelector.SchemaType
 
getUrl(boolean) - Method in class org.springframework.integration.smb.session.SmbConfig
 
getUserData() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint.CorrelationDataWrapper
 
getUserFlag() - Method in class org.springframework.integration.mail.AbstractMailReceiver
 
getUsername() - Method in class org.springframework.integration.smb.session.SmbConfig
 
getUUID(Object) - Static method in class org.springframework.integration.util.UUIDConverter
Convenient utility to convert an object to a UUID.
getValidator() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
getValue() - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue() - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue() - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue() - Method in class org.springframework.integration.expression.ValueExpression
 
getValue() - Method in class org.springframework.integration.jdbc.storedproc.ProcedureParameter
 
getValue() - Method in class org.springframework.integration.jpa.support.JpaParameter
 
getValue(Class<C>) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(Class<T>) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(Class<T>) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(Object, Class<C>) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(Object, Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(Object, Class<T>) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(Object, Class<T>) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(String) - Method in class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSource
 
getValue(String) - Method in class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory.ExpressionEvaluatingParameterSource
 
getValue(String) - Method in interface org.springframework.integration.jpa.support.parametersource.ParameterSource
Return the parameter value for the requested named parameter.
getValue(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(EvaluationContext) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(EvaluationContext) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(EvaluationContext) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(EvaluationContext, Class<C>) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(EvaluationContext, Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(EvaluationContext, Class<T>) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(EvaluationContext, Class<T>) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValue(EvaluationContext, Object, Class<C>) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValue(EvaluationContext, Object, Class<T>) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValue(EvaluationContext, Object, Class<T>) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValue(EvaluationContext, Object, Class<T>) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueByPosition(int) - Method in class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory.ExpressionEvaluatingParameterSource
 
getValueByPosition(int) - Method in interface org.springframework.integration.jpa.support.parametersource.PositionSupportingParameterSource
 
getValueType() - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueType() - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueType() - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueType() - Method in class org.springframework.integration.expression.ValueExpression
 
getValueType(Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueType(Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueType(Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueType(Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueType(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueType(EvaluationContext) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueType(EvaluationContext) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueType(EvaluationContext) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueType(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueType(EvaluationContext, Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueType(EvaluationContext, Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueType(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueTypeDescriptor() - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueTypeDescriptor() - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueTypeDescriptor() - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueTypeDescriptor() - Method in class org.springframework.integration.expression.ValueExpression
 
getValueTypeDescriptor(Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueTypeDescriptor(Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueTypeDescriptor(Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueTypeDescriptor(Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueTypeDescriptor(EvaluationContext) - Method in class org.springframework.integration.expression.ValueExpression
 
getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.integration.expression.DynamicExpression
 
getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.integration.expression.FunctionExpression
 
getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.integration.expression.SupplierExpression
 
getValueTypeDescriptor(EvaluationContext, Object) - Method in class org.springframework.integration.expression.ValueExpression
 
getWebServiceTemplate() - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
 
getWebSocketHandler() - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
 
getXmppConnection() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
 
getXmppConnection() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
 
getXPathExpresion() - Method in class org.springframework.integration.xml.selector.AbstractXPathMessageSelector
 
GLOBAL_CHANNEL_INTERCEPTOR_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
GlobalChannelInterceptor - Annotation Interface in org.springframework.integration.config
ChannelInterceptor components with this annotation will be applied as global channel interceptors using the provided patterns to match channel names.
GlobalChannelInterceptorInitializer - Class in org.springframework.integration.config
GlobalChannelInterceptorInitializer() - Constructor for class org.springframework.integration.config.GlobalChannelInterceptorInitializer
 
GlobalChannelInterceptorParser - Class in org.springframework.integration.config.xml
Parser for 'channel-interceptor' elements.
GlobalChannelInterceptorParser() - Constructor for class org.springframework.integration.config.xml.GlobalChannelInterceptorParser
 
GlobalChannelInterceptorProcessor - Class in org.springframework.integration.config
This class applies global interceptors (<channel-interceptor> or @GlobalChannelInterceptor) to message channels beans.
GlobalChannelInterceptorProcessor() - Constructor for class org.springframework.integration.config.GlobalChannelInterceptorProcessor
 
GlobalChannelInterceptorWrapper - Class in org.springframework.integration.channel.interceptor
 
GlobalChannelInterceptorWrapper(ChannelInterceptor) - Constructor for class org.springframework.integration.channel.interceptor.GlobalChannelInterceptorWrapper
 
GlobalWireTapParser - Class in org.springframework.integration.config.xml
Parser for the top level 'wire-tap' element.
GlobalWireTapParser() - Constructor for class org.springframework.integration.config.xml.GlobalWireTapParser
 
Graph - Class in org.springframework.integration.graph
This object can be exposed, for example, as a JSON object over HTTP.
Graph(Map<String, Object>, Collection<IntegrationNode>, Collection<LinkNode>) - Constructor for class org.springframework.integration.graph.Graph
 
GRAPH_CONTROLLER_BEAN_NAME - Static variable in class org.springframework.integration.http.config.HttpContextUtils
Represents the bean name for the default IntegrationGraphController.
GRAPH_CONTROLLER_DEFAULT_PATH - Static variable in class org.springframework.integration.http.config.HttpContextUtils
Represents the default request mapping path for the IntegrationGraphController.
GRAPH_CONTROLLER_PATH_PROPERTY - Static variable in class org.springframework.integration.http.config.HttpContextUtils
Represents the environment property for the IntegrationGraphController request mapping path.
GraphQl - Class in org.springframework.integration.graphql.dsl
Factory class for GraphQL components DSL.
GraphQlMessageHandler - Class in org.springframework.integration.graphql.outbound
An AbstractReplyProducingMessageHandler capable of fielding GraphQL Query, Mutation and Subscription requests.
GraphQlMessageHandler(ExecutionGraphQlService) - Constructor for class org.springframework.integration.graphql.outbound.GraphQlMessageHandler
 
GraphQlMessageHandlerSpec - Class in org.springframework.integration.graphql.dsl
GraphQlMessageHandlerSpec(ExecutionGraphQlService) - Constructor for class org.springframework.integration.graphql.dsl.GraphQlMessageHandlerSpec
 
GroovyAwareScriptExecutingProcessorFactory - Class in org.springframework.integration.groovy.config
The factory to create GroovyScriptExecutingMessageProcessor instances if provided language == "groovy", otherwise delegates to the super class.
GroovyAwareScriptExecutingProcessorFactory() - Constructor for class org.springframework.integration.groovy.config.GroovyAwareScriptExecutingProcessorFactory
 
GroovyCommandMessageProcessor - Class in org.springframework.integration.groovy
Deprecated, for removal: This API element is subject to removal in a future version.
GroovyCommandMessageProcessor() - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Deprecated.
GroovyCommandMessageProcessor(Binding) - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Deprecated.
Creates a GroovyCommandMessageProcessor that will use the DefaultScriptVariableGenerator and provided Binding.
GroovyCommandMessageProcessor(Binding, ScriptVariableGenerator) - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Deprecated.
Creates a GroovyCommandMessageProcessor that will use the provided ScriptVariableGenerator and Binding.
GroovyCommandMessageProcessor(ScriptVariableGenerator) - Constructor for class org.springframework.integration.groovy.GroovyCommandMessageProcessor
Deprecated.
Creates a GroovyCommandMessageProcessor that will use the provided ScriptVariableGenerator.
GroovyControlBusFactoryBean - Class in org.springframework.integration.groovy.config
Deprecated, for removal: This API element is subject to removal in a future version.
GroovyControlBusFactoryBean() - Constructor for class org.springframework.integration.groovy.config.GroovyControlBusFactoryBean
Deprecated.
 
GroovyControlBusParser - Class in org.springframework.integration.groovy.config
Deprecated, for removal: This API element is subject to removal in a future version.
in favor of ControlBusParser
GroovyControlBusParser() - Constructor for class org.springframework.integration.groovy.config.GroovyControlBusParser
Deprecated.
 
GroovyIntegrationConfigurationInitializer - Class in org.springframework.integration.groovy.config
The Groovy Module Integration infrastructure beanFactory initializer.
GroovyIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.groovy.config.GroovyIntegrationConfigurationInitializer
 
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
The MessageProcessor implementation to evaluate Groovy scripts.
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
 
GROUP_CONDITION - Static variable in class org.springframework.integration.file.aggregator.FileMarkerReleaseStrategy
GROUP_ID - Static variable in class org.springframework.integration.mongodb.store.MessageDocumentFields
 
GroupConditionProvider - Interface in org.springframework.integration.aggregator
A contract which can be implemented on the ReleaseStrategy and used in the AbstractCorrelatingMessageHandler to populate the provided group condition supplier.
groupConditionSupplier(BiFunction<Message<?>, String, String>) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure a BiFunction to supply a group condition from a message to be added to the group.
groupId - Variable in class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
 
groupId(String) - Method in class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
Set the group id to use on the consumer side.
groupId(String) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the group id for this container.
groupIdQuery(Object) - Static method in class org.springframework.integration.mongodb.store.AbstractConfigurableMongoDbMessageStore
 
groupTimeout(long) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with a group timeout expression that evaluates to this constant value.
groupTimeout(Function<MessageGroup, ?>) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure the handler with a function that will be invoked to resolve the group timeout, based on the message group.
groupTimeoutExpression(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Specify a SpEL expression to evaluate the group timeout for scheduled expiration.
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form