Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
O
- OBJECT_NAME - Static variable in class org.springframework.integration.jmx.JmxHeaders
- objectName() - Element in annotation interface org.springframework.integration.support.management.IntegrationManagedResource
- ObjectStringMapBuilder - Class in org.springframework.integration.support
- 
A map builder creating a map with Object keys and String values.
- ObjectStringMapBuilder() - Constructor for class org.springframework.integration.support.ObjectStringMapBuilder
- ObjectStringMessageConverter - Class in org.springframework.integration.support.converter
- 
AStringMessageConverterextension to convert any object to string.
- ObjectStringMessageConverter() - Constructor for class org.springframework.integration.support.converter.ObjectStringMessageConverter
- ObjectToJsonTransformer - Class in org.springframework.integration.json
- 
Transformer implementation that converts a payload instance into a JSON string representation.
- ObjectToJsonTransformer() - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
- ObjectToJsonTransformer(ObjectToJsonTransformer.ResultType) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
- ObjectToJsonTransformer(JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
- ObjectToJsonTransformer(JsonObjectMapper<?, ?>, ObjectToJsonTransformer.ResultType) - Constructor for class org.springframework.integration.json.ObjectToJsonTransformer
- ObjectToJsonTransformer.ResultType - Enum Class in org.springframework.integration.json
- ObjectToJsonTransformerParser - Class in org.springframework.integration.config.xml
- ObjectToJsonTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToJsonTransformerParser
- ObjectToMapTransformer - Class in org.springframework.integration.transformer
- 
Transforms an object graph into a Map.
- ObjectToMapTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToMapTransformer
- 
Construct with the defaultJsonObjectMapperinstance available viafactory.
- ObjectToMapTransformer(JsonObjectMapper<?, ?>) - Constructor for class org.springframework.integration.transformer.ObjectToMapTransformer
- 
Construct with the providedJsonObjectMapperinstance.
- ObjectToMapTransformerParser - Class in org.springframework.integration.config.xml
- ObjectToMapTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToMapTransformerParser
- objectToString() - Static method in class org.springframework.integration.dsl.Transformers
- objectToString(String) - Static method in class org.springframework.integration.dsl.Transformers
- ObjectToStringTransformer - Class in org.springframework.integration.transformer
- 
A simple transformer that creates an outbound payload by invoking the inbound payload Object'stoString()method.
- ObjectToStringTransformer() - Constructor for class org.springframework.integration.transformer.ObjectToStringTransformer
- ObjectToStringTransformer(String) - Constructor for class org.springframework.integration.transformer.ObjectToStringTransformer
- ObjectToStringTransformerParser - Class in org.springframework.integration.config.xml
- 
Parser for the 'object-to-string-transformer' element.
- ObjectToStringTransformerParser() - Constructor for class org.springframework.integration.config.xml.ObjectToStringTransformerParser
- observationPatterns() - Element in annotation interface org.springframework.integration.config.EnableIntegrationManagement
- 
Set simple pattern component names matching for observation registry injection.
- ObservationPropagationChannelInterceptor - Class in org.springframework.integration.channel.interceptor
- 
TheExecutorChannelInterceptorimplementation responsible for anObservationpropagation from one message flow's thread to another through theMessageChannels involved in the flow.
- ObservationPropagationChannelInterceptor(ObservationRegistry) - Constructor for class org.springframework.integration.channel.interceptor.ObservationPropagationChannelInterceptor
- obtain(Object) - Method in class org.springframework.integration.hazelcast.lock.HazelcastLockRegistry
- obtain(Object) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
- obtain(Object) - Method in class org.springframework.integration.redis.util.RedisLockRegistry
- obtain(Object) - Method in class org.springframework.integration.support.locks.DefaultLockRegistry
- 
Obtains a lock by masking the lockKey's hashCode() with the mask and using the result as an index to the lock table.
- obtain(Object) - Method in interface org.springframework.integration.support.locks.LockRegistry
- 
Obtains the lock associated with the parameter object.
- obtain(Object) - Method in class org.springframework.integration.support.locks.PassThruLockRegistry
- obtain(Object) - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
- obtainComponentName(NamedComponent) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
- 
Obtain a component name from the providedNamedComponent.
- obtainConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
- obtainConnection() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
- obtainConnection() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
- obtainConnection(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
- obtainGroupTimeout(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- obtainInputChannelFromFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- obtainInputChannelFromFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.EndpointSpec
- 
Try to get aMessageChannelas an input for the providedIntegrationFlowor create one and wrap the provided flow to a new one.
- obtainInputChannelFromFlow(IntegrationFlow, boolean) - Method in class org.springframework.integration.dsl.EndpointSpec
- 
Try to get aMessageChannelas an input for the providedIntegrationFlowor create one and wrap the provided flow to a new one.
- obtainNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
- obtainPropagatingContext(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ObservationPropagationChannelInterceptor
- obtainPropagatingContext(Message<?>, MessageChannel) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
- obtainPropagatingContext(Message<?>, MessageChannel) - Method in class org.springframework.integration.security.channel.SecurityContextPropagationChannelInterceptor
- obtainQueueName(String) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- obtainQueueName(String) - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
- obtainSecurityMetadataSource() - Method in class org.springframework.integration.security.channel.ChannelSecurityInterceptor
- 
Deprecated.
- obtainSharedConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
- obtainSizeIfPossible(Iterable<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
- 
Obtain a size of the providedIterable.
- obtainSizeIfPossible(Iterator<?>) - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
- 
Obtain a size of the providedIterator.
- obtainSizeIfPossible(Iterator<?>) - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
- of(Message<?>) - Static method in class org.springframework.integration.support.MutableMessage
- 
Build a newMutableMessagebased on the provided message if that one is not already aMutableMessage.
- offer(Message<?>) - Method in class org.springframework.integration.store.MessageGroupQueue
- offer(Message<?>, long, TimeUnit) - Method in class org.springframework.integration.store.MessageGroupQueue
- oldValue - Variable in class org.springframework.integration.hazelcast.message.EntryEventMessagePayload
- 
The entry old value if any.
- onAdd(String, String) - Method in interface org.springframework.integration.metadata.MetadataStoreListener
- 
Invoked when a key is added to the store.
- onAdd(String, String) - Method in class org.springframework.integration.metadata.MetadataStoreListenerAdapter
- onAppendEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
- onApplicationEvent(ApplicationEvent) - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
- onApplicationEvent(ApplicationContextEvent) - Method in class org.springframework.integration.config.IdGeneratorConfigurer
- onApplicationEvent(ContextClosedEvent) - Method in class org.springframework.integration.config.IntegrationManagementConfigurer
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.graph.IntegrationGraphServer
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.handler.DelayHandler
- 
HandleContextRefreshedEventto invokeDelayHandler.reschedulePersistedMessages()as late as possible after application context startup.
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
- 
HttpRequestHandlingEndpointSupports may depend on auto-createdrequestChannels, so MVC Handlers detection should be postponed as late as possible.
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
- 
TheNotificationListenermight not be registered onAbstractEndpoint.start()because theMBeanExportermight not been started yet.
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
- 
HttpRequestHandlingEndpointSupports may depend on auto-createdrequestChannels, so MVC Handlers detection should be postponed as late as possible.
- onApplicationEvent(AbstractLeaderEvent) - Method in class org.springframework.integration.support.SmartLifecycleRoleController
- onClose(Connection) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- onComplete() - Method in class org.springframework.integration.handler.AbstractMessageHandler
- onConnect(FtpSession) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
- onCreate(Connection) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- onDeleteEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
- onDisconnect(FtpSession) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
- onError(Throwable) - Method in class org.springframework.integration.handler.AbstractMessageHandler
- onError(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
- OnFailedToAcquireMutexEvent - Class in org.springframework.integration.leader.event
- 
Generic event representing that a mutex could not be acquired during leader election.
- OnFailedToAcquireMutexEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.OnFailedToAcquireMutexEvent
- 
Instantiate a new OnFailedToAcquireMutexEvent.
- onFailure(Message<File>) - Method in class org.springframework.integration.file.FileReadingMessageSource
- 
Adds the failed message back to the 'toBeReceived' queue if there is room.
- onGranted(Context) - Method in class org.springframework.integration.leader.AbstractCandidate
- onGranted(Context) - Method in interface org.springframework.integration.leader.Candidate
- 
Callback method invoked when this candidate is elected leader.
- onGranted(Context) - Method in class org.springframework.integration.leader.DefaultCandidate
- OnGrantedEvent - Class in org.springframework.integration.leader.event
- 
Generic event representing that leader has been granted.
- OnGrantedEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.OnGrantedEvent
- 
Instantiates a new granted event.
- onInit() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- onInit() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- onInit() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
- onInit() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- onInit() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- onInit() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
- onInit() - Method in class org.springframework.integration.channel.AbstractMessageChannel
- onInit() - Method in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
- onInit() - Method in class org.springframework.integration.channel.DirectChannel
- onInit() - Method in class org.springframework.integration.channel.ExecutorChannel
- onInit() - Method in class org.springframework.integration.channel.PartitionedChannel
- onInit() - Method in class org.springframework.integration.channel.PublishSubscribeChannel
- 
Callback method for initialization.
- onInit() - Method in class org.springframework.integration.context.IntegrationObjectSupport
- 
Subclasses may implement this for initialization logic.
- onInit() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
- onInit() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
- onInit() - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
- onInit() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
- onInit() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
- onInit() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
- onInit() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
- onInit() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
- onInit() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
- onInit() - Method in class org.springframework.integration.file.FileReadingMessageSource
- onInit() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
- onInit() - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
- onInit() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
- onInit() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
- onInit() - Method in class org.springframework.integration.gateway.AnnotationGatewayProxyFactoryBean
- onInit() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
- onInit() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- onInit() - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
- onInit() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
- onInit() - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
- onInit() - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
- onInit() - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
- onInit() - Method in class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
- onInit() - Method in class org.springframework.integration.handler.LoggingHandler
- onInit() - Method in class org.springframework.integration.handler.MessageHandlerChain
- onInit() - Method in class org.springframework.integration.hazelcast.inbound.HazelcastEventDrivenMessageProducer
- onInit() - Method in class org.springframework.integration.hazelcast.outbound.HazelcastCacheWritingMessageHandler
- onInit() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
- onInit() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingController
- onInit() - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
- 
Locates theMultipartResolverbean based on the default name defined by theDispatcherServlet.MULTIPART_RESOLVER_BEAN_NAMEconstant if available.
- onInit() - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- onInit() - Method in class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
- onInit() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- onInit() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
- onInit() - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
- onInit() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
- onInit() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- onInit() - Method in class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
- onInit() - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
- onInit() - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
- onInit() - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
- onInit() - Method in class org.springframework.integration.jms.JmsInboundGateway
- onInit() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
- onInit() - Method in class org.springframework.integration.jms.JmsSendingMessageHandler
- onInit() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
- onInit() - Method in class org.springframework.integration.jmx.NotificationPublishingMessageHandler
- onInit() - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
- 
Subclasses may implement this for initialization logic.
- onInit() - Method in class org.springframework.integration.jpa.inbound.JpaPollingChannelAdapter
- 
Check for mandatory attributes.
- onInit() - Method in class org.springframework.integration.json.JsonToObjectTransformer
- onInit() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
- onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
- onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
- onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
- onInit() - Method in class org.springframework.integration.mail.AbstractMailReceiver
- onInit() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
- onInit() - Method in class org.springframework.integration.mail.ImapMailReceiver
- onInit() - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
- onInit() - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
- onInit() - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
- onInit() - Method in class org.springframework.integration.mongodb.outbound.MongoDbStoringMessageHandler
- onInit() - Method in class org.springframework.integration.mongodb.outbound.ReactiveMongoDbStoringMessageHandler
- onInit() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
- onInit() - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
- onInit() - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- onInit() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
- onInit() - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
- onInit() - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- onInit() - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
- onInit() - Method in class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler
- onInit() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
- onInit() - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
- onInit() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
- onInit() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
- onInit() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
- onInit() - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
- onInit() - Method in class org.springframework.integration.redis.outbound.ReactiveRedisStreamMessageHandler
- onInit() - Method in class org.springframework.integration.redis.outbound.RedisPublishingMessageHandler
- onInit() - Method in class org.springframework.integration.redis.outbound.RedisQueueOutboundChannelAdapter
- onInit() - Method in class org.springframework.integration.redis.outbound.RedisStoreWritingMessageHandler
- onInit() - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
- onInit() - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
- onInit() - Method in class org.springframework.integration.router.MethodInvokingRouter
- onInit() - Method in class org.springframework.integration.router.AbstractMessageRouter
- onInit() - Method in class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
- onInit() - Method in class org.springframework.integration.router.RecipientListRouter
- onInit() - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
- onInit() - Method in class org.springframework.integration.stomp.outbound.StompMessageHandler
- onInit() - Method in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
- onInit() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
- onInit() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
- onInit() - Method in class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
- onInit() - Method in class org.springframework.integration.transformer.DecodingTransformer
- onInit() - Method in class org.springframework.integration.transformer.FromProtobufTransformer
- onInit() - Method in class org.springframework.integration.transformer.HeaderEnricher
- onInit() - Method in class org.springframework.integration.transformer.HeaderFilter
- onInit() - Method in class org.springframework.integration.transformer.MapToObjectTransformer
- onInit() - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
- onInit() - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
- onInit() - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
- onInit() - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
- onInit() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
- onInit() - Method in class org.springframework.integration.websocket.outbound.WebSocketOutboundMessageHandler
- onInit() - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
- onInit() - Method in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
- onInit() - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
- onInit() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareEndpoint
- onInit() - Method in class org.springframework.integration.xmpp.core.AbstractXmppConnectionAwareMessageHandler
- onInit() - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
- onInit() - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
- onInit() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
- onInit() - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
- onInit() - Method in class org.springframework.integration.zip.transformer.AbstractZipTransformer
- OnlyOnceTrigger - Class in org.springframework.integration.test.util
- OnlyOnceTrigger() - Constructor for class org.springframework.integration.test.util.OnlyOnceTrigger
- onMessage(Message) - Method in class org.springframework.integration.jms.JmsOutboundGateway
- onMessage(Message, Session) - Method in class org.springframework.integration.jms.ChannelPublishingJmsMessageListener
- onMessage(Message, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.Listener
- onMessage(Message, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway.Listener
- onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionInterceptorSupport
- onMessage(Message<?>) - Method in interface org.springframework.integration.ip.tcp.connection.TcpListener
- 
Called by a TCPConnection when a new message arrives.
- onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
- onMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
- onMessage(Message<?>) - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
- onMessage(WebSocketSession, WebSocketMessage<?>) - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
- onMessage(WebSocketSession, WebSocketMessage<?>) - Method in interface org.springframework.integration.websocket.WebSocketListener
- 
Handle the receivedWebSocketMessage.
- onMessageBatch(List<Message>, Channel) - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchListener
- onMkdirEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
- onNext(Message<?>) - Method in class org.springframework.integration.handler.AbstractMessageHandler
- onPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
- 
Specify aBiConsumerfor seeks management duringConsumerSeekAware.onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)call from theKafkaMessageListenerContainer.
- onPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
- 
Specify aBiConsumerfor seeks management duringConsumerSeekAware.onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)call from theKafkaMessageListenerContainer.
- onRemove(String, String) - Method in interface org.springframework.integration.metadata.MetadataStoreListener
- 
Invoked when a key is removed from the store.
- onRemove(String, String) - Method in class org.springframework.integration.metadata.MetadataStoreListenerAdapter
- onRenameEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
- onRevoked(Context) - Method in class org.springframework.integration.leader.AbstractCandidate
- onRevoked(Context) - Method in interface org.springframework.integration.leader.Candidate
- 
Callback method invoked when this candidate is no longer leader.
- onRevoked(Context) - Method in class org.springframework.integration.leader.DefaultCandidate
- OnRevokedEvent - Class in org.springframework.integration.leader.event
- 
Generic event representing that leader has been revoked.
- OnRevokedEvent(Object, Context, String) - Constructor for class org.springframework.integration.leader.event.OnRevokedEvent
- 
Instantiates a new revoked event.
- onRmdirEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
- onRotation(MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
- 
Update the state of theMessageSourceafter the server is rotated, if necessary.
- onSubscribe(Subscription) - Method in class org.springframework.integration.handler.AbstractMessageHandler
- onUpdate(String, String) - Method in interface org.springframework.integration.metadata.MetadataStoreListener
- 
Invoked when a key is updated into the store.
- onUpdate(String, String) - Method in class org.springframework.integration.metadata.MetadataStoreListenerAdapter
- onUploadEnd(FtpSession, FtpRequest) - Method in class org.springframework.integration.ftp.server.ApacheMinaFtplet
- open(RetryContext, RetryCallback<T, E>) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
- openFolder() - Method in class org.springframework.integration.mail.AbstractMailReceiver
- operation(String) - Method in class org.springframework.integration.graphql.dsl.GraphQlMessageHandlerSpec
- operation(Function<Message<?>, String>) - Method in class org.springframework.integration.graphql.dsl.GraphQlMessageHandlerSpec
- OPERATION_NAME - Static variable in class org.springframework.integration.jmx.JmxHeaders
- operationExpression(String) - Method in class org.springframework.integration.graphql.dsl.GraphQlMessageHandlerSpec
- operationExpression(Expression) - Method in class org.springframework.integration.graphql.dsl.GraphQlMessageHandlerSpec
- OperationInvokingChannelAdapterParser - Class in org.springframework.integration.jmx.config
- OperationInvokingChannelAdapterParser() - Constructor for class org.springframework.integration.jmx.config.OperationInvokingChannelAdapterParser
- OperationInvokingMessageHandler - Class in org.springframework.integration.jmx
- 
AMessageHandlerimplementation for invoking JMX operations based on the Message sent to itsAbstractMessageHandler.handleMessage(Message)method.
- OperationInvokingMessageHandler(MBeanServerConnection) - Constructor for class org.springframework.integration.jmx.OperationInvokingMessageHandler
- 
Construct an instance based on the providedMBeanServerConnection.
- OperationInvokingOutboundGatewayParser - Class in org.springframework.integration.jmx.config
- OperationInvokingOutboundGatewayParser() - Constructor for class org.springframework.integration.jmx.config.OperationInvokingOutboundGatewayParser
- operationName(String) - Method in class org.springframework.integration.graphql.dsl.GraphQlMessageHandlerSpec
- operationName(Function<Message<?>, String>) - Method in class org.springframework.integration.graphql.dsl.GraphQlMessageHandlerSpec
- operationNameExpression(String) - Method in class org.springframework.integration.graphql.dsl.GraphQlMessageHandlerSpec
- operationNameExpression(Expression) - Method in class org.springframework.integration.graphql.dsl.GraphQlMessageHandlerSpec
- options(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Specify the array of options for various gateway commands.
- options(ChangeStreamOptions) - Method in class org.springframework.integration.mongodb.dsl.MongoDbChangeStreamMessageProducerSpec
- 
Configure aChangeStreamOptions.
- options(AbstractRemoteFileOutboundGateway.Option...) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Specify the array ofAbstractRemoteFileOutboundGateway.Optionfor various gateway commands.
- OracleChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
- 
Contains Oracle-specific queries for theJdbcChannelMessageStore.
- OracleChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.OracleChannelMessageStoreQueryProvider
- order() - Element in annotation interface org.springframework.integration.config.EnablePublisher
- 
Indicate the order in which thePublisherAnnotationBeanPostProcessorshould be applied.
- order() - Element in annotation interface org.springframework.integration.config.GlobalChannelInterceptor
- 
The order of the interceptor.
- order(int) - Method in class org.springframework.integration.dsl.BarrierSpec
- order(int) - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
- ORDER - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
- Orderable - Interface in org.springframework.integration.context
- 
Interface that extendsOrderedwhile also exposing theOrderable.setOrder(int)as an interface-level so that it is avaiable on AOP proxies, etc.
- OrderlyShutdownCapable - Interface in org.springframework.integration.context
- 
Interface for components that wish to be considered for an orderly shutdown using management interfaces.
- orderlyShutdownCapableComponentsAfter() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
- orderlyShutdownCapableComponentsBefore() - Method in class org.springframework.integration.monitor.IntegrationMBeanExporter
- org.springframework.integration - package org.springframework.integration
- 
Base package for Spring Integration Core.
- org.springframework.integration.acks - package org.springframework.integration.acks
- 
Provides classes related to message acknowledgment.
- org.springframework.integration.aggregator - package org.springframework.integration.aggregator
- 
Provides classes related to message aggregation.
- org.springframework.integration.amqp.channel - package org.springframework.integration.amqp.channel
- 
Provides classes related to AMQP-backed channels.
- org.springframework.integration.amqp.config - package org.springframework.integration.amqp.config
- 
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.amqp.dsl - package org.springframework.integration.amqp.dsl
- 
Provides AMQP Component support for the Java DSL.
- org.springframework.integration.amqp.inbound - package org.springframework.integration.amqp.inbound
- 
Provides classes supporting inbound endpoints.
- org.springframework.integration.amqp.outbound - package org.springframework.integration.amqp.outbound
- 
Provides classes supporting outbound endpoints.
- org.springframework.integration.amqp.support - package org.springframework.integration.amqp.support
- 
Provides AMQP support classes.
- org.springframework.integration.annotation - package org.springframework.integration.annotation
- 
Provides annotations for annotation-based configuration.
- org.springframework.integration.aop - package org.springframework.integration.aop
- 
Provides classes to support message publication using AOP.
- org.springframework.integration.camel.dsl - package org.springframework.integration.camel.dsl
- 
Provides supporting classes for JavaDSL with Apache Camel components.
- org.springframework.integration.camel.outbound - package org.springframework.integration.camel.outbound
- 
Provides classes for Apache Camel outbound channel adapters.
- org.springframework.integration.camel.support - package org.springframework.integration.camel.support
- 
Provides supporting classes for Apache Camel channel adapters.
- org.springframework.integration.cassandra.config.xml - package org.springframework.integration.cassandra.config.xml
- 
Provides classes for Cassandra parsers and namespace handlers.
- org.springframework.integration.cassandra.dsl - package org.springframework.integration.cassandra.dsl
- 
Provides Apache Cassandra Components support for the Java DSL.
- org.springframework.integration.cassandra.outbound - package org.springframework.integration.cassandra.outbound
- 
Provides classes supporting Cassandra outbound endpoints.
- org.springframework.integration.channel - package org.springframework.integration.channel
- 
Provides classes representing various channel types.
- org.springframework.integration.channel.interceptor - package org.springframework.integration.channel.interceptor
- 
Provides classes related to channel interception.
- org.springframework.integration.codec - package org.springframework.integration.codec
- 
Provides base classes for theCodecabstraction.
- org.springframework.integration.codec.kryo - package org.springframework.integration.codec.kryo
- 
The Kryo specificCodecclasses.
- org.springframework.integration.config - package org.springframework.integration.config
- 
Base package for configuration.
- org.springframework.integration.config.annotation - package org.springframework.integration.config.annotation
- 
Provides classes supporting annotation-based configuration.
- org.springframework.integration.config.xml - package org.springframework.integration.config.xml
- 
Provides supporting XML-based configuration - parsers, namespace handlers.
- org.springframework.integration.context - package org.springframework.integration.context
- 
Provides classes relating to application context configuration.
- org.springframework.integration.core - package org.springframework.integration.core
- 
Provides core classes.
- org.springframework.integration.dispatcher - package org.springframework.integration.dispatcher
- 
Provides classes related to dispatching messages.
- org.springframework.integration.dsl - package org.springframework.integration.dsl
- 
Root package of the Spring Integration Java DSL.
- org.springframework.integration.dsl.context - package org.springframework.integration.dsl.context
- 
The context support classes for Spring Integration Java DSL.
- org.springframework.integration.dsl.support - package org.springframework.integration.dsl.support
- 
Provides various support classes used across Spring Integration Java DSL Components.
- org.springframework.integration.endpoint - package org.springframework.integration.endpoint
- 
Provides core classes related to Endpoints.
- org.springframework.integration.event.config - package org.springframework.integration.event.config
- 
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.event.core - package org.springframework.integration.event.core
- 
Provides Event core classes.
- org.springframework.integration.event.inbound - package org.springframework.integration.event.inbound
- 
Provides classes supporting inbound endpoints.
- org.springframework.integration.event.outbound - package org.springframework.integration.event.outbound
- 
Provides classes supporting outbound endpoints.
- org.springframework.integration.events - package org.springframework.integration.events
- 
ApplicationEvents generated by the Spring Integration framework.
- org.springframework.integration.expression - package org.springframework.integration.expression
- 
Provides classes supporting SpEL expressions.
- org.springframework.integration.feed.config - package org.springframework.integration.feed.config
- 
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.feed.dsl - package org.springframework.integration.feed.dsl
- 
Provides Feed Components support for Spring Integration Java DSL.
- org.springframework.integration.feed.inbound - package org.springframework.integration.feed.inbound
- 
Provides classes supporting inbound endpoints.
- org.springframework.integration.file - package org.springframework.integration.file
- 
Base package for File support.
- org.springframework.integration.file.aggregator - package org.springframework.integration.file.aggregator
- 
Provides support classes for file-based aggregation logic.
- org.springframework.integration.file.config - package org.springframework.integration.file.config
- 
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.file.dsl - package org.springframework.integration.file.dsl
- 
Provides File Components support for Spring Integration Java DSL.
- org.springframework.integration.file.event - package org.springframework.integration.file.event
- 
ApplicationEvents generated by the file module.
- org.springframework.integration.file.filters - package org.springframework.integration.file.filters
- 
Provides classes supporting file filtering.
- org.springframework.integration.file.locking - package org.springframework.integration.file.locking
- 
Provides classes supporting file locking.
- org.springframework.integration.file.remote - package org.springframework.integration.file.remote
- 
Base package for supporting remote files.
- org.springframework.integration.file.remote.aop - package org.springframework.integration.file.remote.aop
- 
Provides classes related to AOP.
- org.springframework.integration.file.remote.gateway - package org.springframework.integration.file.remote.gateway
- 
Provides classes supporting remote file gateways.
- org.springframework.integration.file.remote.handler - package org.springframework.integration.file.remote.handler
- 
Provides classes supporting remote file message handlers.
- org.springframework.integration.file.remote.server - package org.springframework.integration.file.remote.server
- 
Provides classes related to file servers.
- org.springframework.integration.file.remote.session - package org.springframework.integration.file.remote.session
- 
Provides classes supporting remote file sessions.
- org.springframework.integration.file.remote.synchronizer - package org.springframework.integration.file.remote.synchronizer
- 
Provides classes supporting the synchronization of remote and local file directories.
- org.springframework.integration.file.splitter - package org.springframework.integration.file.splitter
- 
Provides implementations ofAbstractMessageSplitter.
- org.springframework.integration.file.support - package org.springframework.integration.file.support
- 
Provides various support classes used across Spring Integration File Components.
- org.springframework.integration.file.tail - package org.springframework.integration.file.tail
- 
Classes used for tailing file system files.
- org.springframework.integration.file.transformer - package org.springframework.integration.file.transformer
- 
Provides classes supporting the transformation of file contents to messages.
- org.springframework.integration.filter - package org.springframework.integration.filter
- 
Provides classes supporting the filter pattern.
- org.springframework.integration.ftp.config - package org.springframework.integration.ftp.config
- 
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.ftp.dsl - package org.springframework.integration.ftp.dsl
- 
Provides FTP Components for the Java DSL.
- org.springframework.integration.ftp.filters - package org.springframework.integration.ftp.filters
- 
Provides classes supporting FTP file filtering.
- org.springframework.integration.ftp.gateway - package org.springframework.integration.ftp.gateway
- 
Provides classes supporting FTP gateways.
- org.springframework.integration.ftp.inbound - package org.springframework.integration.ftp.inbound
- 
Provides classes supporting inbound endpoints.
- org.springframework.integration.ftp.outbound - package org.springframework.integration.ftp.outbound
- 
Provides classes for the FTP outbound channel adapter.
- org.springframework.integration.ftp.server - package org.springframework.integration.ftp.server
- 
Provides classes related to FTP servers.
- org.springframework.integration.ftp.session - package org.springframework.integration.ftp.session
- 
Provides classes supporting FTP sessions.
- org.springframework.integration.gateway - package org.springframework.integration.gateway
- 
Provides classes supporting messaging gateways.
- org.springframework.integration.graph - package org.springframework.integration.graph
- 
Provides classes related to the runtime object graph.
- org.springframework.integration.graphql.dsl - package org.springframework.integration.graphql.dsl
- 
Provides classes for Java DSL to support GraphQL components.
- org.springframework.integration.graphql.outbound - package org.springframework.integration.graphql.outbound
- 
Provides classes for GraphQL outbound channel adapters.
- org.springframework.integration.groovy - package org.springframework.integration.groovy
- 
Base package for Groovy support.
- org.springframework.integration.groovy.config - package org.springframework.integration.groovy.config
- 
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.handler - package org.springframework.integration.handler
- 
Provides classes implementing various types of message handler.
- org.springframework.integration.handler.advice - package org.springframework.integration.handler.advice
- 
Provides classes that are used to adviseMessageHandlers with cross-cutting concerns.
- org.springframework.integration.handler.support - package org.springframework.integration.handler.support
- 
Provides classes for message handlers support.
- org.springframework.integration.hazelcast - package org.springframework.integration.hazelcast
- 
Provides common used types and classes.
- org.springframework.integration.hazelcast.config - package org.springframework.integration.hazelcast.config
- 
Provides classes for configuration.
- org.springframework.integration.hazelcast.config.xml - package org.springframework.integration.hazelcast.config.xml
- 
Provides classes for parsers and namespace handlers.
- org.springframework.integration.hazelcast.inbound - package org.springframework.integration.hazelcast.inbound
- 
Provides classes supporting inbound endpoints.
- org.springframework.integration.hazelcast.leader - package org.springframework.integration.hazelcast.leader
- 
Provides the Leader Initiator support classes.
- org.springframework.integration.hazelcast.listener - package org.springframework.integration.hazelcast.listener
- 
Provides classes for listeners.
- org.springframework.integration.hazelcast.lock - package org.springframework.integration.hazelcast.lock
- 
Provides the distributed Locks support classes.
- org.springframework.integration.hazelcast.message - package org.springframework.integration.hazelcast.message
- 
Provides classes supporting Hazelcast message headers and payload.
- org.springframework.integration.hazelcast.metadata - package org.springframework.integration.hazelcast.metadata
- 
Provides the Metadata Store support classes.
- org.springframework.integration.hazelcast.outbound - package org.springframework.integration.hazelcast.outbound
- 
Provides classes supporting outbound endpoints.
- org.springframework.integration.hazelcast.store - package org.springframework.integration.hazelcast.store
- 
Provides the Message Store support classes.
- org.springframework.integration.history - package org.springframework.integration.history
- 
Provides classes supporting the capture of message history.
- org.springframework.integration.http - package org.springframework.integration.http
- 
Base package for Http support.
- org.springframework.integration.http.config - package org.springframework.integration.http.config
- 
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.http.converter - package org.springframework.integration.http.converter
- 
Provides classes supporting message conversion.
- org.springframework.integration.http.dsl - package org.springframework.integration.http.dsl
- 
Provides HTTP Components support for Spring Integration Java DSL.
- org.springframework.integration.http.inbound - package org.springframework.integration.http.inbound
- 
Provides classes supporting inbound endpoints.
- org.springframework.integration.http.management - package org.springframework.integration.http.management
- 
Provides classes related to management support.
- org.springframework.integration.http.multipart - package org.springframework.integration.http.multipart
- 
Provides classes supporting multipart HTTP requests.
- org.springframework.integration.http.outbound - package org.springframework.integration.http.outbound
- 
Provides classes supporting outbound endpoints.
- org.springframework.integration.http.support - package org.springframework.integration.http.support
- 
Provides classes to support Http endpoints, including header mapping.
- org.springframework.integration.ip - package org.springframework.integration.ip
- 
Base package for IP (TCP/UDP) Support.
- org.springframework.integration.ip.config - package org.springframework.integration.ip.config
- 
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.ip.dsl - package org.springframework.integration.ip.dsl
- 
Provides TCP/UDP Component support for the Java DSL.
- org.springframework.integration.ip.event - package org.springframework.integration.ip.event
- 
ApplicationEvents generated by the ip module.
- org.springframework.integration.ip.tcp - package org.springframework.integration.ip.tcp
- 
Base package for TCP Support.
- org.springframework.integration.ip.tcp.connection - package org.springframework.integration.ip.tcp.connection
- 
All things related to tcp connections - client and server factories; listener and sender interfaces.
- org.springframework.integration.ip.tcp.serializer - package org.springframework.integration.ip.tcp.serializer
- 
Byte array (de)serializers for putting some protocol on the wire so that incoming messages can be constructed from stream data.
- org.springframework.integration.ip.udp - package org.springframework.integration.ip.udp
- 
Base package for UDP support.
- org.springframework.integration.ip.util - package org.springframework.integration.ip.util
- 
Provides utilities for IP support.
- org.springframework.integration.jdbc - package org.springframework.integration.jdbc
- 
Root package of the Spring Integration JDBC module, which contains various JDBC and Stored Procedure/Function supporting components.
- org.springframework.integration.jdbc.channel - package org.springframework.integration.jdbc.channel
- 
Provides a message channel-specific JDBC API.
- org.springframework.integration.jdbc.config - package org.springframework.integration.jdbc.config
- 
Contains parser classes for the JDBC namespace support.
- org.springframework.integration.jdbc.lock - package org.springframework.integration.jdbc.lock
- org.springframework.integration.jdbc.metadata - package org.springframework.integration.jdbc.metadata
- 
Contains JDBC implementation of MetadataStore
- org.springframework.integration.jdbc.store - package org.springframework.integration.jdbc.store
- 
Provides JDBC-backed Message Store implementations.
- org.springframework.integration.jdbc.store.channel - package org.springframework.integration.jdbc.store.channel
- 
Provides support classes for the JdbcChannelMessageStore.
- org.springframework.integration.jdbc.storedproc - package org.springframework.integration.jdbc.storedproc
- 
Provides Stored Procedure/Function supporting classes.
- org.springframework.integration.jms - package org.springframework.integration.jms
- 
Base package for JMS Support.
- org.springframework.integration.jms.config - package org.springframework.integration.jms.config
- 
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.jms.dsl - package org.springframework.integration.jms.dsl
- 
Provides JMS Component support for the Java DSL.
- org.springframework.integration.jms.util - package org.springframework.integration.jms.util
- org.springframework.integration.jmx - package org.springframework.integration.jmx
- 
Base package for JMX support.
- org.springframework.integration.jmx.config - package org.springframework.integration.jmx.config
- 
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.jpa.config.xml - package org.springframework.integration.jpa.config.xml
- 
Provides parser classes to provide Xml namespace support for the Jpa components.
- org.springframework.integration.jpa.core - package org.springframework.integration.jpa.core
- 
Provides core classes of the JPA module.
- org.springframework.integration.jpa.dsl - package org.springframework.integration.jpa.dsl
- 
Provides JPA Components support for Java DSL.
- org.springframework.integration.jpa.inbound - package org.springframework.integration.jpa.inbound
- 
Provides inbound Spring Integration Jpa components.
- org.springframework.integration.jpa.outbound - package org.springframework.integration.jpa.outbound
- 
Provides Spring Integration components for doing outbound operations.
- org.springframework.integration.jpa.support - package org.springframework.integration.jpa.support
- 
Provides various support classes used across Spring Integration Jpa Components.
- org.springframework.integration.jpa.support.parametersource - package org.springframework.integration.jpa.support.parametersource
- 
Provides generic support for ParameterSources and ParameterSource Factories.
- org.springframework.integration.json - package org.springframework.integration.json
- 
Provides classes supporting JSON in Spring Integration.
- org.springframework.integration.kafka.channel - package org.springframework.integration.kafka.channel
- 
Provides classes related to message channel implementations for Apache Kafka.
- org.springframework.integration.kafka.config.xml - package org.springframework.integration.kafka.config.xml
- 
Provides parser classes to provide Xml namespace support for the Apache Kafka components.
- org.springframework.integration.kafka.dsl - package org.springframework.integration.kafka.dsl
- 
Provides Spring Integration Java DSL Components support for Apache Kafka.
- org.springframework.integration.kafka.inbound - package org.springframework.integration.kafka.inbound
- 
Provides Spring Integration inbound components for Apache Kafka.
- org.springframework.integration.kafka.outbound - package org.springframework.integration.kafka.outbound
- 
Provides Spring Integration outbound components for Apache Kafka.
- org.springframework.integration.kafka.support - package org.springframework.integration.kafka.support
- 
Provides support classes.
- org.springframework.integration.leader - package org.springframework.integration.leader
- 
Temporary package until s-c-c-core is released.
- org.springframework.integration.leader.event - package org.springframework.integration.leader.event
- 
Temporary package until s-c-c-core is released.
- org.springframework.integration.mail - package org.springframework.integration.mail
- 
Base package for Mail support.
- org.springframework.integration.mail.config - package org.springframework.integration.mail.config
- 
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.mail.dsl - package org.springframework.integration.mail.dsl
- 
Provides Mail Components for the Java DSL.
- org.springframework.integration.mail.event - package org.springframework.integration.mail.event
- 
Events generated by the mail module
- org.springframework.integration.mail.support - package org.springframework.integration.mail.support
- 
Provides classes to support email.
- org.springframework.integration.mail.transformer - package org.springframework.integration.mail.transformer
- 
Provides classes related to transforming mail messages.
- org.springframework.integration.mapping - package org.springframework.integration.mapping
- 
Provides classes related to mapping to/from message headers.
- org.springframework.integration.mapping.support - package org.springframework.integration.mapping.support
- 
Support classes for mapping.
- org.springframework.integration.message - package org.springframework.integration.message
- 
Provides concreteMessageimplementations.
- org.springframework.integration.metadata - package org.springframework.integration.metadata
- 
Provides classes supporting metadata stores.
- org.springframework.integration.mongodb.config - package org.springframework.integration.mongodb.config
- 
Contains parser classes for the MongoDb namespace support.
- org.springframework.integration.mongodb.dsl - package org.springframework.integration.mongodb.dsl
- 
Provides MongoDB Components support for Java DSL.
- org.springframework.integration.mongodb.inbound - package org.springframework.integration.mongodb.inbound
- 
Provides classes related to the Mongo inbound channel adapters
- org.springframework.integration.mongodb.metadata - package org.springframework.integration.mongodb.metadata
- 
Contains mongodb metadata store related classes
- org.springframework.integration.mongodb.outbound - package org.springframework.integration.mongodb.outbound
- 
Provides classes related to the Mongo outbound channel adapters
- org.springframework.integration.mongodb.store - package org.springframework.integration.mongodb.store
- 
Provides classes related to the MongoDB message store.
- org.springframework.integration.mongodb.support - package org.springframework.integration.mongodb.support
- 
Provides supporting classes for this module.
- org.springframework.integration.monitor - package org.springframework.integration.monitor
- 
Provides classes related to Spring Integration managed resources.
- org.springframework.integration.mqtt.config.xml - package org.springframework.integration.mqtt.config.xml
- 
Provides parser classes to provide Xml namespace support for the MqttAdapter components.
- org.springframework.integration.mqtt.core - package org.springframework.integration.mqtt.core
- 
Provides core classes of the MqttAdapter module.
- org.springframework.integration.mqtt.event - package org.springframework.integration.mqtt.event
- 
ApplicationEvents generated by the mqtt module.
- org.springframework.integration.mqtt.inbound - package org.springframework.integration.mqtt.inbound
- 
Provides inbound Spring Integration MqttAdapter components.
- org.springframework.integration.mqtt.outbound - package org.springframework.integration.mqtt.outbound
- 
Provides Spring Integration components for doing outbound operations.
- org.springframework.integration.mqtt.support - package org.springframework.integration.mqtt.support
- 
Provides various support classes used across Spring Integration MqttAdapter Components.
- org.springframework.integration.r2dbc.dsl - package org.springframework.integration.r2dbc.dsl
- 
Provides classes for supporting Java DSL for R2DBC components.
- org.springframework.integration.r2dbc.inbound - package org.springframework.integration.r2dbc.inbound
- 
Provides classes for supporting R2DBC inbound components.
- org.springframework.integration.r2dbc.outbound - package org.springframework.integration.r2dbc.outbound
- 
Provides classes for supporting R2DBC outbound components.
- org.springframework.integration.redis.channel - package org.springframework.integration.redis.channel
- 
Provides classes related to Redis-backed channels.
- org.springframework.integration.redis.config - package org.springframework.integration.redis.config
- 
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.redis.event - package org.springframework.integration.redis.event
- 
Events generated by the redis module
- org.springframework.integration.redis.inbound - package org.springframework.integration.redis.inbound
- 
Provides classes supporting inbound endpoints.
- org.springframework.integration.redis.metadata - package org.springframework.integration.redis.metadata
- 
Provides support for Redis-basedMetadataStores.
- org.springframework.integration.redis.outbound - package org.springframework.integration.redis.outbound
- 
Provides classes supporting outbound endpoints.
- org.springframework.integration.redis.store - package org.springframework.integration.redis.store
- 
Provides classes related to the Redis message store.
- org.springframework.integration.redis.support - package org.springframework.integration.redis.support
- 
Provides supporting classes for this module.
- org.springframework.integration.redis.util - package org.springframework.integration.redis.util
- 
Provides utility classes.
- org.springframework.integration.resource - package org.springframework.integration.resource
- 
Provides classes related to messaging using SpringResources
- org.springframework.integration.router - package org.springframework.integration.router
- 
Provides classes supporting the router pattern.
- org.springframework.integration.routingslip - package org.springframework.integration.routingslip
- 
Provides classes supporting the RoutingSlip pattern.
- org.springframework.integration.rsocket - package org.springframework.integration.rsocket
- 
Provides common classes for RSocket components.
- org.springframework.integration.rsocket.config - package org.springframework.integration.rsocket.config
- 
Provides classes for RSocket XML namespace parsing and configuration support.
- org.springframework.integration.rsocket.dsl - package org.springframework.integration.rsocket.dsl
- 
Provides RSocket Components support for Spring Integration Java DSL.
- org.springframework.integration.rsocket.inbound - package org.springframework.integration.rsocket.inbound
- 
Provides classes representing inbound RSocket components.
- org.springframework.integration.rsocket.outbound - package org.springframework.integration.rsocket.outbound
- 
Provides classes representing outbound RSocket components.
- org.springframework.integration.scattergather - package org.springframework.integration.scattergather
- 
Provides classes supporting the Scatter-Gather pattern.
- org.springframework.integration.scheduling - package org.springframework.integration.scheduling
- 
Provides classes related to task scheduling.
- org.springframework.integration.scripting - package org.springframework.integration.scripting
- 
Base package for scripting support.
- org.springframework.integration.scripting.config - package org.springframework.integration.scripting.config
- 
Base package supporting configuration.
- org.springframework.integration.scripting.config.jsr223 - package org.springframework.integration.scripting.config.jsr223
- 
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.scripting.dsl - package org.springframework.integration.scripting.dsl
- 
Provides Scripting Components support for Spring Integration Java DSL.
- org.springframework.integration.scripting.jsr223 - package org.springframework.integration.scripting.jsr223
- 
Provides classes supporting JSR223 Scripting.
- org.springframework.integration.security.channel - package org.springframework.integration.security.channel
- 
Provides classes related to secured channels.
- org.springframework.integration.security.config - package org.springframework.integration.security.config
- 
Provides classes for configuration - parsers, namespace handlers, bean post processors.
- org.springframework.integration.selector - package org.springframework.integration.selector
- 
Provides classes related to message selection.
- org.springframework.integration.sftp.config - package org.springframework.integration.sftp.config
- 
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.sftp.dsl - package org.springframework.integration.sftp.dsl
- 
Provides SFTP Components for the Java DSL.
- org.springframework.integration.sftp.filters - package org.springframework.integration.sftp.filters
- 
Provides classes supporting SFTP file filtering.
- org.springframework.integration.sftp.gateway - package org.springframework.integration.sftp.gateway
- 
Provides classes supporting SFTP gateways.
- org.springframework.integration.sftp.inbound - package org.springframework.integration.sftp.inbound
- 
Provides classes supporting inbound endpoints.
- org.springframework.integration.sftp.outbound - package org.springframework.integration.sftp.outbound
- 
Provides classes for the SFTP outbound channel adapter.
- org.springframework.integration.sftp.server - package org.springframework.integration.sftp.server
- 
Provides classes related to SFTP servers.
- org.springframework.integration.sftp.session - package org.springframework.integration.sftp.session
- 
Provides classes supporting SFTP sessions.
- org.springframework.integration.smb.config - package org.springframework.integration.smb.config
- 
SMB-specific file list filter classes.
- org.springframework.integration.smb.dsl - package org.springframework.integration.smb.dsl
- 
Provides SMB Components for the Java DSL.
- org.springframework.integration.smb.filters - package org.springframework.integration.smb.filters
- 
SMB Namespace support classes.
- org.springframework.integration.smb.inbound - package org.springframework.integration.smb.inbound
- 
Inbound Channel Adapters implementations for SMB protocol.
- org.springframework.integration.smb.outbound - package org.springframework.integration.smb.outbound
- 
Outbound Channel Adapter implementations for SMB protocol.
- org.springframework.integration.smb.session - package org.springframework.integration.smb.session
- 
SMB Remote Session abstraction support classes.
- org.springframework.integration.splitter - package org.springframework.integration.splitter
- 
Provides classes supporting the splitter pattern.
- org.springframework.integration.stomp - package org.springframework.integration.stomp
- 
Provides core classes STOMP components.
- org.springframework.integration.stomp.config - package org.springframework.integration.stomp.config
- 
Contains parser classes for the STOMP namespace support.
- org.springframework.integration.stomp.event - package org.springframework.integration.stomp.event
- org.springframework.integration.stomp.inbound - package org.springframework.integration.stomp.inbound
- 
Provides classes which represent inbound STOMP components.
- org.springframework.integration.stomp.outbound - package org.springframework.integration.stomp.outbound
- 
Provides classes which represent outbound STOMP components.
- org.springframework.integration.stomp.support - package org.springframework.integration.stomp.support
- 
Provides classes to support STOMP components.
- org.springframework.integration.store - package org.springframework.integration.store
- 
Provides classes releated to storing messages.
- org.springframework.integration.stream - package org.springframework.integration.stream
- 
Base package for stream support.
- org.springframework.integration.stream.config - package org.springframework.integration.stream.config
- 
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.support - package org.springframework.integration.support
- 
Base core support package.
- org.springframework.integration.support.channel - package org.springframework.integration.support.channel
- org.springframework.integration.support.context - package org.springframework.integration.support.context
- 
Provides classes supporting use of the application context.
- org.springframework.integration.support.converter - package org.springframework.integration.support.converter
- 
Provides classes supporting message conversion.
- org.springframework.integration.support.json - package org.springframework.integration.support.json
- 
Provides classes supporting json.
- org.springframework.integration.support.leader - package org.springframework.integration.support.leader
- org.springframework.integration.support.locks - package org.springframework.integration.support.locks
- 
Provides classes related to locking resources.
- org.springframework.integration.support.management - package org.springframework.integration.support.management
- 
Provides classes related to management support.
- org.springframework.integration.support.management.metrics - package org.springframework.integration.support.management.metrics
- 
Provides interfaces related to 5.0 metrics.
- org.springframework.integration.support.management.micrometer - package org.springframework.integration.support.management.micrometer
- 
Provides classes to support the use of Micrometer for metrics.
- org.springframework.integration.support.management.observation - package org.springframework.integration.support.management.observation
- 
Provides classes to support of Micrometer Observation API.
- org.springframework.integration.support.utils - package org.springframework.integration.support.utils
- 
Provides global utility support classes for the runtime system.
- org.springframework.integration.syslog - package org.springframework.integration.syslog
- 
Base package for Syslog Support.
- org.springframework.integration.syslog.config - package org.springframework.integration.syslog.config
- 
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.integration.syslog.inbound - package org.springframework.integration.syslog.inbound
- 
Provides classes for inbound endpoints.
- org.springframework.integration.test.condition - package org.springframework.integration.test.condition
- org.springframework.integration.test.context - package org.springframework.integration.test.context
- 
Test context-related components.
- org.springframework.integration.test.matcher - package org.springframework.integration.test.matcher
- 
Provides severalBaseMatcherimplementations.
- org.springframework.integration.test.mock - package org.springframework.integration.test.mock
- 
Utilities for mocking integration components.
- org.springframework.integration.test.predicate - package org.springframework.integration.test.predicate
- org.springframework.integration.test.rule - package org.springframework.integration.test.rule
- 
Provides various test rules.
- org.springframework.integration.test.support - package org.springframework.integration.test.support
- 
Provides several test support classes including for testing Spring Integration request-response message scenarios.
- org.springframework.integration.test.util - package org.springframework.integration.test.util
- 
Provides various test utilities, for exampleTestUtilsprovides convenience helpers to easily retrieve private bean properties.
- org.springframework.integration.transaction - package org.springframework.integration.transaction
- 
Provides classes supporting the use of transactions and pseudo transactions in Spring Integration applications.
- org.springframework.integration.transformer - package org.springframework.integration.transformer
- 
Contains core-implementation of various Transformers which includes Enrichers and Filters.
- org.springframework.integration.transformer.support - package org.springframework.integration.transformer.support
- 
Contains support classes for Transformers.
- org.springframework.integration.util - package org.springframework.integration.util
- 
Provides core utility classes.
- org.springframework.integration.webflux.config - package org.springframework.integration.webflux.config
- 
Provides classes for configuration - parsers, namespace handlers.
- org.springframework.integration.webflux.dsl - package org.springframework.integration.webflux.dsl
- 
Provides WebFlux Components support for Spring Integration Java DSL.
- org.springframework.integration.webflux.inbound - package org.springframework.integration.webflux.inbound
- 
Provides classes supporting inbound endpoints.
- org.springframework.integration.webflux.outbound - package org.springframework.integration.webflux.outbound
- 
Provides classes supporting outbound endpoints.
- org.springframework.integration.webflux.support - package org.springframework.integration.webflux.support
- 
Provides classes to support WebFlux endpoints.
- org.springframework.integration.websocket - package org.springframework.integration.websocket
- 
Provides classes used across all WebSocket components.
- org.springframework.integration.websocket.config - package org.springframework.integration.websocket.config
- 
Contains parser classes for the WebSockets namespace support.
- org.springframework.integration.websocket.event - package org.springframework.integration.websocket.event
- org.springframework.integration.websocket.inbound - package org.springframework.integration.websocket.inbound
- 
Provides classes which represent inbound WebSocket components.
- org.springframework.integration.websocket.outbound - package org.springframework.integration.websocket.outbound
- 
Provides classes which represent outbound WebSocket components.
- org.springframework.integration.websocket.support - package org.springframework.integration.websocket.support
- 
Provides support classes used from WebSocket components.
- org.springframework.integration.ws - package org.springframework.integration.ws
- 
Provides several inbound and outbound Web Service components.
- org.springframework.integration.ws.config - package org.springframework.integration.ws.config
- 
Contains parser classes for the Web Services namespace support.
- org.springframework.integration.ws.dsl - package org.springframework.integration.ws.dsl
- 
Contains classes for DSL support.
- org.springframework.integration.xml - package org.springframework.integration.xml
- 
Root package of the XML Module.
- org.springframework.integration.xml.config - package org.springframework.integration.xml.config
- 
Contains parser classes for the XML namespace support.
- org.springframework.integration.xml.result - package org.springframework.integration.xml.result
- 
ProvidesResultFactorythat will returnResult, possibly taking into account payload instance.
- org.springframework.integration.xml.router - package org.springframework.integration.xml.router
- 
Provides XML message routers.
- org.springframework.integration.xml.selector - package org.springframework.integration.xml.selector
- 
Provides XML-centricMessageSelectorimplementations.
- org.springframework.integration.xml.source - package org.springframework.integration.xml.source
- 
Provides variousSourceFactoryimplementations.
- org.springframework.integration.xml.splitter - package org.springframework.integration.xml.splitter
- 
Provides implementations ofAbstractMessageSplitter.
- org.springframework.integration.xml.transformer - package org.springframework.integration.xml.transformer
- 
Provides Transformer and Enricher implementations.
- org.springframework.integration.xml.transformer.support - package org.springframework.integration.xml.transformer.support
- 
Contains support classes for Transformers.
- org.springframework.integration.xml.xpath - package org.springframework.integration.xml.xpath
- 
Provides XPath supporting classes.
- org.springframework.integration.xmpp - package org.springframework.integration.xmpp
- 
Root package of the Spring Integration XMPP Module.
- org.springframework.integration.xmpp.config - package org.springframework.integration.xmpp.config
- 
Contains parser classes for the XMPP namespace support.
- org.springframework.integration.xmpp.core - package org.springframework.integration.xmpp.core
- 
Provides classes shared across all XMPP components.
- org.springframework.integration.xmpp.inbound - package org.springframework.integration.xmpp.inbound
- 
Provides XMPP inbound Endpoint implementations that extendAbstractXmppConnectionAwareEndpoint.
- org.springframework.integration.xmpp.outbound - package org.springframework.integration.xmpp.outbound
- 
Provides XMPP outbound MessageHandler implementations.
- org.springframework.integration.xmpp.support - package org.springframework.integration.xmpp.support
- 
Provides XMPP specific support classes.
- org.springframework.integration.zeromq - package org.springframework.integration.zeromq
- 
Provides common classes for supporting ZeroMQ components.
- org.springframework.integration.zeromq.channel - package org.springframework.integration.zeromq.channel
- 
Provides classes for message channels support over ZeroMQ.
- org.springframework.integration.zeromq.dsl - package org.springframework.integration.zeromq.dsl
- 
Provides classes for supporting ZeroMQ component via Java DSL.
- org.springframework.integration.zeromq.inbound - package org.springframework.integration.zeromq.inbound
- 
Provides classes for inbound channel adapters over ZeroMQ.
- org.springframework.integration.zeromq.outbound - package org.springframework.integration.zeromq.outbound
- 
Provides classes for outbound channel adapters over ZeroMQ.
- org.springframework.integration.zip - package org.springframework.integration.zip
- 
Root package of the Zip Module.
- org.springframework.integration.zip.config.xml - package org.springframework.integration.zip.config.xml
- 
Provides parser classes to provide Xml namespace support for the Zip components.
- org.springframework.integration.zip.splitter - package org.springframework.integration.zip.splitter
- 
Classes to support Splitter pattern for Zip.
- org.springframework.integration.zip.transformer - package org.springframework.integration.zip.transformer
- 
Classes to support Transformer pattern for Zip.
- org.springframework.integration.zookeeper.config - package org.springframework.integration.zookeeper.config
- 
Provides classes related to configuration.
- org.springframework.integration.zookeeper.config.xml - package org.springframework.integration.zookeeper.config.xml
- 
Base package for zookeeper configuration.
- org.springframework.integration.zookeeper.leader - package org.springframework.integration.zookeeper.leader
- 
Temporary package until s-c-c-zookeeper is released.
- org.springframework.integration.zookeeper.lock - package org.springframework.integration.zookeeper.lock
- 
Provides classes related to locking.
- org.springframework.integration.zookeeper.metadata - package org.springframework.integration.zookeeper.metadata
- 
Provides classes supporting the Zookeeper-basedListenableMetadataStore
- origin(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
- 
List of allowed origins, e.g.
- ORIGINAL_FILE - Static variable in class org.springframework.integration.file.FileHeaders
- OSDelegatingFileTailingMessageProducer - Class in org.springframework.integration.file.tail
- 
A file tailing message producer that delegates to the OS tail program.
- OSDelegatingFileTailingMessageProducer() - Constructor for class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
- OTHER - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- outbound_channel_adapter - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- outbound_gateway - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- outboundAdapter() - Static method in class org.springframework.integration.mail.dsl.Mail
- 
AMailSendingMessageHandlerSpecfactory.
- outboundAdapter(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
- 
The factory to produce aJmsOutboundChannelAdapterSpec.
- outboundAdapter(EntityManager) - Static method in class org.springframework.integration.jpa.dsl.Jpa
- 
Create aJpaUpdatingOutboundEndpointSpecbuilder instance for one-way adapter based on the providedEntityManager.
- outboundAdapter(EntityManagerFactory) - Static method in class org.springframework.integration.jpa.dsl.Jpa
- 
Create aJpaUpdatingOutboundEndpointSpecbuilder instance for one-way adapter based on the providedEntityManagerFactory.
- outboundAdapter(File) - Static method in class org.springframework.integration.file.dsl.Files
- 
Create aFileWritingMessageHandlerSpecbuilder for the one-wayFileWritingMessageHandler.
- outboundAdapter(String) - Static method in class org.springframework.integration.file.dsl.Files
- 
Create aFileWritingMessageHandlerSpecbuilder for the one-wayFileWritingMessageHandler.
- outboundAdapter(String) - Static method in class org.springframework.integration.ip.dsl.Udp
- 
Create an outbound unicast channel adapter using the supplied destination expression.
- outboundAdapter(String) - Static method in class org.springframework.integration.mail.dsl.Mail
- 
AMailSendingMessageHandlerSpecfactory based on providehost.
- outboundAdapter(String, int) - Static method in class org.springframework.integration.ip.dsl.Udp
- 
Create an outbound unicast channel adapter using the supplied host and port.
- outboundAdapter(Function<Message<?>, ?>) - Static method in class org.springframework.integration.ip.dsl.Udp
- 
Create an outbound unicast channel adapter using the supplied destination expression.
- outboundAdapter(Function<Message<P>, ?>) - Static method in class org.springframework.integration.file.dsl.Files
- 
Create aFileWritingMessageHandlerSpecbuilder for the one-wayFileWritingMessageHandler.
- outboundAdapter(AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initial AmqpOutboundEndpointSpec (adapter).
- outboundAdapter(Expression) - Static method in class org.springframework.integration.file.dsl.Files
- 
Create aFileWritingMessageHandlerSpecbuilder for the one-wayFileWritingMessageHandler.
- outboundAdapter(SessionFactory<SmbFile>) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
ASmbMessageHandlerSpecfactory for an outbound channel adapter spec.
- outboundAdapter(SessionFactory<SmbFile>, FileExistsMode) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
ASmbMessageHandlerSpecfactory for an outbound channel adapter spec.
- outboundAdapter(SessionFactory<FTPFile>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
AFtpMessageHandlerSpecfactory for an outbound channel adapter spec.
- outboundAdapter(SessionFactory<FTPFile>, FileExistsMode) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
AFtpMessageHandlerSpecfactory for an outbound channel adapter spec.
- outboundAdapter(SessionFactory<SftpClient.DirEntry>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
AnSftpMessageHandlerSpecfactory for an outbound channel adapter spec.
- outboundAdapter(SessionFactory<SftpClient.DirEntry>, FileExistsMode) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
AnSftpMessageHandlerSpecfactory for an outbound channel adapter spec.
- outboundAdapter(FtpRemoteFileTemplate) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
AFtpMessageHandlerSpecfactory for an outbound channel adapter spec.
- outboundAdapter(FtpRemoteFileTemplate, FileExistsMode) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
AFtpMessageHandlerSpecfactory for an outbound channel adapter spec.
- outboundAdapter(AbstractConnectionFactorySpec<?, ?>) - Static method in class org.springframework.integration.ip.dsl.Tcp
- 
Create an outbound gateway using the supplied connection factory.
- outboundAdapter(AbstractConnectionFactory) - Static method in class org.springframework.integration.ip.dsl.Tcp
- 
Create an outbound gateway using the supplied connection factory.
- outboundAdapter(JpaOperations) - Static method in class org.springframework.integration.jpa.dsl.Jpa
- 
Create aJpaUpdatingOutboundEndpointSpecbuilder instance for one-way adapter based on the providedJpaOperations.
- outboundAdapter(SftpRemoteFileTemplate) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
AnSftpMessageHandlerSpecfactory for an outbound channel adapter spec.
- outboundAdapter(SftpRemoteFileTemplate, FileExistsMode) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
AnSftpMessageHandlerSpecfactory for an outbound channel adapter spec.
- outboundAdapter(SmbRemoteFileTemplate) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
ASmbMessageHandlerSpecfactory for an outbound channel adapter spec.
- outboundAdapter(SmbRemoteFileTemplate, FileExistsMode) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
ASmbMessageHandlerSpecfactory for an outbound channel adapter spec.
- outboundAdapter(JmsTemplate) - Static method in class org.springframework.integration.jms.dsl.Jms
- 
The factory to produce aJmsOutboundChannelAdapterSpec.
- outboundAdapter(MailSender) - Static method in class org.springframework.integration.mail.dsl.Mail
- 
A convenient factory method to produceMailSendingMessageHandlerbased on providedMailSender.
- outboundChannelAdapter(String) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for one-way adapter based on provideduri.
- outboundChannelAdapter(String) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for one-way adapter based on provideduri.
- outboundChannelAdapter(String, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for one-way adapter based on provideduriandRestTemplate.
- outboundChannelAdapter(String, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for one-way adapter based on provideduriandWebClient.
- outboundChannelAdapter(URI) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for one-way adapter based on providedURI.
- outboundChannelAdapter(URI) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for one-way adapter based on providedURI.
- outboundChannelAdapter(URI, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for one-way adapter based on providedURIandRestTemplate.
- outboundChannelAdapter(URI, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for one-way adapter based on providedURIandWebClient.
- outboundChannelAdapter(Function<Message<P>, ?>) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for one-way adapter based on providedFunctionto evaluate targeturiagainst request message.
- outboundChannelAdapter(Function<Message<P>, ?>) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for one-way adapter based on providedFunctionto evaluate targeturiagainst request message.
- outboundChannelAdapter(Function<Message<P>, ?>, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for one-way adapter based on providedFunctionto evaluate targeturiagainst request message andRestTemplatefor HTTP exchanges.
- outboundChannelAdapter(Function<Message<P>, ?>, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for one-way adapter based on providedFunctionto evaluate targeturiagainst request message andWebClientfor HTTP exchanges.
- outboundChannelAdapter(ReactiveCassandraOperations) - Static method in class org.springframework.integration.cassandra.dsl.Cassandra
- 
Create an instance ofCassandraMessageHandlerSpecfor the providedReactiveCassandraOperations.
- outboundChannelAdapter(ReactiveCassandraOperations, CassandraMessageHandler.Type) - Static method in class org.springframework.integration.cassandra.dsl.Cassandra
- 
Create an instance ofCassandraMessageHandlerSpecfor the providedReactiveCassandraOperations.
- outboundChannelAdapter(R2dbcEntityOperations) - Static method in class org.springframework.integration.r2dbc.dsl.R2dbc
- 
Create an instance ofR2dbcMessageHandlerSpecfor the providedR2dbcEntityOperations.
- outboundChannelAdapter(Expression) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for one-way adapter based on provided SpELExpressionto evaluate targeturiagainst request message.
- outboundChannelAdapter(Expression) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for one-way adapter based on provided SpELExpressionto evaluate targeturiagainst request message.
- outboundChannelAdapter(Expression, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for one-way adapter based on provided SpELExpressionto evaluate targeturiagainst request message andRestTemplatefor HTTP exchanges.
- outboundChannelAdapter(Expression, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for one-way adapter based on provided SpELExpressionto evaluate targeturiagainst request message andWebClientfor HTTP exchanges.
- outboundChannelAdapter(KafkaTemplate<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- 
Create an initialKafkaProducerMessageHandlerSpec.
- outboundChannelAdapter(ProducerFactory<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- 
Create an initialKafkaProducerMessageHandlerSpecwith ProducerFactory.
- outboundChannelAdapter(ZContext, String) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
- 
Create an instance ofZeroMqMessageHandlerSpecfor the providedZContextand connection URL.
- outboundChannelAdapter(ZContext, String, SocketType) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
- 
Create an instance ofZeroMqMessageHandlerSpecfor the providedZContext, connection URL andSocketType.
- outboundChannelAdapter(ZContext, Supplier<String>) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
- 
Create an instance ofZeroMqMessageHandlerSpecfor the providedZContextand connection URL supplier.
- outboundChannelAdapter(ZContext, Supplier<String>, SocketType) - Static method in class org.springframework.integration.zeromq.dsl.ZeroMq
- 
Create an instance ofZeroMqMessageHandlerSpecfor the providedZContext, connection URL supplier andSocketType.
- outboundGateway(ConnectionFactory) - Static method in class org.springframework.integration.jms.dsl.Jms
- 
The factory to produce aJmsOutboundGatewaySpec.
- outboundGateway(File) - Static method in class org.springframework.integration.file.dsl.Files
- 
Create aFileWritingMessageHandlerSpecbuilder for the gatewayFileWritingMessageHandler.
- outboundGateway(String) - Static method in class org.springframework.integration.file.dsl.Files
- 
Create aFileWritingMessageHandlerSpecbuilder for the gatewayFileWritingMessageHandler.
- outboundGateway(String) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for request-reply gateway based on provideduri.
- outboundGateway(String) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for request-reply gateway based on provideduri.
- outboundGateway(String, Object...) - Static method in class org.springframework.integration.rsocket.dsl.RSockets
- 
Create anRSocketOutboundGatewaySpecbuilder for request-reply gateway based on providedrouteand optional variables to expand route template.
- outboundGateway(String, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for request-reply gateway based on provideduriandRestTemplate.
- outboundGateway(String, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for request-reply gateway based on provideduriandWebClient.
- outboundGateway(URI) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for request-reply gateway based on providedURI.
- outboundGateway(URI) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for request-reply gateway based on providedURI.
- outboundGateway(URI, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for request-reply gateway based on providedURIandRestTemplate.
- outboundGateway(URI, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for request-reply gateway based on providedURIandWebClient.
- outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.file.dsl.Files
- 
Create aFileWritingMessageHandlerSpecbuilder for the gatewayFileWritingMessageHandler.
- outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for request-reply gateway based on providedFunctionto evaluate targeturiagainst request message.
- outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.rsocket.dsl.RSockets
- 
Create anRSocketOutboundGatewaySpecbuilder for request-reply gateway based on providedFunctionto evaluate targetrouteagainst request message.
- outboundGateway(Function<Message<P>, ?>) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for request-reply gateway based on providedFunctionto evaluate targeturiagainst request message.
- outboundGateway(Function<Message<P>, ?>, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for request-reply gateway based on providedFunctionto evaluate targeturiagainst request message andRestTemplatefor HTTP exchanges.
- outboundGateway(Function<Message<P>, ?>, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for request-reply gateway based on providedFunctionto evaluate targeturiagainst request message andWebClientfor HTTP exchanges.
- outboundGateway(AmqpTemplate) - Static method in class org.springframework.integration.amqp.dsl.Amqp
- 
Create an initial AmqpOutboundEndpointSpec (gateway).
- outboundGateway(ReactiveCassandraOperations) - Static method in class org.springframework.integration.cassandra.dsl.Cassandra
- 
Create an instance ofCassandraMessageHandlerSpecfor the providedReactiveCassandraOperationsin an outbound gateway mode.
- outboundGateway(ReactiveCassandraOperations, CassandraMessageHandler.Type) - Static method in class org.springframework.integration.cassandra.dsl.Cassandra
- 
Create an instance ofCassandraMessageHandlerSpecfor the providedReactiveCassandraOperationsin an outbound gateway mode.
- outboundGateway(MongoOperations) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aMongoDbOutboundGatewaySpecbuilder instance based on the providedMongoOperations.
- outboundGateway(MongoDatabaseFactory, MongoConverter) - Static method in class org.springframework.integration.mongodb.dsl.MongoDb
- 
Create aMongoDbOutboundGatewaySpecbuilder instance based on the providedMongoDatabaseFactoryandMongoConverter.
- outboundGateway(Expression) - Static method in class org.springframework.integration.file.dsl.Files
- 
Create aFileWritingMessageHandlerSpecbased on the providedExpressionfor directory.
- outboundGateway(Expression) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for request-reply gateway based on provided SpELExpressionto evaluate targeturiagainst request message.
- outboundGateway(Expression) - Static method in class org.springframework.integration.rsocket.dsl.RSockets
- 
Create anRSocketOutboundGatewaySpecbuilder for request-reply gateway based on provided SpELExpressionto evaluate targetrouteagainst request message.
- outboundGateway(Expression) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for request-reply gateway based on provided SpELExpressionto evaluate targeturiagainst request message.
- outboundGateway(Expression, RestTemplate) - Static method in class org.springframework.integration.http.dsl.Http
- 
Create anHttpMessageHandlerSpecbuilder for request-reply gateway based on provided SpELExpressionto evaluate targeturiagainst request message andRestTemplatefor HTTP exchanges.
- outboundGateway(Expression, WebClient) - Static method in class org.springframework.integration.webflux.dsl.WebFlux
- 
Create anWebFluxMessageHandlerSpecbuilder for request-reply gateway based on provided SpELExpressionto evaluate targeturiagainst request message andWebClientfor HTTP exchanges.
- outboundGateway(RemoteFileTemplate<SmbFile>, String, String) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
Produce aSmbOutboundGatewaySpecbased on theRemoteFileTemplate,AbstractRemoteFileOutboundGateway.Commandandexpressionfor the remoteFilePath.
- outboundGateway(RemoteFileTemplate<SmbFile>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
Produce aSmbOutboundGatewaySpecbased on theRemoteFileTemplate,AbstractRemoteFileOutboundGateway.Commandandexpressionfor the remoteFilePath.
- outboundGateway(RemoteFileTemplate<FTPFile>, String, String) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
Produce aFtpOutboundGatewaySpecbased on theRemoteFileTemplate,AbstractRemoteFileOutboundGateway.Commandandexpressionfor the remoteFilePath.
- outboundGateway(RemoteFileTemplate<FTPFile>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
Produce aFtpOutboundGatewaySpecbased on theRemoteFileTemplate,AbstractRemoteFileOutboundGateway.Commandandexpressionfor the remoteFilePath.
- outboundGateway(RemoteFileTemplate<SftpClient.DirEntry>, String, String) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
Produce aSftpOutboundGatewaySpecbased on theRemoteFileTemplate,AbstractRemoteFileOutboundGateway.Commandandexpressionfor the remoteFilePath.
- outboundGateway(RemoteFileTemplate<SftpClient.DirEntry>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
Produce aSftpOutboundGatewaySpecbased on theRemoteFileTemplate,AbstractRemoteFileOutboundGateway.Commandandexpressionfor the remoteFilePath.
- outboundGateway(SessionFactory<SmbFile>, String, String) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
Produce aSmbOutboundGatewaySpecbased on theSessionFactory,AbstractRemoteFileOutboundGateway.Commandandexpressionfor the remoteFilePath.
- outboundGateway(SessionFactory<SmbFile>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
Produce aSmbOutboundGatewaySpecbased on theSessionFactory,AbstractRemoteFileOutboundGateway.Commandandexpressionfor the remoteFilePath.
- outboundGateway(SessionFactory<SmbFile>, MessageSessionCallback<SmbFile, ?>) - Static method in class org.springframework.integration.smb.dsl.Smb
- 
Produce aSmbOutboundGatewaySpecbased on theMessageSessionCallback.
- outboundGateway(SessionFactory<FTPFile>, String, String) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
Produce aFtpOutboundGatewaySpecbased on theSessionFactory,AbstractRemoteFileOutboundGateway.Commandandexpressionfor the remoteFilePath.
- outboundGateway(SessionFactory<FTPFile>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
Produce aFtpOutboundGatewaySpecbased on theSessionFactory,AbstractRemoteFileOutboundGateway.Commandandexpressionfor the remoteFilePath.
- outboundGateway(SessionFactory<FTPFile>, MessageSessionCallback<FTPFile, ?>) - Static method in class org.springframework.integration.ftp.dsl.Ftp
- 
Produce aFtpOutboundGatewaySpecbased on theMessageSessionCallback.
- outboundGateway(SessionFactory<SftpClient.DirEntry>, String, String) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
Produce aSftpOutboundGatewaySpecbased on theSessionFactory,AbstractRemoteFileOutboundGateway.Commandandexpressionfor the remoteFilePath.
- outboundGateway(SessionFactory<SftpClient.DirEntry>, AbstractRemoteFileOutboundGateway.Command, String) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
Produce aSftpOutboundGatewaySpecbased on theSessionFactory,AbstractRemoteFileOutboundGateway.Commandandexpressionfor the remoteFilePath.
- outboundGateway(SessionFactory<SftpClient.DirEntry>, MessageSessionCallback<SftpClient.DirEntry, ?>) - Static method in class org.springframework.integration.sftp.dsl.Sftp
- 
Produce aSftpOutboundGatewaySpecbased on theMessageSessionCallback.
- outboundGateway(TcpClientConnectionFactorySpec<?, ?>) - Static method in class org.springframework.integration.ip.dsl.Tcp
- 
Create an outbound gateway using the supplied client connection factory.
- outboundGateway(AbstractClientConnectionFactory) - Static method in class org.springframework.integration.ip.dsl.Tcp
- 
Create an outbound gateway using the supplied client connection factory.
- outboundGateway(ProducerFactory<K, V>, GenericMessageListenerContainer<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- 
Create an initialKafkaProducerMessageHandlerSpecwith ProducerFactory.
- outboundGateway(ReplyingKafkaTemplate<K, V, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
- 
Create an initialKafkaProducerMessageHandlerSpec.
- OutboundGatewayType - Enum Class in org.springframework.integration.jpa.support
- 
Indicates the mode of operation for the outbound Jpa Gateway.
- outboundHeaderMapper(AmqpHeaderMapper) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- 
Configure the outbound header mapper to use whenAmqpPollableMessageChannelSpec.extractPayload(boolean)is true.
- outboundHeaderNames(String...) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
- outboundMapper() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- 
Construct a default outbound header mapper.
- outboundMapper() - Static method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
- 
Factory method for creating a basic outbound mapper instance.
- OutboundMessageMapper<T> - Interface in org.springframework.integration.mapping
- 
Strategy interface for mapping from aMessageto an Object.
- outboundMulticastAdapter(String) - Static method in class org.springframework.integration.ip.dsl.Udp
- 
Create an outbound multicast channel adapter using the supplied destination expression.
- outboundMulticastAdapter(String, int) - Static method in class org.springframework.integration.ip.dsl.Udp
- 
Create an outbound multicast channel adapter using the supplied host and port.
- outboundMulticastAdapter(Function<Message<?>, ?>) - Static method in class org.springframework.integration.ip.dsl.Udp
- 
Create an outbound multicast channel adapter using the supplied destination expression.
- outboundReplyHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- outboundRequestHeaders() - Static method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- outboundStreamAdapter(Environment, String) - Static method in class org.springframework.integration.amqp.dsl.RabbitStream
- 
Create an initialRabbitStreamMessageHandlerSpec(adapter).
- outboundStreamAdapter(RabbitStreamTemplate) - Static method in class org.springframework.integration.amqp.dsl.RabbitStream
- 
Create an initialRabbitStreamMessageHandlerSpec(adapter).
- OUTCOME - Enum constant in enum class org.springframework.integration.support.management.observation.IntegrationObservation.GatewayTags
- 
Outcome of the request/reply execution.
- output - Enum constant in enum class org.springframework.integration.graph.LinkNode.Type
- outputChannel() - Element in annotation interface org.springframework.integration.annotation.Aggregator
- outputChannel() - Element in annotation interface org.springframework.integration.annotation.Filter
- 
Specify the channel to which this filter will send messages that pass the selector.
- outputChannel() - Element in annotation interface org.springframework.integration.annotation.ServiceActivator
- 
Specify the channel to which this service activator will send any replies.
- outputChannel() - Element in annotation interface org.springframework.integration.annotation.Splitter
- 
Specify the channel to which this splitter will send any replies.
- outputChannel() - Element in annotation interface org.springframework.integration.annotation.Transformer
- 
Specify the channel to which this transformer will send the transformed message.
- outputChannel(String) - Method in class org.springframework.integration.dsl.MessageProducerSpec
- 
Specify the bean name of theoutputChannelfor theMessageProducer.
- outputChannel(String) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
- outputChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessageProducerSpec
- 
Specify theoutputChannelfor theMessageProducer.
- outputChannel(MessageChannel) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
- outputExpression(String) - Method in class org.springframework.integration.dsl.AggregatorSpec
- 
An expression to determine the output message from the released group.
- outputProcessor(MessageGroupProcessor) - Method in class org.springframework.integration.dsl.AggregatorSpec
- 
A processor to determine the output message from the released group.
- outputProcessor(MessageGroupProcessor) - Method in class org.springframework.integration.dsl.BarrierSpec
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form