Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
D
- DatagramPacketMessageMapper - Class in org.springframework.integration.ip.udp
-
Message Mapper for converting to and from UDP DatagramPackets.
- DatagramPacketMessageMapper() - Constructor for class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
- DATALINK - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- datatype(Class<?>...) - Method in class org.springframework.integration.dsl.MessageChannelSpec
- DATE - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- DATE_FORMATS - Static variable in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
- deBatchingEnabled(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
-
Determine whether the container should de-batch batched messages (true) or call the listener with the batch (false).
- Debezium - Class in org.springframework.integration.debezium.dsl
-
Factory class for Debezium DSL components.
- DebeziumHeaders - Class in org.springframework.integration.debezium.support
-
Pre-defined header names to be used when retrieving Debezium Change Event headers.
- DebeziumHeaders() - Constructor for class org.springframework.integration.debezium.support.DebeziumHeaders
- DebeziumMessageProducer - Class in org.springframework.integration.debezium.inbound
-
Debezium Change Event Channel Adapter.
- DebeziumMessageProducer(DebeziumEngine.Builder<ChangeEvent<byte[], byte[]>>) - Constructor for class org.springframework.integration.debezium.inbound.DebeziumMessageProducer
-
Create new Debezium message producer inbound channel adapter.
- DebeziumMessageProducerSpec - Class in org.springframework.integration.debezium.dsl
- DebeziumMessageProducerSpec(DebeziumEngine.Builder<ChangeEvent<byte[], byte[]>>) - Constructor for class org.springframework.integration.debezium.dsl.DebeziumMessageProducerSpec
- debug() - Static method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
-
The factory to produce Log4j2LevelAdjuster instances for
Level.DEBUG
logging with theorg.springframework.integration
as default category. - DEBUG - Enum constant in enum class org.springframework.integration.handler.LoggingHandler.Level
- DEBUG - Enum constant in enum class org.springframework.integration.syslog.RFC5424SyslogParser.Severity
- DECIMAL - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- decode(byte[], Class<T>) - Method in interface org.springframework.integration.codec.Codec
-
Decode an object of a given type.
- decode(byte[], Class<T>) - Method in class org.springframework.integration.codec.CompositeCodec
- decode(byte[], Class<T>) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
- decode(InputStream, Class<T>) - Method in interface org.springframework.integration.codec.Codec
-
Decode an object of a given type.
- decode(InputStream, Class<T>) - Method in class org.springframework.integration.codec.CompositeCodec
- decode(InputStream, Class<T>) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
- DECODE_ERRORS - Static variable in class org.springframework.integration.syslog.SyslogHeaders
- decodeFluxAsUnit(boolean) - Method in class org.springframework.integration.rsocket.dsl.RSocketInboundGatewaySpec
-
Configure an option to decode an incoming
Flux
as a single unit or each its event separately. - decoding(Codec, Class<T>) - Static method in class org.springframework.integration.dsl.Transformers
-
The factory method for the
DecodingTransformer
. - decoding(Codec, String) - Static method in class org.springframework.integration.dsl.Transformers
-
The factory method for the
DecodingTransformer
. - decoding(Codec, Function<Message<?>, Class<T>>) - Static method in class org.springframework.integration.dsl.Transformers
-
The factory method for the
DecodingTransformer
. - decoding(Codec, Expression) - Static method in class org.springframework.integration.dsl.Transformers
-
The factory method for the
DecodingTransformer
. - DecodingTransformer<T> - Class in org.springframework.integration.transformer
-
AbstractPayloadTransformer
that delegates to a codec to decode the payload from a byte[]. - DecodingTransformer(Codec, Class<T>) - Constructor for class org.springframework.integration.transformer.DecodingTransformer
-
Construct an instance to use the supplied codec to decode to the supplied type.
- DecodingTransformer(Codec, Expression) - Constructor for class org.springframework.integration.transformer.DecodingTransformer
-
Construct an instance to use the supplied codec to decode to the supplied type.
- decorate(MessageHandlingRunnable) - Method in interface org.springframework.integration.dispatcher.MessageHandlingTaskDecorator
- decorateMessage(Message<?>) - Method in interface org.springframework.integration.support.MessageDecorator
- Default - Annotation Interface in org.springframework.integration.annotation
-
Indicates that the class member has some default meaning.
- DEFAULT_ADVICE_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
- DEFAULT_BUSY_WAIT_TIME - Static variable in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
- DEFAULT_COLLECTION_NAME - Static variable in class org.springframework.integration.mongodb.store.ConfigurableMongoDbMessageStore
- DEFAULT_COLLECTION_NAME - Static variable in class org.springframework.integration.mongodb.store.MongoDbChannelMessageStore
-
The default conventional collection name.
- DEFAULT_COMPLETION_TIMEOUT - Static variable in interface org.springframework.integration.mqtt.core.ClientManager
-
The default completion timeout in milliseconds.
- DEFAULT_COMPLETION_TIMEOUT - Static variable in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
The default completion timeout in milliseconds.
- DEFAULT_CONFIGURING_POSTPROCESSOR_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- DEFAULT_CONSUME_DELAY - Static variable in class org.springframework.integration.zeromq.channel.ZeroMqChannel
- DEFAULT_CONSUME_DELAY - Static variable in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
- DEFAULT_DELAY_WHEN_EMPTY - Static variable in class org.springframework.integration.util.IntegrationReactiveUtils
-
A default delay before repeating an empty source
Mono
as 1 secondDuration
. - DEFAULT_DOMAIN - Static variable in class org.springframework.integration.monitor.IntegrationMBeanExporter
- DEFAULT_ERROR_CODE - Static variable in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
The View model key for the error code.
- DEFAULT_ERROR_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
- DEFAULT_ERRORS_KEY - Static variable in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
The View model key for errors.
- DEFAULT_FILE_REGISTRATION_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
- DEFAULT_GENERIC_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
- DEFAULT_HALF_OPEN_AFTER - Static variable in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
-
A half-open duration as 1000 .
- DEFAULT_HASH_MAP_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
- DEFAULT_HEADER_TYPES - Static variable in class org.springframework.integration.support.json.AbstractJsonInboundMessageMapper
- DEFAULT_HEART_BEAT_TIME - Static variable in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
- DEFAULT_INSTANCE - Static variable in class org.springframework.integration.context.IntegrationProperties
-
A singleton with default values.
- DEFAULT_MAX_ATTEMPTS - Static variable in class org.springframework.integration.handler.DelayHandler
- DEFAULT_MAX_MESSAGE_SIZE - Static variable in class org.springframework.integration.ip.tcp.serializer.AbstractByteArraySerializer
-
The default maximum message size when deserializing.
- DEFAULT_MESSAGEHEADERS_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
- DEFAULT_MUTABLE_MESSAGE_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
- DEFAULT_MUTABLE_MESSAGEHEADERS_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
- DEFAULT_NAME - Static variable in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
- DEFAULT_POLLER - Static variable in class org.springframework.integration.scheduling.PollerMetadata
-
A convenient short alias for the global default poller bean name.
- DEFAULT_POLLER_METADATA_BEAN_NAME - Static variable in class org.springframework.integration.scheduling.PollerMetadata
-
The bean name for global default poller.
- DEFAULT_POLLING_PERIOD - Static variable in class org.springframework.integration.endpoint.AbstractPollingEndpoint
-
A default polling period for
PeriodicTrigger
. - DEFAULT_PORT - Static variable in class org.springframework.integration.syslog.inbound.SyslogReceivingChannelAdapterSupport
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.endpoint.PollingConsumer
-
A default receive timeout as 1000L milliseconds.
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.jms.JmsOutboundGateway
-
A default receive timeout in milliseconds.
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
- DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.integration.scheduling.PollerMetadata
-
The default receive timeout as one second.
- DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
- DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
- DEFAULT_REGION - Static variable in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Default region property, used to partition the message store.
- DEFAULT_REPLY_KEY - Static variable in class org.springframework.integration.http.inbound.HttpRequestHandlingController
-
The View model key for reply.
- DEFAULT_REPLY_TIMEOUT - Static variable in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- DEFAULT_RETRY_DELAY - Static variable in class org.springframework.integration.handler.DelayHandler
- DEFAULT_RETRY_INTERVAL - Static variable in class org.springframework.integration.ip.tcp.TcpInboundGateway
-
A default retry interval in milliseconds - 60000L.
- DEFAULT_RETRY_INTERVAL - Static variable in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
A default retry interval for the
ClientModeConnectionManager
rescheduling. - DEFAULT_SEND_BUFFER_SIZE - Static variable in class org.springframework.integration.websocket.IntegrationWebSocketContainer
- DEFAULT_SEND_TIME_LIMIT - Static variable in class org.springframework.integration.websocket.IntegrationWebSocketContainer
- DEFAULT_SI_USER_FLAG - Static variable in class org.springframework.integration.mail.AbstractMailReceiver
-
Default user flag for marking messages as seen by this receiver: "spring-integration-mail-adapter".
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Default value for the table prefix property.
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.metadata.JdbcMetadataStore
-
Default value for the table prefix property.
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
Default value for the table prefix property.
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
Default value for the table prefix property.
- DEFAULT_TAIL_ATTEMPTS_DELAY - Static variable in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
-
The default delay between tail attempts in milliseconds.
- DEFAULT_THRESHOLD - Static variable in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
-
Default threshold is effectively infinite.
- DEFAULT_THRESHOLD - Static variable in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
-
A default failures threshold as 5.
- DEFAULT_TIMEOUT - Static variable in class org.springframework.integration.aggregator.TimeoutCountSequenceSizeReleaseStrategy
-
Default timeout is one minute.
- DEFAULT_TIMEOUT - Static variable in class org.springframework.integration.context.IntegrationContextUtils
-
The default timeout for blocking operations like send and receive messages.
- DEFAULT_TIMEOUT_STRING - Static variable in class org.springframework.integration.context.IntegrationContextUtils
-
A string representation for
IntegrationContextUtils.DEFAULT_TIMEOUT
, e.g. - DEFAULT_TRUSTED_PACKAGES - Static variable in class org.springframework.integration.support.json.JacksonJsonUtils
-
The packages to trust on JSON deserialization by default.
- DEFAULT_TTL - Static variable in class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Default value for the time-to-live property.
- DEFAULT_UUID_ID - Static variable in class org.springframework.integration.codec.kryo.RegistrationIds
- DefaultAggregateHeadersFunction - Class in org.springframework.integration.aggregator
-
The
Function
implementation for a default headers merging in the aggregator component. - DefaultAggregateHeadersFunction() - Constructor for class org.springframework.integration.aggregator.DefaultAggregateHeadersFunction
- DefaultAggregatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
-
This implementation of MessageGroupProcessor will take the messages from the MessageGroup and pass them on in a single message with a Collection as a payload.
- DefaultAggregatingMessageGroupProcessor() - Constructor for class org.springframework.integration.aggregator.DefaultAggregatingMessageGroupProcessor
- DefaultAmqpHeaderMapper - Class in org.springframework.integration.amqp.support
-
Default implementation of
AmqpHeaderMapper
. - DefaultAmqpHeaderMapper(String[], String[]) - Constructor for class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
- DefaultCandidate - Class in org.springframework.integration.leader
-
Simple
Candidate
for leadership. - DefaultCandidate() - Constructor for class org.springframework.integration.leader.DefaultCandidate
-
Instantiate a default candidate.
- DefaultCandidate(String, String) - Constructor for class org.springframework.integration.leader.DefaultCandidate
-
Instantiate a default candidate.
- defaultChannel() - Element in annotation interface org.springframework.integration.config.EnablePublisher
-
The
default-publisher-channel
name. - DefaultConfiguringBeanFactoryPostProcessor - Class in org.springframework.integration.config
-
A
BeanDefinitionRegistryPostProcessor
implementation that registers bean definitions for many infrastructure components with their default configurations. - DefaultDatatypeChannelMessageConverter - Class in org.springframework.integration.support.converter
-
Default message converter for datatype channels.
- DefaultDatatypeChannelMessageConverter() - Constructor for class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
- DefaultDebeziumHeaderMapper - Class in org.springframework.integration.debezium.support
-
Specifies how to convert Debezium
ChangeEvent.headers()
into aMessageHeaders
. - DefaultDebeziumHeaderMapper() - Constructor for class org.springframework.integration.debezium.support.DefaultDebeziumHeaderMapper
- defaultDelay(long) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
- defaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the default delivery mode.
- defaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
-
Configure the delivery mode for messages that don't have an
AmqpHeaders.DELIVERY_MODE
header. - DefaultDirectoryScanner - Class in org.springframework.integration.file
-
Default directory scanner and base class for other directory scanners.
- DefaultDirectoryScanner() - Constructor for class org.springframework.integration.file.DefaultDirectoryScanner
-
Initialize
DefaultDirectoryScanner.filter
with a default list ofFileListFilter
s using aCompositeFileListFilter
:IgnoreHiddenFileListFilter
AcceptOnceFileListFilter
. - defaultDomain() - Element in annotation interface org.springframework.integration.jmx.config.EnableIntegrationMBeanExport
-
The default domain to use when generating JMX ObjectNames.
- defaultEncoding(String) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
-
Set the default encoding.
- DefaultErrorMessageStrategy - Class in org.springframework.integration.support
-
A simple
ErrorMessageStrategy
implementations which produces a error message with original message if theAttributeAccessor
hasErrorMessageUtils.INPUT_MESSAGE_CONTEXT_KEY
attribute. - DefaultErrorMessageStrategy() - Constructor for class org.springframework.integration.support.DefaultErrorMessageStrategy
- defaultFileNameFunction(String) - Static method in class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
-
The default function used to create the file name for the corresponding marker file.
- DefaultFileNameGenerator - Class in org.springframework.integration.file
-
Default implementation of the filename generator strategy.
- DefaultFileNameGenerator() - Constructor for class org.springframework.integration.file.DefaultFileNameGenerator
- defaultFileTypeMap(FileTypeMap) - Method in class org.springframework.integration.mail.dsl.MailSendingMessageHandlerSpec
-
Set the default type map.
- DefaultFtpSessionFactory - Class in org.springframework.integration.ftp.session
-
Default implementation of FTP SessionFactory.
- DefaultFtpSessionFactory() - Constructor for class org.springframework.integration.ftp.session.DefaultFtpSessionFactory
- DefaultFtpsSessionFactory - Class in org.springframework.integration.ftp.session
-
SessionFactory for FTPS.
- DefaultFtpsSessionFactory() - Constructor for class org.springframework.integration.ftp.session.DefaultFtpsSessionFactory
- DefaultHeaderChannelRegistry - Class in org.springframework.integration.channel
-
Converts a channel to a name, retaining a reference to the channel keyed by the name.
- DefaultHeaderChannelRegistry() - Constructor for class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
Construct a registry with the default delay for channel expiry.
- DefaultHeaderChannelRegistry(long) - Constructor for class org.springframework.integration.channel.DefaultHeaderChannelRegistry
-
Construct a registry with the provided delay (milliseconds) for channel expiry.
- DefaultHeaderChannelRegistry.MessageChannelWrapper - Record Class in org.springframework.integration.channel
- defaultHeaders() - Element in annotation interface org.springframework.integration.annotation.MessagingGateway
-
Provides custom message headers.
- DefaultHttpHeaderMapper - Class in org.springframework.integration.http.support
-
Default
HeaderMapper
implementation for HTTP. - DefaultHttpHeaderMapper() - Constructor for class org.springframework.integration.http.support.DefaultHttpHeaderMapper
- DefaultInboundChannelAdapterParser - Class in org.springframework.integration.config.xml
-
Parser for the <inbound-channel-adapter/> element.
- DefaultInboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.DefaultInboundChannelAdapterParser
- DefaultJmsHeaderMapper - Class in org.springframework.integration.jms
-
Default implementation of
JmsHeaderMapper
. - DefaultJmsHeaderMapper() - Constructor for class org.springframework.integration.jms.DefaultJmsHeaderMapper
- DefaultJpaOperations - Class in org.springframework.integration.jpa.core
-
Class similar to JPA template limited to the operations required for the JPA adapters/gateway not using JpaTemplate as the class is deprecated since Spring 3.1.
- DefaultJpaOperations() - Constructor for class org.springframework.integration.jpa.core.DefaultJpaOperations
- DefaultLeaderEventPublisher - Class in org.springframework.integration.leader.event
-
Default implementation of
LeaderEventPublisher
. - DefaultLeaderEventPublisher() - Constructor for class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
-
Instantiates a new leader event publisher.
- DefaultLeaderEventPublisher(ApplicationEventPublisher) - Constructor for class org.springframework.integration.leader.event.DefaultLeaderEventPublisher
-
Instantiates a new leader event publisher.
- DefaultLockRegistry - Class in org.springframework.integration.support.locks
-
Default implementation of
LockRegistry
which uses Masked Hashcode algorithm to obtain locks. - DefaultLockRegistry() - Constructor for class org.springframework.integration.support.locks.DefaultLockRegistry
-
Constructs a DefaultLockRegistry with the default mask 0xFF with 256 locks.
- DefaultLockRegistry(int) - Constructor for class org.springframework.integration.support.locks.DefaultLockRegistry
-
Constructs a DefaultLockRegistry with the supplied mask - the mask must have a value Math.pow(2, n) - 1 where n is 1 to 31, creating a hash of Math.pow(2, n) locks.
- DefaultLockRepository - Class in org.springframework.integration.jdbc.lock
-
The default implementation of the
LockRepository
based on the table from the script presented in theorg/springframework/integration/jdbc/schema-*.sql
. - DefaultLockRepository(DataSource) - Constructor for class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Constructor that initializes the client id that will be associated for all the locks persisted by the store instance to a random
UUID
. - DefaultLockRepository(DataSource, String) - Constructor for class org.springframework.integration.jdbc.lock.DefaultLockRepository
-
Constructor that allows the user to specify a client id that will be associated for all the locks persisted by the store instance.
- defaultLoggingEnabled() - Element in annotation interface org.springframework.integration.config.EnableIntegrationManagement
-
Use for disabling all logging in the main message flow in framework components.
- DefaultMailHeaderMapper - Class in org.springframework.integration.mail.support
-
Maps an inbound
MimeMessage
to aMap
. - DefaultMailHeaderMapper() - Constructor for class org.springframework.integration.mail.support.DefaultMailHeaderMapper
- DefaultMBeanAttributeFilter - Class in org.springframework.integration.jmx
- DefaultMBeanAttributeFilter() - Constructor for class org.springframework.integration.jmx.DefaultMBeanAttributeFilter
- DefaultMBeanObjectConverter - Class in org.springframework.integration.jmx
- DefaultMBeanObjectConverter() - Constructor for class org.springframework.integration.jmx.DefaultMBeanObjectConverter
- DefaultMBeanObjectConverter(MBeanAttributeFilter) - Constructor for class org.springframework.integration.jmx.DefaultMBeanObjectConverter
- DefaultMessageBuilderFactory - Class in org.springframework.integration.support
- DefaultMessageBuilderFactory() - Constructor for class org.springframework.integration.support.DefaultMessageBuilderFactory
- DefaultMessageConverter - Class in org.springframework.integration.syslog
-
Default
MessageConverter
; delegates to aSyslogToMapTransformer
to convert the payload to a map of values and also provides some of the map contents as message headers. - DefaultMessageConverter() - Constructor for class org.springframework.integration.syslog.DefaultMessageConverter
- DefaultMessageReceiverObservationConvention - Class in org.springframework.integration.support.management.observation
-
A default
MessageReceiverObservationConvention
implementation. - DefaultMessageReceiverObservationConvention() - Constructor for class org.springframework.integration.support.management.observation.DefaultMessageReceiverObservationConvention
- DefaultMessageRequestReplyReceiverObservationConvention - Class in org.springframework.integration.support.management.observation
-
A default
MessageRequestReplyReceiverObservationConvention
implementation. - DefaultMessageRequestReplyReceiverObservationConvention() - Constructor for class org.springframework.integration.support.management.observation.DefaultMessageRequestReplyReceiverObservationConvention
- DefaultMessageSenderObservationConvention - Class in org.springframework.integration.support.management.observation
-
A default
MessageSenderObservationConvention
implementation. - DefaultMessageSenderObservationConvention() - Constructor for class org.springframework.integration.support.management.observation.DefaultMessageSenderObservationConvention
- DefaultMessageSplitter - Class in org.springframework.integration.splitter
-
The default Message Splitter implementation.
- DefaultMessageSplitter() - Constructor for class org.springframework.integration.splitter.DefaultMessageSplitter
- DefaultMqttPahoClientFactory - Class in org.springframework.integration.mqtt.core
-
Creates a default
MqttClient
and a set of options as configured. - DefaultMqttPahoClientFactory() - Constructor for class org.springframework.integration.mqtt.core.DefaultMqttPahoClientFactory
- DefaultMqttPahoClientFactory.Will - Class in org.springframework.integration.mqtt.core
- DefaultMultipartFileReader - Class in org.springframework.integration.http.multipart
-
MultipartFileReader
implementation that reads theMultipartFile
content directly into a newMultipartFile
instance that is not restricted to the HTTP request scope. - DefaultMultipartFileReader() - Constructor for class org.springframework.integration.http.multipart.DefaultMultipartFileReader
- DefaultOutboundChannelAdapterParser - Class in org.springframework.integration.config.xml
-
Parser for the <outbound-channel-adapter/> element.
- DefaultOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.config.xml.DefaultOutboundChannelAdapterParser
- defaultOutputChannel() - Element in annotation interface org.springframework.integration.annotation.Router
-
Specify the channel to which this router will send messages for which destination channels are not resolved and
Router.resolutionRequired()
is false. - defaultOutputChannel(String) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
-
Specify a
MessageChannel
bean name as a default output from the router. - defaultOutputChannel(MessageChannel) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
-
Specify a
MessageChannel
as a default output from the router. - defaultOutputToParentFlow() - Method in class org.springframework.integration.dsl.AbstractRouterSpec
-
Make a default output mapping of the router to the parent flow.
- defaultOutputToParentFlow() - Method in class org.springframework.integration.dsl.RouterSpec
-
Make a default output mapping of the router to the parent flow.
- defaultOverwrite(boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
-
Determine the default action to take when setting individual header specifications without an explicit 'overwrite' argument.
- DefaultPahoMessageConverter - Class in org.springframework.integration.mqtt.support
-
Default implementation for mapping to/from Messages.
- DefaultPahoMessageConverter() - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter with default options (qos=0, retain=false, charset=UTF-8).
- DefaultPahoMessageConverter(int, boolean) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter to create outbound messages with the supplied default qos and retain settings and a UTF-8 charset for converting outbound String payloads to
byte[]
and inboundbyte[]
to String (unlesspayloadAdBytes
is true). - DefaultPahoMessageConverter(int, boolean, String) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter to create outbound messages with the supplied default qos and retain settings and the supplied charset.
- DefaultPahoMessageConverter(int, MessageProcessor<Integer>, boolean, MessageProcessor<Boolean>) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter to create outbound messages with the supplied default qos and retained message processors and a UTF-8 charset for converting outbound String payloads to
byte[]
and inboundbyte[]
to String (unlesspayloadAdBytes
is true). - DefaultPahoMessageConverter(int, MessageProcessor<Integer>, boolean, MessageProcessor<Boolean>, String) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter to create outbound messages with the supplied default qos and retain settings and the supplied charset.
- DefaultPahoMessageConverter(String) - Constructor for class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
-
Construct a converter with default options (qos=0, retain=false) and the supplied charset.
- defaultPayloadExpression() - Element in annotation interface org.springframework.integration.annotation.MessagingGateway
-
An expression that will be used to generate the
payload
for all methods in the service interface unless explicitly overridden by a method declaration. - defaultQosProcessor() - Static method in interface org.springframework.integration.mqtt.support.MqttMessageConverter
- defaultReplyChannel() - Element in annotation interface org.springframework.integration.annotation.MessagingGateway
-
Identifies the default channel the gateway proxy will subscribe to, to receive reply
Message
s, the payloads of which will be converted to the return type of the method signature. - defaultReplyDestination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- defaultReplyQueueName(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- defaultReplyTimeout() - Element in annotation interface org.springframework.integration.annotation.MessagingGateway
-
Allows to specify how long this gateway will wait for the reply
Message
before returning. - defaultReplyTimeout(Duration) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec
-
Default reply timeout.
- defaultReplyTo(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
The
defaultReplyTo
address with the form - defaultReplyTopicName(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- defaultRequestChannel() - Element in annotation interface org.springframework.integration.annotation.MessagingGateway
-
Identifies the default channel to which messages will be sent upon invocation of methods of the gateway proxy.
- defaultRequestTimeout() - Element in annotation interface org.springframework.integration.annotation.MessagingGateway
-
Provides the amount of time dispatcher would wait to send a
Message
. - defaultRequeueRejected(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- defaultRetainedProcessor() - Static method in interface org.springframework.integration.mqtt.support.MqttMessageConverter
- DefaultRouterParser - Class in org.springframework.integration.config.xml
-
Parser for the <router/> element.
- DefaultRouterParser() - Constructor for class org.springframework.integration.config.xml.DefaultRouterParser
- defaults() - Static method in class org.springframework.integration.context.IntegrationProperties
- DefaultScriptExecutor - Class in org.springframework.integration.scripting.jsr223
-
Default implementation of the
AbstractScriptExecutor
. - DefaultScriptExecutor(String) - Constructor for class org.springframework.integration.scripting.jsr223.DefaultScriptExecutor
-
Create a DefaultScriptExecutor for the specified language name (JSR233 alias).
- DefaultScriptVariableGenerator - Class in org.springframework.integration.scripting
-
A default
ScriptVariableGenerator
implementation; used by script processors. - DefaultScriptVariableGenerator() - Constructor for class org.springframework.integration.scripting.DefaultScriptVariableGenerator
- DefaultScriptVariableGenerator(Map<String, Object>) - Constructor for class org.springframework.integration.scripting.DefaultScriptVariableGenerator
- DefaultSessionFactoryLocator<F> - Class in org.springframework.integration.file.remote.session
-
The default implementation of
SessionFactoryLocator
using a simple map lookup and an optional default to fall back on. - DefaultSessionFactoryLocator(Map<Object, SessionFactory<F>>) - Constructor for class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
- DefaultSessionFactoryLocator(Map<Object, SessionFactory<F>>, SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.session.DefaultSessionFactoryLocator
- DefaultSftpSessionFactory - Class in org.springframework.integration.sftp.session
-
Factory for creating
SftpSession
instances. - DefaultSftpSessionFactory() - Constructor for class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
- DefaultSftpSessionFactory(boolean) - Constructor for class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
- DefaultSftpSessionFactory(SshClient, boolean) - Constructor for class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
-
Instantiate based on the provided
SshClient
, e.g. - DefaultSftpSessionFactory.ConcurrentSftpClient - Class in org.springframework.integration.sftp.session
-
The
DefaultSftpClient
extension to lock theDefaultSftpClient.send(int, Buffer)
for concurrent interaction. - DefaultSoapHeaderMapper - Class in org.springframework.integration.ws
-
A
HeaderMapper
implementation for mapping to and from a SoapHeader. - DefaultSoapHeaderMapper() - Constructor for class org.springframework.integration.ws.DefaultSoapHeaderMapper
- defaultSubFlowMapping(IntegrationFlow) - Method in class org.springframework.integration.dsl.AbstractRouterSpec
-
Specify an
IntegrationFlow
as an output from the router when no any other mapping has matched. - DefaultTcpNetConnectionSupport - Class in org.springframework.integration.ip.tcp.connection
-
Default implementation of
TcpNetConnectionSupport
. - DefaultTcpNetConnectionSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNetConnectionSupport
- DefaultTcpNetSocketFactorySupport - Class in org.springframework.integration.ip.tcp.connection
-
Implementation of TcpSocketFactorySupport for non-SSL sockets
ServerSocket
andSocket
. - DefaultTcpNetSocketFactorySupport() - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSocketFactorySupport
- DefaultTcpNetSSLSocketFactorySupport - Class in org.springframework.integration.ip.tcp.connection
- DefaultTcpNetSSLSocketFactorySupport(TcpSSLContextSupport) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNetSSLSocketFactorySupport
- DefaultTcpNioConnectionSupport - Class in org.springframework.integration.ip.tcp.connection
-
Implementation of
TcpNioConnectionSupport
for non-SSL NIO connections. - DefaultTcpNioConnectionSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNioConnectionSupport
- DefaultTcpNioSSLConnectionSupport - Class in org.springframework.integration.ip.tcp.connection
-
Implementation of
TcpNioConnectionSupport
for SSL NIO connections. - DefaultTcpNioSSLConnectionSupport(TcpSSLContextSupport) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNioSSLConnectionSupport
-
Create an instance with host verification enabled.
- DefaultTcpNioSSLConnectionSupport(TcpSSLContextSupport, boolean) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpNioSSLConnectionSupport
-
Create an instance.
- DefaultTcpSocketSupport - Class in org.springframework.integration.ip.tcp.connection
-
Default implementation of
TcpSocketSupport
; makes no changes to sockets. - DefaultTcpSocketSupport() - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpSocketSupport
-
Construct an instance with host verification enabled.
- DefaultTcpSocketSupport(boolean) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpSocketSupport
-
Construct an instance with the provided sslVerifyHost.
- DefaultTcpSSLContextSupport - Class in org.springframework.integration.ip.tcp.connection
-
Default implementation of
TcpSSLContextSupport
; uses a 'TLS' (by default)SSLContext
, initialized with 'JKS' keystores, managed by 'SunX509' Key and Trust managers. - DefaultTcpSSLContextSupport(String, String, String, String) - Constructor for class org.springframework.integration.ip.tcp.connection.DefaultTcpSSLContextSupport
-
Prepares for the creation of an SSLContext using the supplied key/trust stores and passwords.
- defaultTopic(String) - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
-
/** Set the default topic for send methods where a topic is not providing.
- DefaultTransactionSynchronizationFactory - Class in org.springframework.integration.transaction
-
Default implementation of
TransactionSynchronizationFactory
which takes an instance ofTransactionSynchronizationProcessor
allowing you to create aTransactionSynchronization
using {DefaultTransactionSynchronizationFactory.create(Object)
method. - DefaultTransactionSynchronizationFactory(TransactionSynchronizationProcessor) - Constructor for class org.springframework.integration.transaction.DefaultTransactionSynchronizationFactory
- DefaultXmlPayloadConverter - Class in org.springframework.integration.xml
-
Default implementation of
XmlPayloadConverter
. - DefaultXmlPayloadConverter() - Constructor for class org.springframework.integration.xml.DefaultXmlPayloadConverter
- DefaultXmlPayloadConverter(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.DefaultXmlPayloadConverter
- DefaultXmppHeaderMapper - Class in org.springframework.integration.xmpp.support
-
Default implementation of
XmppHeaderMapper
. - DefaultXmppHeaderMapper() - Constructor for class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
- defineRequestResponseScenario() - Method in class org.springframework.integration.test.support.SingleRequestResponseScenarioTests
- defineRequestResponseScenarios() - Method in class org.springframework.integration.test.support.AbstractRequestResponseScenarioTests
-
Implement this method to define RequestResponse scenarios
- defineRequestResponseScenarios() - Method in class org.springframework.integration.test.support.SingleRequestResponseScenarioTests
- delay(int) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the value to set in the
x-delay
header when using the RabbitMQ delayed message exchange plugin. - delay(long) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
-
The delay between checks of the file for new content in milliseconds.
- delay(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
DelayHandler
to the current integration flow position with default options. - delay(Consumer<DelayerEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
DelayHandler
to the current integration flow position. - DELAY_WHEN_EMPTY_KEY - Static variable in class org.springframework.integration.util.IntegrationReactiveUtils
-
The subscriber context entry for
Flux.delayElements(java.time.Duration)
from theMono.repeatWhenEmpty(java.util.function.Function)
. - delayedAdvice(Advice...) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
-
Configure a list of
Advice
objects that will be applied, in nested order, when delayed messages are sent. - delayedMessageErrorChannel(String) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
-
Set a message channel name to which an
ErrorMessage
will be sent if sending the released message fails. - delayedMessageErrorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
-
Set a message channel to which an
ErrorMessage
will be sent if sending the released message fails. - delayer - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- DelayerEndpointSpec - Class in org.springframework.integration.dsl
-
A
ConsumerEndpointSpec
for aDelayHandler
. - DelayerEndpointSpec() - Constructor for class org.springframework.integration.dsl.DelayerEndpointSpec
- DelayerEndpointSpec(DelayHandler) - Constructor for class org.springframework.integration.dsl.DelayerEndpointSpec
- DelayerParser - Class in org.springframework.integration.config.xml
-
Parser for the <delayer> element.
- DelayerParser() - Constructor for class org.springframework.integration.config.xml.DelayerParser
- delayExpression(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the SpEL expression to calculate the
x-delay
header when using the RabbitMQ delayed message exchange plugin. - delayExpression(String) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
- delayExpression(Expression) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the SpEL expression to calculate the
x-delay
header when using the RabbitMQ delayed message exchange plugin. - delayExpression(Expression) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
- delayFunction(Function<Message<?>, Integer>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
-
Set the function to calculate the
x-delay
header when using the RabbitMQ delayed message exchange plugin. - delayFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.DelayerEndpointSpec
-
Specify the function to determine delay value against
Message
. - DelayHandler - Class in org.springframework.integration.handler
-
A
MessageHandler
that is capable of delaying the continuation of a Message flow based on the result of evaluationdelayExpression
on an inboundMessage
or a default delay value configured on this handler. - DelayHandler() - Constructor for class org.springframework.integration.handler.DelayHandler
-
Construct an instance with default options.
- DelayHandler(String) - Constructor for class org.springframework.integration.handler.DelayHandler
-
Create a DelayHandler with the given 'messageGroupId' that is used as 'key' for
MessageGroup
to store delayed Messages in theMessageGroupStore
. - DelayHandler(String, TaskScheduler) - Constructor for class org.springframework.integration.handler.DelayHandler
-
Create a DelayHandler with the given default delay.
- DelayHandler.DelayedMessageWrapper - Class in org.springframework.integration.handler
- DelayHandlerManagement - Interface in org.springframework.integration.handler
- delayRead(Selector, long, SelectionKey) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- DelegatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
-
The
MessageGroupProcessor
implementation with delegation to the provideddelegate
and optional aggregation for headers. - DelegatingMessageGroupProcessor(MessageGroupProcessor, Function<MessageGroup, Map<String, Object>>) - Constructor for class org.springframework.integration.aggregator.DelegatingMessageGroupProcessor
- DelegatingSessionFactory<F> - Class in org.springframework.integration.file.remote.session
- DelegatingSessionFactory(Map<Object, SessionFactory<F>>, SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.session.DelegatingSessionFactory
-
Construct an instance with a
DefaultSessionFactoryLocator
using the supplied factories and default key. - DelegatingSessionFactory(SessionFactoryLocator<F>) - Constructor for class org.springframework.integration.file.remote.session.DelegatingSessionFactory
-
Construct an instance using the supplied factory.
- delete(Object) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
- delete(Object) - Method in interface org.springframework.integration.jpa.core.JpaOperations
- delete(String) - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
- delete(String) - Method in interface org.springframework.integration.jdbc.lock.LockRepository
-
Remove a lock from this repository.
- DELETE - Enum constant in enum class org.springframework.integration.cassandra.outbound.CassandraMessageHandler.Type
-
Set a
CassandraMessageHandler
into adelete
mode. - DELETE - Enum constant in enum class org.springframework.integration.file.FileReadingMessageSource.WatchEventType
- DELETE - Enum constant in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
-
(-D) Delete the remote file after successful transfer (get, mget).
- DELETE - Enum constant in enum class org.springframework.integration.jpa.support.PersistMode
- DELETE - Enum constant in enum class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler.Type
-
Set a
R2dbcMessageHandler
into adelete
mode. - DELETE_ALL_QUERY_STRING - Static variable in class org.springframework.integration.jpa.support.JpaUtils
- deleteAfterPoll(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
-
If set to 'true', the retrieved objects are deleted from the database upon being polled.
- deleteAfterPoll(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
-
If set to
true
, the retrieved objects are deleted from the database upon being polled. - deleteExpired() - Method in class org.springframework.integration.jdbc.lock.DefaultLockRepository
- deleteExpired() - Method in interface org.springframework.integration.jdbc.lock.LockRepository
-
Remove all the expired locks.
- deleteFiles - Variable in class org.springframework.integration.zip.transformer.AbstractZipTransformer
- deleteInBatch(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
-
If not set, this property defaults to
false
, which means that deletion occurs on a per-object basis if a collection of entities is being deleted. - deleteInBatch(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
-
If not set, this property defaults to
false
, which means that deletion occurs on a per-object basis if a collection of entities is being deleted. - deleteInBatch(Iterable<?>) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
- deleteInBatch(Iterable<?>) - Method in interface org.springframework.integration.jpa.core.JpaOperations
- deleteMessages(Message[]) - Method in class org.springframework.integration.mail.AbstractMailReceiver
-
Delete the given messages from this receiver's folder.
- deleteMessages(Message[]) - Method in class org.springframework.integration.mail.Pop3MailReceiver
-
Deletes the given messages from this receiver's folder, and closes it to expunge deleted messages.
- deleteRemoteFiles(boolean) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
-
Set to true to enable deletion of remote files after successful transfer.
- deleteSourceFiles(boolean) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
-
Specify whether to delete source Files after writing to the destination directory.
- delimiters(String) - Method in class org.springframework.integration.dsl.SplitterSpec
-
Set delimiters to tokenize String values.
- DELIVERY_ATTEMPT - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
- deliveryComplete(IMqttDeliveryToken) - Method in class org.springframework.integration.mqtt.core.Mqttv3ClientManager
- deliveryComplete(IMqttDeliveryToken) - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
- deliveryComplete(IMqttDeliveryToken) - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
- deliveryComplete(IMqttToken) - Method in class org.springframework.integration.mqtt.core.Mqttv5ClientManager
- deliveryComplete(IMqttToken) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- deliveryComplete(IMqttToken) - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- deliveryModeExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
-
Specify a SpEL expression to evaluate a
deliveryMode
for JMS message to send. - deliveryModeFunction(Function<Message<P>, ?>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
-
Specify a
Function
to resolve adeliveryMode
for JMS message to send. - deliveryPersistent(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- deliveryPersistent(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
- deliveryPersistent(boolean) - Method in class org.springframework.integration.jms.dsl.JmsTemplateSpec
- DerbyChannelMessageStoreQueryProvider - Class in org.springframework.integration.jdbc.store.channel
- DerbyChannelMessageStoreQueryProvider() - Constructor for class org.springframework.integration.jdbc.store.channel.DerbyChannelMessageStoreQueryProvider
- deriveLanguageFromFileExtension(String) - Static method in class org.springframework.integration.scripting.jsr223.ScriptExecutorFactory
-
Derive a scripting language from the provided script file name.
- describeTo(Description) - Method in class org.springframework.integration.test.matcher.EqualsResultMatcher
- describeTo(Description) - Method in class org.springframework.integration.test.matcher.HeaderMatcher
- describeTo(Description) - Method in class org.springframework.integration.test.matcher.MapContentMatchers
- describeTo(Description) - Method in class org.springframework.integration.test.matcher.MessageMatcher
- describeTo(Description) - Method in class org.springframework.integration.test.matcher.PayloadAndHeaderMatcher
- describeTo(Description) - Method in class org.springframework.integration.test.matcher.PayloadMatcher
- description() - Method in record class org.springframework.integration.http.management.ControlBusController.ControlBusCommand
-
Returns the value of the
description
record component. - description() - Element in annotation interface org.springframework.integration.support.management.IntegrationManagedResource
- description(String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.CounterBuilder
-
Add the description.
- description(String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.GaugeBuilder
-
Add the description.
- description(String) - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.TimerBuilder
-
Add the description.
- description(String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounterBuilder
- description(String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGaugeBuilder
- description(String) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimerBuilder
- deserialize(ByteArrayInputStream) - Method in class org.springframework.integration.support.converter.AllowListDeserializingConverter
- deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
- deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayElasticRawDeserializer
- deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
Read the header from the stream and then reads the provided length from the stream and returns the data in a byte[].
- deserialize(InputStream) - Method in class org.springframework.integration.ip.tcp.serializer.MapJsonSerializer
- deserialize(InputStream) - Method in class org.springframework.integration.syslog.inbound.RFC6587SyslogDeserializer
- deserializer(String...) - Static method in class org.springframework.integration.dsl.Transformers
- deserializer(Deserializer<?>) - Method in class org.springframework.integration.ip.dsl.AbstractConnectionFactorySpec
- deserializer(Deserializer<Object>, String...) - Static method in class org.springframework.integration.dsl.Transformers
- deserializeWithType(JsonParser, DeserializationContext, TypeDeserializer) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
- destination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec
-
Configure the destination from which to receive messages.
- destination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
- destination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
-
Configure the destination to which this adapter will send messages.
- destination(Destination) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
-
Configure the destination that backs this channel.
- destination(String) - Method in class org.springframework.integration.jms.dsl.JmsInboundChannelAdapterSpec
-
Configure the name of destination from which to receive messages.
- destination(String) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec.JmsMessageDrivenChannelAdapterListenerContainerSpec
-
Specify a destination name to use.
- destination(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
-
Configure the name of the destination to which this adapter will send messages.
- destination(String) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
-
Configure the destination name that backs this channel.
- destination(Function<Message<P>, ?>) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
-
Configure a
Function
that will be invoked at run time to determine the destination to which a message will be sent. - DESTINATION - Static variable in class org.springframework.integration.debezium.support.DebeziumHeaders
-
Debezium's event destination.
- DESTINATION - Static variable in class org.springframework.integration.stomp.support.IntegrationStompHeaders
- destinationExpression(String) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
-
Configure a SpEL expression that will evaluate, at run time, the destination to which a message will be sent.
- destinationProvider - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- destinationProvider(DestinationProvider) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
-
Configure with a destination provider;
- destinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.dsl.JmsDestinationAccessorSpec
-
A
DestinationResolver
to use. - destinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
- destinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
- destinationResolver(DestinationResolver) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
- destroy() - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- destroy() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- destroy() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
- destroy() - Method in class org.springframework.integration.channel.AbstractMessageChannel
- destroy() - Method in class org.springframework.integration.channel.FluxMessageChannel
- destroy() - Method in class org.springframework.integration.channel.NullChannel
- destroy() - Method in class org.springframework.integration.channel.PartitionedChannel
- destroy() - Method in class org.springframework.integration.channel.QueueChannel
- destroy() - Method in class org.springframework.integration.config.AbstractStandardMessageHandlerFactoryBean
- destroy() - Method in class org.springframework.integration.config.ConsumerEndpointFactoryBean
- destroy() - Method in class org.springframework.integration.config.SourcePollingChannelAdapterFactoryBean
- destroy() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistration
-
Destroy the
IntegrationFlow
bean (as well as all its dependent beans) and clean up all the local cache for it. - destroy() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
- destroy() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
- destroy() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
- destroy() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory
-
Remove (close) any unused sessions in the pool.
- destroy() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
- destroy() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- destroy() - Method in class org.springframework.integration.handler.MessageHandlerSupport
- destroy() - Method in class org.springframework.integration.hazelcast.leader.LeaderInitiator
- destroy() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
- destroy() - Method in class org.springframework.integration.jms.JmsInboundGateway
- destroy() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
- destroy() - Method in class org.springframework.integration.jms.SubscribableJmsChannel
- destroy() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
- destroy() - Method in class org.springframework.integration.mail.AbstractMailReceiver
- destroy() - Method in class org.springframework.integration.mail.config.MailReceiverFactoryBean
- destroy() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
- destroy() - Method in class org.springframework.integration.mail.ImapMailReceiver
- destroy() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
- destroy() - Method in class org.springframework.integration.mqtt.inbound.AbstractMqttMessageDrivenChannelAdapter
- destroy() - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
- destroy() - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- destroy() - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- destroy() - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
- destroy() - Method in class org.springframework.integration.redis.util.RedisLockRegistry
- destroy() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
- destroy() - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
- destroy() - Method in class org.springframework.integration.sftp.session.DefaultSftpSessionFactory
- destroy() - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
- destroy() - Method in class org.springframework.integration.store.MessageGroupStoreReaper
- destroy() - Method in class org.springframework.integration.support.leader.LockRegistryLeaderInitiator
- destroy() - Method in interface org.springframework.integration.support.management.IntegrationManagement
- destroy() - Method in class org.springframework.integration.websocket.IntegrationWebSocketContainer
- destroy() - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
- destroy() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
- destroy() - Method in class org.springframework.integration.zeromq.outbound.ZeroMqMessageHandler
- destroy() - Method in class org.springframework.integration.zeromq.ZeroMqProxy
- destroy() - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
- destroying(ServerSession) - Method in class org.springframework.integration.sftp.server.ApacheMinaSftpEventListener
- destroyInstance(AbstractAmqpChannel) - Method in class org.springframework.integration.amqp.config.AmqpChannelFactoryBean
- destroyInstance(AbstractJmsChannel) - Method in class org.springframework.integration.jms.config.JmsChannelFactoryBean
- detectAlias(String) - Static method in class org.springframework.integration.jpa.support.JpaUtils
-
Resolves the alias for the entity to be retrieved from the given JPA query.
- detectEndpoints() - Method in class org.springframework.integration.rsocket.ServerRSocketMessageHandler
- detectHandlerMethods(Object) - Method in class org.springframework.integration.http.inbound.IntegrationRequestMappingHandlerMapping
- detectHandlerMethods(Object) - Method in class org.springframework.integration.webflux.inbound.WebFluxIntegrationRequestMappingHandlerMapping
- determinePayload(Throwable, AttributeAccessor) - Method in class org.springframework.integration.core.ErrorMessagePublisher
-
Build a
Throwable payload
for futureErrorMessage
. - determineRetryState(Message<?>) - Method in interface org.springframework.integration.handler.advice.RetryStateGenerator
- determineRetryState(Message<?>) - Method in class org.springframework.integration.handler.advice.SpelExpressionRetryStateGenerator
- determineTargetChannels(Message<?>) - Method in class org.springframework.integration.router.AbstractMappingMessageRouter
- determineTargetChannels(Message<?>) - Method in class org.springframework.integration.router.AbstractMessageRouter
-
Subclasses must implement this method to return a Collection of zero or more MessageChannels to which the given Message should be routed.
- determineTargetChannels(Message<?>) - Method in class org.springframework.integration.router.RecipientListRouter
- direct() - Method in class org.springframework.integration.dsl.Channels
- direct() - Static method in class org.springframework.integration.dsl.MessageChannels
- direct(String) - Method in class org.springframework.integration.dsl.Channels
- direct(String) - Static method in class org.springframework.integration.dsl.MessageChannels
- directBuffers(boolean) - Method in class org.springframework.integration.ip.dsl.TcpNioClientConnectionFactorySpec
-
True to use direct buffers.
- directBuffers(boolean) - Method in class org.springframework.integration.ip.dsl.TcpNioServerConnectionFactorySpec
-
True to use direct buffers.
- DirectChannel - Class in org.springframework.integration.channel
-
A channel that invokes a single subscriber for each sent Message.
- DirectChannel() - Constructor for class org.springframework.integration.channel.DirectChannel
-
Create a channel with default
RoundRobinLoadBalancingStrategy
. - DirectChannel(LoadBalancingStrategy) - Constructor for class org.springframework.integration.channel.DirectChannel
-
Create a DirectChannel with a
LoadBalancingStrategy
. - DirectChannelSpec - Class in org.springframework.integration.dsl
- DirectChannelSpec() - Constructor for class org.springframework.integration.dsl.DirectChannelSpec
- DirectMessageListenerContainerSpec - Class in org.springframework.integration.amqp.dsl
-
Spec for a
DirectMessageListenerContainer
. - DirectMessageListenerContainerSpec(DirectMessageListenerContainer) - Constructor for class org.springframework.integration.amqp.dsl.DirectMessageListenerContainerSpec
- DirectoryCreatedEvent - Class in org.springframework.integration.ftp.server
-
An event emitted when a directory is created.
- DirectoryCreatedEvent - Class in org.springframework.integration.sftp.server
-
An event emitted when a directory is created.
- DirectoryCreatedEvent(Object, Path, Map<String, ?>) - Constructor for class org.springframework.integration.sftp.server.DirectoryCreatedEvent
- DirectoryCreatedEvent(FtpSession, FtpRequest) - Constructor for class org.springframework.integration.ftp.server.DirectoryCreatedEvent
- DirectoryScanner - Interface in org.springframework.integration.file
-
Strategy for scanning directories.
- dirty() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
- dirty() - Method in interface org.springframework.integration.file.remote.session.Session
-
Mark this session as dirty, indicating that it should not be reused and any delegated sessions should be taken care of before closing.
- discard - Enum constant in enum class org.springframework.integration.graph.LinkNode.Type
- DiscardAwareFileListFilter<F> - Interface in org.springframework.integration.file.filters
-
The
FileListFilter
modification which can accept aConsumer
which can be called when the filter discards the file. - discardChannel() - Element in annotation interface org.springframework.integration.annotation.Aggregator
- discardChannel() - Element in annotation interface org.springframework.integration.annotation.Filter
-
Specify the channel to which this filter will send messages that do no pass the selector.
- discardChannel(String) - Method in class org.springframework.integration.dsl.BarrierSpec
-
Set the channel bean name to which late arriving trigger messages are sent, or request message does not arrive in time.
- discardChannel(String) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- discardChannel(String) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
-
Specify a channel name where rejected Messages should be sent.
- discardChannel(String) - Method in class org.springframework.integration.dsl.SplitterSpec
-
Specify a channel bean name where rejected Messages should be sent.
- discardChannel(MessageChannel) - Method in class org.springframework.integration.dsl.BarrierSpec
-
Set the channel to which late arriving trigger messages are sent, or request message does not arrive in time.
- discardChannel(MessageChannel) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- discardChannel(MessageChannel) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
-
Specify a channel where rejected Messages should be sent.
- discardChannel(MessageChannel) - Method in class org.springframework.integration.dsl.SplitterSpec
-
Specify a channel where rejected Messages should be sent.
- discardFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
-
Configure a subflow to run for discarded messages instead of a
FilterEndpointSpec.discardChannel(MessageChannel)
. - discardFlow(IntegrationFlow) - Method in class org.springframework.integration.dsl.SplitterSpec
-
Configure a subflow to run for discarded messages instead of a
SplitterSpec.discardChannel(MessageChannel)
. - DiscardingMessageHandler - Interface in org.springframework.integration.handler
-
Classes implementing this interface are capable of discarding messages.
- DiscardingMessageHandlerNode - Class in org.springframework.integration.graph
-
Represents an endpoint that has a discard channel.
- DiscardingMessageHandlerNode(int, String, MessageHandler, String, String, String) - Constructor for class org.springframework.integration.graph.DiscardingMessageHandlerNode
- discardWithinAdvice() - Element in annotation interface org.springframework.integration.annotation.Filter
-
When
true
(default) any discard action (and exception thrown) will occur within the scope of the advice class(es) in the chain. - discardWithinAdvice(boolean) - Method in class org.springframework.integration.dsl.FilterEndpointSpec
-
Set to 'true' if you wish the discard processing to occur within any request handler advice applied to this filter.
- disconnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
- disconnect(StompSessionHandler) - Method in interface org.springframework.integration.stomp.StompSessionManager
- DISCONNECT_COMPLETION_TIMEOUT - Static variable in interface org.springframework.integration.mqtt.core.ClientManager
-
The default disconnect completion timeout in milliseconds.
- DISCONNECT_COMPLETION_TIMEOUT - Static variable in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
-
The default disconnect completion timeout in milliseconds.
- disconnected(MqttDisconnectResponse) - Method in class org.springframework.integration.mqtt.core.Mqttv5ClientManager
- disconnected(MqttDisconnectResponse) - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- disconnected(MqttDisconnectResponse) - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- dispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.BroadcastingDispatcher
- dispatch(Message<?>) - Method in interface org.springframework.integration.dispatcher.MessageDispatcher
-
Dispatch the message.
- dispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.PartitionedDispatcher
- dispatch(Message<?>) - Method in class org.springframework.integration.dispatcher.UnicastingDispatcher
- dispatcher - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
- DISTINCT - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- DISTRIBUTED_OBJECT - Enum constant in enum class org.springframework.integration.hazelcast.ClusterMonitorType
-
The distributed object listener mode.
- distributedObject - Variable in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer
- DistributedSQLIterationType - Enum Class in org.springframework.integration.hazelcast
-
Enumeration of Distributed SQL Iteration Type.
- doAccept(Selector, ServerSocketChannel, long) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- doAccept(Selector, ServerSocketChannel, long) - Method in class org.springframework.integration.ip.tcp.connection.TcpNioServerConnectionFactory
- doAddMessage(Message<?>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- doAddMessage(Message<?>, Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- doBegin(Object, TransactionDefinition) - Method in class org.springframework.integration.transaction.PseudoTransactionManager
- doChmod(RemoteFileOperations<F>, String, int) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
-
Set the mode on the remote file after transfer; the default implementation does nothing.
- doChmod(RemoteFileOperations<FTPFile>, String, int) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- doChmod(RemoteFileOperations<SftpClient.DirEntry>, String, int) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
- doChmod(RemoteFileTemplate<F>, String, int) - Method in class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
-
Set the mode on the remote file after transfer; the default implementation does nothing.
- doChmod(RemoteFileTemplate<FTPFile>, String, int) - Method in class org.springframework.integration.ftp.outbound.FtpMessageHandler
- doChmod(RemoteFileTemplate<SftpClient.DirEntry>, String, int) - Method in class org.springframework.integration.sftp.outbound.SftpMessageHandler
- doCommit(DefaultTransactionStatus) - Method in class org.springframework.integration.transaction.PseudoTransactionManager
- doConnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.AbstractStompSessionManager
- doConnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.ReactorNettyTcpStompSessionManager
- doConnect(StompSessionHandler) - Method in class org.springframework.integration.stomp.WebSocketStompSessionManager
- doConvert(Object, Map<String, Object>, MessagePostProcessor) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport.ConvertingMessagingTemplate
- doCreateEndpoint(MessageHandler, MessageChannel, List<Annotation>) - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- DOCUMENT_LIST - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
- doDeclares() - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- doDeclares() - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- doDeclares() - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- doDeclares() - Method in class org.springframework.integration.amqp.channel.PublishSubscribeAmqpChannel
- doDecode(Kryo, Input, Class<T>) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
Subclasses implement this method to decode with Kryo.
- doDecode(Kryo, Input, Class<T>) - Method in class org.springframework.integration.codec.kryo.PojoCodec
- doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.AbstractPooledBufferByteArraySerializer
- doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
-
Reads the data in the inputStream to a byte[].
- doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
- doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArraySingleTerminatorSerializer
-
Reads the data in the inputStream to a byte[].
- doDeserialize(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
-
Reads the data in the inputStream to a byte[].
- doEncode(Kryo, Object, Output) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
-
Subclasses implement this method to encode with Kryo.
- doEncode(Kryo, Object, Output) - Method in class org.springframework.integration.codec.kryo.PojoCodec
- doExecuteWithClient(ClientCallback<FTPClient, T>) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
- doExecuteWithClient(ClientCallback<SftpClient, T>) - Method in class org.springframework.integration.sftp.session.SftpRemoteFileTemplate
- doExtractData(WebServiceMessage) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.ResponseMessageExtractor
- doGet() - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
- doGet() - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
- doGet() - Method in class org.springframework.integration.dsl.BarrierSpec
- doGet() - Method in class org.springframework.integration.dsl.ConsumerEndpointSpec
- doGet() - Method in class org.springframework.integration.dsl.DirectChannelSpec
- doGet() - Method in class org.springframework.integration.dsl.EndpointSpec
- doGet() - Method in class org.springframework.integration.dsl.EnricherSpec
- doGet() - Method in class org.springframework.integration.dsl.ExecutorChannelSpec
- doGet() - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
- doGet() - Method in class org.springframework.integration.dsl.IntegrationComponentSpec
- doGet() - Method in class org.springframework.integration.dsl.MessageChannelSpec
- doGet() - Method in class org.springframework.integration.dsl.PartitionedChannelSpec
- doGet() - Method in class org.springframework.integration.dsl.PriorityChannelSpec
- doGet() - Method in class org.springframework.integration.dsl.QueueChannelSpec
- doGet() - Method in class org.springframework.integration.dsl.QueueChannelSpec.MessageStoreSpec
- doGet() - Method in class org.springframework.integration.dsl.SplitterSpec
- doGet() - Method in class org.springframework.integration.dsl.WireTapSpec
- doGet() - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
- doGet() - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
- doGet() - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
- doGet() - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
- doGet() - Method in class org.springframework.integration.scripting.dsl.ScriptMessageSourceSpec
- doGet() - Method in class org.springframework.integration.scripting.dsl.ScriptSpec
- doGet() - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- doGetTransaction() - Method in class org.springframework.integration.transaction.PseudoTransactionManager
- doHandle(String, Message<?>, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
- doHandle(String, Message<?>, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.MarshallingWebServiceOutboundGateway
- doHandle(String, Message<?>, WebServiceMessageCallback) - Method in class org.springframework.integration.ws.SimpleWebServiceOutboundGateway
- doHandleRequest(HttpServletRequest, RequestEntity<?>) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
-
Handles the HTTP request by generating a Message and sending it to the request channel.
- doHandleRequestMessage(Message<?>) - Method in class org.springframework.integration.filter.MessageFilter
- doHandleRequestMessage(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
- doInCollection(MongoCollection<Document>) - Method in interface org.springframework.integration.mongodb.outbound.MessageCollectionCallback
- doInCollection(MongoCollection<Document>, Message<?>) - Method in interface org.springframework.integration.mongodb.outbound.MessageCollectionCallback
-
Perform a Mongo operation in the collection using request message as a context.
- doInit() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- doInit() - Method in class org.springframework.integration.camel.outbound.CamelMessageHandler
- doInit() - Method in class org.springframework.integration.cassandra.outbound.CassandraMessageHandler
- doInit() - Method in class org.springframework.integration.file.FileWritingMessageHandler
- doInit() - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
-
Subclasses can override to perform initialization - called from
InitializingBean.afterPropertiesSet()
. - doInit() - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- doInit() - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
-
Subclasses can override to perform initialization - called from
InitializingBean.afterPropertiesSet()
. - doInit() - Method in class org.springframework.integration.filter.MessageFilter
- doInit() - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- doInit() - Method in class org.springframework.integration.graphql.outbound.GraphQlMessageHandler
- doInit() - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
- doInit() - Method in class org.springframework.integration.handler.DelayHandler
- doInit() - Method in class org.springframework.integration.handler.ServiceActivatingHandler
- doInit() - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
- doInit() - Method in class org.springframework.integration.ip.tcp.TcpOutboundGateway
- doInit() - Method in class org.springframework.integration.jdbc.JdbcOutboundGateway
- doInit() - Method in class org.springframework.integration.jdbc.StoredProcOutboundGateway
- doInit() - Method in class org.springframework.integration.jms.JmsOutboundGateway
- doInit() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
- doInit() - Method in class org.springframework.integration.mongodb.outbound.MongoDbOutboundGateway
- doInit() - Method in class org.springframework.integration.redis.outbound.RedisOutboundGateway
- doInit() - Method in class org.springframework.integration.rsocket.outbound.RSocketOutboundGateway
- doInit() - Method in class org.springframework.integration.scattergather.ScatterGatherHandler
- doInit() - Method in class org.springframework.integration.splitter.MethodInvokingSplitter
- doInit() - Method in class org.springframework.integration.splitter.AbstractMessageSplitter
- doInit() - Method in class org.springframework.integration.transformer.ContentEnricher
-
Initialize the Content Enricher.
- doInit() - Method in class org.springframework.integration.transformer.MessageTransformingHandler
- doInit() - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
- doInit() - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
- doInit() - Method in class org.springframework.integration.xml.splitter.XPathMessageSplitter
- doInOperations(RemoteFileOperations<F>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations.OperationsCallback
-
Execute any number of operations using a dedicated remote session as long as those operations are performed on the template argument and on the calling thread.
- doInParser(JsonInboundMessageMapper, String, Map<String, Object>) - Method in class org.springframework.integration.support.json.Jackson2JsonMessageParser
- doInParser(JsonInboundMessageMapper, String, Map<String, Object>) - Method in interface org.springframework.integration.support.json.JsonInboundMessageMapper.JsonMessageParser
- doInSession(Session<F>) - Method in interface org.springframework.integration.file.remote.SessionCallback
-
Called within the context of a session.
- doInSession(Session<F>) - Method in interface org.springframework.integration.file.remote.SessionCallbackWithoutResult
- doInSession(Session<F>, Message<?>) - Method in interface org.springframework.integration.file.remote.MessageSessionCallback
-
Called within the context of a session and requestMessage.
- doInSessionWithoutResult(Session<F>) - Method in interface org.springframework.integration.file.remote.SessionCallbackWithoutResult
-
Called within the context of a session.
- doInvoke(Object...) - Method in class org.springframework.integration.handler.support.IntegrationInvocableHandlerMethod
- doInvoke(MethodInvocation, boolean) - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
- doInvoke(MethodInvocation, Message<?>) - Method in class org.springframework.integration.handler.advice.AbstractHandleMessageAdvice
- doInvoke(MethodInvocation, Message<?>) - Method in class org.springframework.integration.handler.advice.IdempotentReceiverInterceptor
- doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
-
Subclasses implement this method to apply behavior to the
MessageHandler
. - doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.CacheRequestHandlerAdvice
- doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.ContextHolderRequestHandlerAdvice
- doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
- doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.RateLimiterRequestHandlerAdvice
- doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.RequestHandlerCircuitBreakerAdvice
- doInvoke(AbstractRequestHandlerAdvice.ExecutionCallback, Object, Message<?>) - Method in class org.springframework.integration.handler.advice.RequestHandlerRetryAdvice
- doInvoke(MessageContext) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
- doInvoke(MessageContext) - Method in class org.springframework.integration.ws.MarshallingWebServiceInboundGateway
- doInvoke(MessageContext) - Method in class org.springframework.integration.ws.SimpleWebServiceInboundGateway
- doInvokeAdvisedRequestHandler(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingMessageHandler
- doInvokeAdvisedRequestHandler(Message<?>) - Method in class org.springframework.integration.handler.AbstractReplyProducingPostProcessingMessageHandler
- doList(String) - Method in class org.springframework.integration.sftp.session.SftpSession
- doListKeys(String) - Method in class org.springframework.integration.hazelcast.store.HazelcastMessageStore
- doListKeys(String) - Method in class org.springframework.integration.redis.store.RedisMessageStore
- doListKeys(String) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- DOM_RESULT - Static variable in class org.springframework.integration.xml.transformer.AbstractXmlTransformer
- domainType(Class<?>) - Method in class org.springframework.integration.mongodb.dsl.MongoDbChangeStreamMessageProducerSpec
-
Configure a domain type to convert change event body into.
- DomResultFactory - Class in org.springframework.integration.xml.result
- DomResultFactory() - Constructor for class org.springframework.integration.xml.result.DomResultFactory
- DomResultFactory(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.result.DomResultFactory
- DomSourceFactory - Class in org.springframework.integration.xml.source
-
SourceFactory
implementation which supports creation of aDOMSource
from aDocument
,File
orString
payload. - DomSourceFactory() - Constructor for class org.springframework.integration.xml.source.DomSourceFactory
- DomSourceFactory(DocumentBuilderFactory) - Constructor for class org.springframework.integration.xml.source.DomSourceFactory
- doOffer(Message<?>) - Method in class org.springframework.integration.store.MessageGroupQueue
-
It is assumed that the 'storeLock' is being held by the caller, otherwise IllegalMonitorStateException may be thrown.
- doParse(BeanDefinitionBuilder, Element, BeanMetadataElement, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractCorrelatingMessageHandlerParser
- doParse(Element, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.SpelFunctionParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.config.xml.AbstractChannelAdapterParser
-
Subclasses must implement this method to parse the adapter element.
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.config.xml.AbstractPollingInboundChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.event.config.EventInboundChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.file.config.FileTailInboundChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.ip.config.TcpInboundChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.ip.config.UdpInboundChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.jmx.config.NotificationListeningChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.kafka.config.xml.KafkaMessageDrivenChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.mail.config.ImapIdleChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.mqtt.config.xml.MqttMessageDrivenChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.redis.config.RedisInboundChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.redis.config.RedisQueueInboundChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.stomp.config.StompInboundChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.syslog.config.SyslogInboundChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.websocket.config.WebSocketInboundChannelAdapterParser
- doParse(Element, ParserContext, String) - Method in class org.springframework.integration.xmpp.config.AbstractXmppInboundChannelAdapterParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.amqp.config.AmqpInboundChannelAdapterParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.ApplicationEventMulticasterParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.SelectorChainParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.config.xml.SelectorParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.hazelcast.config.xml.HazelcastClusterMonitorInboundChannelAdapterParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.hazelcast.config.xml.HazelcastContinuousQueryInboundChannelAdapterParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.hazelcast.config.xml.HazelcastEventDrivenInboundChannelAdapterParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.http.config.HttpInboundEndpointParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.jms.config.JmsMessageDrivenEndpointParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.jmx.config.MBeanExporterParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.scripting.config.AbstractScriptParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.webflux.config.WebFluxInboundEndpointParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.websocket.config.ClientWebSocketContainerParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.websocket.config.ServerWebSocketContainerParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xml.config.XPathExpressionParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.integration.xmpp.config.XmppConnectionParser
- doParseAndRegisterConsumer(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractOutboundChannelAdapterParser
-
Override this method to control the registration process and return the bean name.
- doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractRouterParser
- doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.ErrorMessageExceptionTypeRouterParser
- doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.HeaderValueRouterParser
- doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PayloadTypeRouterParser
- doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.config.xml.RecipientListRouterParser
- doParseRouter(Element, ParserContext) - Method in class org.springframework.integration.xml.config.XPathRouterParser
- doPoll() - Method in class org.springframework.integration.store.MessageGroupQueue
-
It is assumed that the 'storeLock' is being held by the caller, otherwise IllegalMonitorStateException may be thrown.
- doPoll(ParameterSource, int, int) - Method in class org.springframework.integration.jpa.core.JpaExecutor
- doPoll(SqlParameterSource) - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
Perform a select against provided
SqlParameterSource
. - doPollForMessage(String) - Method in class org.springframework.integration.jdbc.store.JdbcChannelMessageStore
-
This method executes a call to the DB to get the oldest Message in the MessageGroup which in the context of the
JdbcChannelMessageStore
means the channel identifier. - doPollForMessage(String) - Method in class org.springframework.integration.jdbc.store.JdbcMessageStore
-
This method executes a call to the DB to get the oldest Message in the MessageGroup Override this method if need to.
- doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.config.xml.AbstractInboundGatewayParser
-
Subclasses may add to the bean definition by overriding this method.
- doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.ip.config.TcpInboundGatewayParser
- doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
- doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.redis.config.RedisQueueInboundGatewayParser
- doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.rsocket.config.RSocketInboundGatewayParser
- doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.ws.config.WebServiceInboundGatewayParser
- doReceive() - Method in class org.springframework.integration.amqp.inbound.AmqpMessageSource
- doReceive() - Method in class org.springframework.integration.endpoint.AbstractFetchLimitingMessageSource
- doReceive() - Method in class org.springframework.integration.endpoint.AbstractMessageSource
-
Subclasses must implement this method.
- doReceive() - Method in class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
- doReceive() - Method in class org.springframework.integration.endpoint.MessageProcessorMessageSource
- doReceive() - Method in class org.springframework.integration.endpoint.MethodInvokingMessageSource
- doReceive() - Method in class org.springframework.integration.feed.inbound.FeedEntryMessageSource
- doReceive() - Method in class org.springframework.integration.file.FileReadingMessageSource
- doReceive() - Method in class org.springframework.integration.hazelcast.inbound.HazelcastDistributedSQLMessageSource
- doReceive() - Method in class org.springframework.integration.jdbc.JdbcPollingChannelAdapter
-
Execute the select query and the update query if provided.
- doReceive() - Method in class org.springframework.integration.jdbc.StoredProcPollingChannelAdapter
-
Execute the select query and the update query if provided.
- doReceive() - Method in class org.springframework.integration.jms.JmsDestinationPollingSource
- doReceive() - Method in class org.springframework.integration.jmx.AttributePollingMessageSource
-
Retrieves the JMX attribute value.
- doReceive() - Method in class org.springframework.integration.jmx.MBeanTreePollingMessageSource
- doReceive() - Method in class org.springframework.integration.jpa.inbound.JpaPollingChannelAdapter
-
Use
JpaExecutor.poll()
to executes the JPA operation. - doReceive() - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
- doReceive() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
- doReceive() - Method in class org.springframework.integration.mail.MailReceivingMessageSource
- doReceive() - Method in class org.springframework.integration.mongodb.inbound.MongoDbMessageSource
-
Will execute a
Query
returning its results as the Message payload. - doReceive() - Method in class org.springframework.integration.mongodb.inbound.ReactiveMongoDbMessageSource
-
Execute a
Query
returning its results as the Message payload. - doReceive() - Method in class org.springframework.integration.r2dbc.inbound.R2dbcMessageSource
-
Execute a query returning its results as the Message payload.
- doReceive() - Method in class org.springframework.integration.redis.inbound.RedisStoreMessageSource
-
Return a Message with the view into a
RedisStore
identified byRedisStoreMessageSource.keyExpression
- doReceive() - Method in class org.springframework.integration.resource.ResourceRetrievingMessageSource
- doReceive() - Method in class org.springframework.integration.scripting.ScriptExecutingMessageSource
- doReceive() - Method in class org.springframework.integration.stream.ByteStreamReadingMessageSource
- doReceive() - Method in class org.springframework.integration.stream.CharacterStreamReadingMessageSource
- doReceive(int) - Method in class org.springframework.integration.endpoint.AbstractFetchLimitingMessageSource
-
Subclasses must implement this method.
- doReceive(int) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
- doReceive(int) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizingMessageSource
-
Polls from the file source.
- doReceive(long) - Method in class org.springframework.integration.channel.AbstractPollableChannel
-
Subclasses must implement this method.
- doReceive(long) - Method in class org.springframework.integration.channel.PriorityChannel
- doReceive(long) - Method in class org.springframework.integration.channel.QueueChannel
- doReceive(Long) - Method in class org.springframework.integration.amqp.channel.PollableAmqpChannel
- doRemove(Object) - Method in class org.springframework.integration.hazelcast.store.HazelcastMessageStore
- doRemove(Object) - Method in class org.springframework.integration.redis.store.RedisMessageStore
- doRemove(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- doRemoveAll(Collection<Object>) - Method in class org.springframework.integration.hazelcast.store.HazelcastMessageStore
- doRemoveAll(Collection<Object>) - Method in class org.springframework.integration.redis.store.RedisMessageStore
- doRemoveAll(Collection<Object>) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- doRetrieve(Object) - Method in class org.springframework.integration.hazelcast.store.HazelcastMessageStore
- doRetrieve(Object) - Method in class org.springframework.integration.redis.store.RedisMessageStore
- doRetrieve(Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- doRollback(DefaultTransactionStatus) - Method in class org.springframework.integration.transaction.PseudoTransactionManager
- doSend(DatagramPacket) - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
- doSend(Message<?>, long) - Method in class org.springframework.integration.amqp.channel.AbstractAmqpChannel
- doSend(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractMessageChannel
-
Subclasses must implement this method.
- doSend(Message<?>, long) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
- doSend(Message<?>, long) - Method in class org.springframework.integration.channel.FluxMessageChannel
- doSend(Message<?>, long) - Method in class org.springframework.integration.channel.PriorityChannel
- doSend(Message<?>, long) - Method in class org.springframework.integration.channel.QueueChannel
- doSend(Message<?>, long) - Method in class org.springframework.integration.jdbc.channel.PostgresSubscribableChannel
- doSend(Message<?>, long) - Method in class org.springframework.integration.jms.AbstractJmsChannel
- doSend(Message<?>, long) - Method in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
- doSend(Message<?>, long) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
- doSend(Message<?>, long) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
- doSetConverter(Converter<T, U>) - Method in class org.springframework.integration.transformer.PayloadTypeConvertingTransformer
- doSetFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.AbstractRemoteFileStreamingMessageSource
- doSetFilter(FileListFilter<F>) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
- doSetRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
- doSetWebServiceTemplate(WebServiceTemplate) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
- doStart() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- doStart() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
- doStart() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- doStart() - Method in class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
- doStart() - Method in class org.springframework.integration.debezium.inbound.DebeziumMessageProducer
- doStart() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
Subclasses must implement this method with the start behavior.
- doStart() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
- doStart() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
- doStart() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
Take no action by default.
- doStart() - Method in class org.springframework.integration.endpoint.PollingConsumer
- doStart() - Method in class org.springframework.integration.endpoint.ReactiveMessageSourceProducer
- doStart() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
- doStart() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
- doStart() - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
- doStart() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
- doStart() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
- doStart() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
- doStart() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- doStart() - Method in class org.springframework.integration.hazelcast.inbound.HazelcastClusterMonitorMessageProducer
- doStart() - Method in class org.springframework.integration.hazelcast.inbound.HazelcastContinuousQueryMessageProducer
- doStart() - Method in class org.springframework.integration.hazelcast.inbound.HazelcastEventDrivenMessageProducer
- doStart() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
- doStart() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
- doStart() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- doStart() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
- doStart() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- doStart() - Method in class org.springframework.integration.jms.JmsInboundGateway
- doStart() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
- doStart() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
Registers the notification listener with the specified ObjectNames.
- doStart() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
- doStart() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
- doStart() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
- doStart() - Method in class org.springframework.integration.mongodb.inbound.MongoDbChangeStreamMessageProducer
- doStart() - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
- doStart() - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- doStart() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
- doStart() - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
- doStart() - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- doStart() - Method in class org.springframework.integration.redis.inbound.ReactiveRedisStreamMessageProducer
- doStart() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
- doStart() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
- doStart() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
- doStart() - Method in class org.springframework.integration.rsocket.AbstractRSocketConnector
- doStart() - Method in class org.springframework.integration.rsocket.ClientRSocketConnector
- doStart() - Method in class org.springframework.integration.rsocket.inbound.RSocketInboundGateway
- doStart() - Method in class org.springframework.integration.rsocket.ServerRSocketConnector
- doStart() - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
- doStart() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
- doStart() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
- doStart() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
- doStart() - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
- doStart() - Method in class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
- doStart() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
- doStop() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- doStop() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundGateway
- doStop() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- doStop() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
- doStop() - Method in class org.springframework.integration.amqp.outbound.AsyncAmqpOutboundGateway
- doStop() - Method in class org.springframework.integration.debezium.inbound.DebeziumMessageProducer
- doStop() - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
Subclasses must implement this method with the stop behavior.
- doStop() - Method in class org.springframework.integration.endpoint.AbstractPollingEndpoint
- doStop() - Method in class org.springframework.integration.endpoint.EventDrivenConsumer
- doStop() - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
Take no action by default.
- doStop() - Method in class org.springframework.integration.endpoint.PollingConsumer
- doStop() - Method in class org.springframework.integration.endpoint.ReactiveStreamsConsumer
- doStop() - Method in class org.springframework.integration.endpoint.SourcePollingChannelAdapter
- doStop() - Method in class org.springframework.integration.event.inbound.ApplicationEventListeningMessageProducer
- doStop() - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
- doStop() - Method in class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
- doStop() - Method in class org.springframework.integration.file.tail.OSDelegatingFileTailingMessageProducer
- doStop() - Method in class org.springframework.integration.gateway.GatewayProxyFactoryBean
- doStop() - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- doStop() - Method in class org.springframework.integration.hazelcast.inbound.HazelcastClusterMonitorMessageProducer
- doStop() - Method in class org.springframework.integration.hazelcast.inbound.HazelcastContinuousQueryMessageProducer
- doStop() - Method in class org.springframework.integration.hazelcast.inbound.HazelcastEventDrivenMessageProducer
- doStop() - Method in class org.springframework.integration.ip.AbstractInternetProtocolReceivingChannelAdapter
- doStop() - Method in class org.springframework.integration.ip.AbstractInternetProtocolSendingMessageHandler
- doStop() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- doStop() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
- doStop() - Method in class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
- doStop() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- doStop() - Method in class org.springframework.integration.jms.JmsInboundGateway
- doStop() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
- doStop() - Method in class org.springframework.integration.jmx.NotificationListeningMessageProducer
-
Unregisters the notification listener.
- doStop() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
- doStop() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
- doStop() - Method in class org.springframework.integration.mail.ImapIdleChannelAdapter
- doStop() - Method in class org.springframework.integration.mqtt.inbound.MqttPahoMessageDrivenChannelAdapter
- doStop() - Method in class org.springframework.integration.mqtt.inbound.Mqttv5PahoMessageDrivenChannelAdapter
- doStop() - Method in class org.springframework.integration.mqtt.outbound.AbstractMqttMessageHandler
- doStop() - Method in class org.springframework.integration.mqtt.outbound.MqttPahoMessageHandler
- doStop() - Method in class org.springframework.integration.mqtt.outbound.Mqttv5PahoMessageHandler
- doStop() - Method in class org.springframework.integration.redis.inbound.RedisInboundChannelAdapter
- doStop() - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
- doStop() - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
- doStop() - Method in class org.springframework.integration.stomp.inbound.StompInboundChannelAdapter
- doStop() - Method in class org.springframework.integration.syslog.inbound.TcpSyslogReceivingChannelAdapter
- doStop() - Method in class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
- doStop() - Method in class org.springframework.integration.websocket.inbound.WebSocketInboundChannelAdapter
- doStop() - Method in class org.springframework.integration.xmpp.inbound.ChatMessageListeningEndpoint
- doStop() - Method in class org.springframework.integration.xmpp.inbound.PresenceListeningEndpoint
- doStop() - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
- doStop(Runnable) - Method in class org.springframework.integration.endpoint.AbstractEndpoint
-
Stop the component and invoke callback.
- doStop(Runnable) - Method in class org.springframework.integration.redis.inbound.RedisQueueInboundGateway
- doStop(Runnable) - Method in class org.springframework.integration.redis.inbound.RedisQueueMessageDrivenEndpoint
- doStore(Object, Object) - Method in class org.springframework.integration.hazelcast.store.HazelcastMessageStore
- doStore(Object, Object) - Method in class org.springframework.integration.redis.store.RedisMessageStore
- doStore(Object, Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- doStoreIfAbsent(Object, Object) - Method in class org.springframework.integration.hazelcast.store.HazelcastMessageStore
- doStoreIfAbsent(Object, Object) - Method in class org.springframework.integration.redis.store.RedisMessageStore
- doStoreIfAbsent(Object, Object) - Method in class org.springframework.integration.store.AbstractKeyValueMessageStore
- doTransform(Message) - Method in class org.springframework.integration.mail.transformer.AbstractMailMessageTransformer
- doTransform(Message) - Method in class org.springframework.integration.mail.transformer.MailToStringTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.json.JsonToObjectTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.json.ObjectToJsonTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractPayloadTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.AbstractTransformer
-
Subclasses must implement this method to provide the transformation logic.
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.ClaimCheckInTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.ClaimCheckOutTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.DecodingTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.FromProtobufTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.SimpleFromAvroTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.SimpleToAvroTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.StreamTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.transformer.ToProtobufTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.xml.transformer.MarshallingTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.xml.transformer.XPathTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.xml.transformer.XsltPayloadTransformer
- doTransform(Message<?>) - Method in class org.springframework.integration.zip.transformer.AbstractZipTransformer
- DOUBLE - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- doWithClient(C) - Method in interface org.springframework.integration.file.remote.ClientCallback
-
Called within the context of a
Session
. - doWithClient(C) - Method in interface org.springframework.integration.file.remote.ClientCallbackWithoutResult
- doWithClientWithoutResult(C) - Method in interface org.springframework.integration.file.remote.ClientCallbackWithoutResult
-
Called within the context of a session.
- doWithInputStream(InputStream) - Method in interface org.springframework.integration.file.remote.InputStreamCallback
-
Called with the InputStream for the remote file.
- doWithMessage(WebServiceMessage) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.RequestMessageCallback
- doWithMessageInternal(WebServiceMessage, Object) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.RequestMessageCallback
- doWithRetry(RetryTemplate, RecoveryCallback<?>, ConsumerRecord<?, ?>, Acknowledgment, Consumer<?, ?>, Runnable) - Method in interface org.springframework.integration.kafka.inbound.KafkaInboundEndpoint
-
Execute the runnable with the retry template and recovery callback.
- doWrite(Message<?>) - Method in class org.springframework.integration.ip.tcp.TcpSendingMessageHandler
-
Method that actually does the write.
- doZipTransform(Message<?>) - Method in class org.springframework.integration.zip.transformer.AbstractZipTransformer
-
Subclasses must implement this method to provide the Zip transformation logic.
- doZipTransform(Message<?>) - Method in class org.springframework.integration.zip.transformer.UnZipTransformer
- doZipTransform(Message<?>) - Method in class org.springframework.integration.zip.transformer.ZipTransformer
- drainTo(Collection<? super Message<?>>) - Method in class org.springframework.integration.store.MessageGroupQueue
- drainTo(Collection<? super Message<?>>, int) - Method in class org.springframework.integration.store.MessageGroupQueue
- DslIntegrationConfigurationInitializer - Class in org.springframework.integration.dsl.context
-
The Java DSL Integration infrastructure
beanFactory
initializer. - DslIntegrationConfigurationInitializer() - Constructor for class org.springframework.integration.dsl.context.DslIntegrationConfigurationInitializer
- duplicate(Message<?>) - Static method in class org.springframework.integration.mqtt.support.MqttHeaderAccessor
-
Return the duplicate header.
- DUPLICATE - Static variable in class org.springframework.integration.mqtt.support.MqttHeaders
- DUPLICATE_MESSAGE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
- DUPS_OK_ACKNOWLEDGE - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
- DUPS_OK_ACKNOWLEDGE_STRING - Static variable in class org.springframework.integration.jms.util.JmsAdapterUtils
- durableSubscriptionName(String) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
- durableSubscriptionName(String) - Method in class org.springframework.integration.jms.dsl.JmsPublishSubscribeMessageChannelSpec
- dynamicChannelLimit(int) - Method in class org.springframework.integration.dsl.RouterSpec
-
Set a limit for how many dynamic channels are retained (for reporting purposes).
- DynamicExpression - Class in org.springframework.integration.expression
-
An implementation of
Expression
that delegates to anExpressionSource
for resolving the actual Expression instance per-invocation at runtime. - DynamicExpression(String, ExpressionSource) - Constructor for class org.springframework.integration.expression.DynamicExpression
- DynamicJmsTemplate - Class in org.springframework.integration.jms
- DynamicJmsTemplate() - Constructor for class org.springframework.integration.jms.DynamicJmsTemplate
- DynamicPeriodicTrigger - Class in org.springframework.integration.util
-
This is a dynamically changeable
Trigger
. - DynamicPeriodicTrigger(long) - Constructor for class org.springframework.integration.util.DynamicPeriodicTrigger
-
Create a trigger with the given period in milliseconds.
- DynamicPeriodicTrigger(Duration) - Constructor for class org.springframework.integration.util.DynamicPeriodicTrigger
-
Create a trigger with the provided duration.
- DynamicRequestMappingBeanPostProcessor - Class in org.springframework.integration.http.inbound
-
A
DestructionAwareBeanPostProcessor
to register request mapping created at runtime (e.g. - DynamicRequestMappingBeanPostProcessor() - Constructor for class org.springframework.integration.http.inbound.DynamicRequestMappingBeanPostProcessor
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form