Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
B
- backlog(int) - Method in class org.springframework.integration.ip.dsl.TcpServerConnectionFactorySpec
- BACKLOG - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- backOff(BackOff) - Method in class org.springframework.integration.jms.dsl.JmsDefaultListenerContainerSpec
-
Specify a
BackOff
. - barrier - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- barrier(long) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
BarrierMessageHandler
instance for provided timeout. - barrier(long, Consumer<BarrierSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
BarrierMessageHandler
instance for provided timeout and options fromBarrierSpec
and endpoint options fromGenericEndpointSpec
. - BarrierMessageHandler - Class in org.springframework.integration.aggregator
-
A message handler that suspends the thread until a message with corresponding correlation is passed into the
trigger
method or the timeout occurs. - BarrierMessageHandler(long) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and default correlation and output strategies.
- BarrierMessageHandler(long, long) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeouts and default correlation and output strategies.
- BarrierMessageHandler(long, long, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and correlation strategy, and default output processor.
- BarrierMessageHandler(long, long, MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and output processor, and default correlation strategy.
- BarrierMessageHandler(long, long, MessageGroupProcessor, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and output processor, and default correlation strategy.
- BarrierMessageHandler(long, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and correlation strategy, and default output processor.
- BarrierMessageHandler(long, MessageGroupProcessor) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and output processor, and default correlation strategy.
- BarrierMessageHandler(long, MessageGroupProcessor, CorrelationStrategy) - Constructor for class org.springframework.integration.aggregator.BarrierMessageHandler
-
Construct an instance with the provided timeout and output processor, and default correlation strategy.
- BarrierParser - Class in org.springframework.integration.config.xml
-
Parser for
<int:barrier/>
. - BarrierParser() - Constructor for class org.springframework.integration.config.xml.BarrierParser
- BarrierSpec - Class in org.springframework.integration.dsl
-
A
MessageHandlerSpec
for theBarrierMessageHandler
. - BarrierSpec(long) - Constructor for class org.springframework.integration.dsl.BarrierSpec
- BASE_PACKAGE - Static variable in class org.springframework.integration.context.IntegrationContextUtils
- BaseHttpInboundEndpoint - Class in org.springframework.integration.http.inbound
-
The
MessagingGatewaySupport
extension for HTTP Inbound endpoints with basic properties. - BaseHttpInboundEndpoint(boolean) - Constructor for class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
- BaseHttpInboundEndpointSpec<S extends BaseHttpInboundEndpointSpec<S,
E>, E extends HttpRequestHandlingEndpointSupport> - Class in org.springframework.integration.http.dsl -
A base
MessagingGatewaySpec
for theHttpRequestHandlingEndpointSupport
implementations. - BaseHttpInboundEndpointSpec(E, String...) - Constructor for class org.springframework.integration.http.dsl.BaseHttpInboundEndpointSpec
- BaseHttpMessageHandlerSpec<S extends BaseHttpMessageHandlerSpec<S,
E>, E extends AbstractHttpRequestExecutingMessageHandler> - Class in org.springframework.integration.http.dsl -
The base
MessageHandlerSpec
forAbstractHttpRequestExecutingMessageHandler
s. - BaseHttpMessageHandlerSpec(E) - Constructor for class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
- BaseIntegrationFlowDefinition<B extends BaseIntegrationFlowDefinition<B>> - Class in org.springframework.integration.dsl
-
The
Builder
pattern implementation for the EIP-method chain. - BaseIntegrationFlowDefinition() - Constructor for class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- BaseIntegrationFlowDefinition.ReplyProducerCleaner - Class in org.springframework.integration.dsl
- basePackageClasses() - Element in annotation interface org.springframework.integration.annotation.IntegrationComponentScan
-
Type-safe alternative to
IntegrationComponentScan.basePackages()
for specifying the packages to scan for annotated components. - basePackages() - Element in annotation interface org.springframework.integration.annotation.IntegrationComponentScan
-
Base packages to scan for annotated components.
- BaseWsInboundGatewaySpec<S extends BaseWsInboundGatewaySpec<S,
E>, E extends AbstractWebServiceInboundGateway> - Class in org.springframework.integration.ws.dsl -
Base
MessagingGatewaySpec
for web services. - BaseWsInboundGatewaySpec(E) - Constructor for class org.springframework.integration.ws.dsl.BaseWsInboundGatewaySpec
-
Construct an instance based on the provided
AbstractWebServiceInboundGateway
. - BaseWsOutboundGatewaySpec<S extends BaseWsOutboundGatewaySpec<S,
E>, E extends AbstractWebServiceOutboundGateway> - Class in org.springframework.integration.ws.dsl -
The base
MessageHandlerSpec
forAbstractWebServiceOutboundGateway
s. - BaseWsOutboundGatewaySpec() - Constructor for class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- BasicMessageGroupStore - Interface in org.springframework.integration.store
-
Defines a minimal message group store with basic capabilities.
- batch - Enum constant in enum class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter.ListenerMode
-
Each
Message
will be converted from theConsumerRecords
returned by a poll. - batchingStrategy(BatchingStrategy) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Set a batching strategy to use when de-batching messages.
- BatchListener() - Constructor for class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchListener
- batchMessageConverter(BatchMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
-
Set the message converter to use with a batch-based consumer.
- batchMode(AmqpInboundChannelAdapter.BatchMode) - Method in class org.springframework.integration.amqp.dsl.AmqpInboundChannelAdapterSMLCSpec
-
Set the
AmqpInboundChannelAdapter.BatchMode
to use when the container is configured to support batching consumed records. - batchSize(int) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
-
Configure the batch size.
- batchSize(int) - Method in class org.springframework.integration.amqp.dsl.SimpleMessageListenerContainerSpec
-
The batch size to use.
- bcc(String...) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the bcc: addresses.
- BCC - Static variable in class org.springframework.integration.mail.MailHeaders
- bccExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set the expression that will be evaluated to determine the bcc: addresses.
- bccFunction(Function<Message<P>, String[]>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
-
Set a function that will be invoked to determine the bcc: addresses based on the message.
- BEAN_NAME - Static variable in class org.springframework.integration.hazelcast.HazelcastLocalInstanceRegistrar
-
The bean name for the
HazelcastLocalInstanceRegistrar
instance. - BEAN_NAME - Static variable in class org.springframework.integration.scripting.config.ScriptExecutingProcessorFactory
- beanAnnotationAware() - Method in class org.springframework.integration.config.AggregatorAnnotationPostProcessor
- beanAnnotationAware() - Method in interface org.springframework.integration.config.annotation.MethodAnnotationPostProcessor
- beanDefinition() - Method in record class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor.BeanDefinitionPropertiesMapper
-
Returns the value of the
beanDefinition
record component. - BeanDefinitionPropertiesMapper(BeanDefinition, List<Annotation>) - Constructor for record class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor.BeanDefinitionPropertiesMapper
-
Creates an instance of a
BeanDefinitionPropertiesMapper
record class. - BeanDefinitionRegisteringParser - Interface in org.springframework.integration.config.xml
-
Simple strategy interface for parsers that are responsible for parsing an element, creating a bean definition, and then registering the bean.
- BeanFactoryChannelResolver - Class in org.springframework.integration.support.channel
-
DestinationResolver
implementation based on a SpringBeanFactory
. - BeanFactoryChannelResolver() - Constructor for class org.springframework.integration.support.channel.BeanFactoryChannelResolver
-
Create a new instance of the
BeanFactoryChannelResolver
class. - BeanFactoryChannelResolver(BeanFactory) - Constructor for class org.springframework.integration.support.channel.BeanFactoryChannelResolver
-
Create a new instance of the
BeanFactoryChannelResolver
class. - BeanFactoryTypeConverter - Class in org.springframework.integration.util
- BeanFactoryTypeConverter() - Constructor for class org.springframework.integration.util.BeanFactoryTypeConverter
- BeanFactoryTypeConverter(ConversionService) - Constructor for class org.springframework.integration.util.BeanFactoryTypeConverter
- beanName() - Method in record class org.springframework.integration.http.management.ControlBusController.ControlBusBean
-
Returns the value of the
beanName
record component. - beanName(String) - Method in class org.springframework.integration.dsl.GatewayProxySpec
-
Specify a bean name for the target
GatewayProxyFactoryBean
. - BeanNameMessageProcessor<T> - Class in org.springframework.integration.handler
-
An "artificial"
MessageProcessor
for lazy-load of target bean by its name. - BeanNameMessageProcessor(String, String) - Constructor for class org.springframework.integration.handler.BeanNameMessageProcessor
- BeanPropertyParameterSource - Class in org.springframework.integration.jpa.support.parametersource
- BeanPropertyParameterSource(Object) - Constructor for class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSource
-
Create a new BeanPropertySqlParameterSource for the given bean.
- BeanPropertyParameterSourceFactory - Class in org.springframework.integration.jpa.support.parametersource
- BeanPropertyParameterSourceFactory() - Constructor for class org.springframework.integration.jpa.support.parametersource.BeanPropertyParameterSourceFactory
- BeanPropertySqlParameterSourceFactory - Class in org.springframework.integration.jdbc
-
A default implementation of
SqlParameterSourceFactory
which creates anSqlParameterSource
to reference bean properties in its input. - BeanPropertySqlParameterSourceFactory() - Constructor for class org.springframework.integration.jdbc.BeanPropertySqlParameterSourceFactory
- beforeCommit(String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- beforeCommit(String, String) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- beforeCommit(String, MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- beforeCommit(MessageChannel) - Method in class org.springframework.integration.transaction.TransactionSynchronizationFactoryBean
- beforeEach(ExtensionContext) - Method in class org.springframework.integration.test.condition.LogLevelsCondition
- beforeHandle(Message<?>, MessageChannel, MessageHandler) - Method in class org.springframework.integration.channel.interceptor.ThreadStatePropagationChannelInterceptor
- beforeReceive(Object) - Method in interface org.springframework.integration.aop.MessageSourceMutator
- beforeReceive(Object) - Method in interface org.springframework.integration.aop.ReceiveMessageAdvice
-
Subclasses can decide whether to
Joinpoint.proceed()
or not. - beforeReceive(MessageSource<?>) - Method in interface org.springframework.integration.aop.MessageSourceMutator
-
Subclasses can decide whether to proceed with this poll.
- beforeReceive(MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.RotatingServerAdvice
- beforeReceive(MessageSource<?>) - Method in interface org.springframework.integration.file.remote.aop.RotationPolicy
-
Invoked before the message source receive() method.
- beforeReceive(MessageSource<?>) - Method in class org.springframework.integration.file.remote.aop.StandardRotationPolicy
- beforeShutdown() - Method in class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter
- beforeShutdown() - Method in interface org.springframework.integration.context.OrderlyShutdownCapable
-
Called before shutdown begins.
- beforeShutdown() - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
- beforeShutdown() - Method in class org.springframework.integration.ip.tcp.connection.AbstractServerConnectionFactory
- beforeShutdown() - Method in class org.springframework.integration.ip.tcp.TcpInboundGateway
- beforeShutdown() - Method in class org.springframework.integration.ip.tcp.TcpReceivingChannelAdapter
- beforeShutdown() - Method in class org.springframework.integration.jms.JmsInboundGateway
- beforeShutdown() - Method in class org.springframework.integration.jms.JmsMessageDrivenEndpoint
- beforeShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
- beforeShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
- beforeShutdown() - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
- BIGINT - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- BINARY - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- BinaryToMessageConverter - Class in org.springframework.integration.mongodb.support
- BinaryToMessageConverter() - Constructor for class org.springframework.integration.mongodb.support.BinaryToMessageConverter
- bindFunction(BiFunction<DatabaseClient.GenericExecuteSpec, ?, DatabaseClient.GenericExecuteSpec>) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
-
Set a
BiFunction
which is used to bind parameters into the update query. - bindPort(int) - Method in class org.springframework.integration.zeromq.dsl.ZeroMqMessageProducerSpec
-
Configure a port for TCP protocol binding via
ZMQ.Socket.bind(String)
. - bindSocket(ZMQ.Socket, int) - Static method in class org.springframework.integration.zeromq.ZeroMqUtils
-
Bind the ZeroMq socket to the given port over the TCP transport protocol.
- bindSourceMessage(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseInboundGatewaySpec
-
Set to true to bind the source message in the headers.
- BIT - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- BLOB - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- BLOCKING_QUEUE - Enum constant in enum class org.springframework.integration.store.SimpleMessageGroupFactory.GroupType
- bodyExtractor(BodyExtractor<?, ? super ClientHttpResponse>) - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
-
Specify a
BodyExtractor
as an alternative to theexpectedResponseType
to allow to get low-level access to the receivedClientHttpResponse
. - BOOLEAN - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- BOOLEAN - Static variable in class org.springframework.integration.xml.xpath.XPathUtils
- BOOLEAN_RESULT - Enum constant in enum class org.springframework.integration.xml.xpath.XPathEvaluationType
- BooleanTestXPathMessageSelector - Class in org.springframework.integration.xml.selector
-
Boolean XPath testing
MessageSelector
. - BooleanTestXPathMessageSelector(String) - Constructor for class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
-
Create a boolean testing XPath
MessageSelector
with no namespace support. - BooleanTestXPathMessageSelector(String, String, String) - Constructor for class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
-
Create a boolean testing XPath
MessageSelector
supporting a single namespace. - BooleanTestXPathMessageSelector(String, Map<String, String>) - Constructor for class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
-
Create a boolean testing XPath
MessageSelector
supporting multiple namespaces. - BooleanTestXPathMessageSelector(XPathExpression) - Constructor for class org.springframework.integration.xml.selector.BooleanTestXPathMessageSelector
-
Create a boolean testing XPath
MessageSelector
using the providedXPathExpression
. - bounded() - Method in interface org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry.KeyToPathStrategy
- BoundRabbitChannelAdvice - Class in org.springframework.integration.amqp.support
-
An advice that causes all downstream
RabbitOperations
operations to be executed on the same channel, as long as there are no thread handoffs, since the channel is bound to the thread. - BoundRabbitChannelAdvice(RabbitOperations) - Constructor for class org.springframework.integration.amqp.support.BoundRabbitChannelAdvice
-
Construct an instance that doesn't wait for confirms.
- BoundRabbitChannelAdvice(RabbitOperations, Duration) - Constructor for class org.springframework.integration.amqp.support.BoundRabbitChannelAdvice
-
Construct an instance that waits for publisher confirms (if configured and waitForConfirmsTimeout is not null).
- bridge - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- bridge() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
BridgeHandler
to the current integration flow position. - bridge(Consumer<GenericEndpointSpec<BridgeHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
-
Populate a
BridgeHandler
to the current integration flow position. - BridgeFrom - Annotation Interface in org.springframework.integration.annotation
-
Messaging Annotation to mark a
Bean
method for aMessageChannel
to produce aBridgeHandler
and Consumer Endpoint. - BridgeFromAnnotationPostProcessor - Class in org.springframework.integration.config
-
Post-processor for the
@BridgeFrom
annotation. - BridgeFromAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.BridgeFromAnnotationPostProcessor
- BridgeFromRepeatable - Annotation Interface in org.springframework.integration.annotation
-
The repeatable container for
BridgeFrom
annotations. - BridgeHandler - Class in org.springframework.integration.handler
-
A simple MessageHandler implementation that passes the request Message directly to the output channel without modifying it.
- BridgeHandler() - Constructor for class org.springframework.integration.handler.BridgeHandler
- BridgeParser - Class in org.springframework.integration.config.xml
-
Parser for the <bridge> element.
- BridgeParser() - Constructor for class org.springframework.integration.config.xml.BridgeParser
- BridgeTo - Annotation Interface in org.springframework.integration.annotation
-
Messaging Annotation to mark a
Bean
method for aMessageChannel
to produce aBridgeHandler
and Consumer Endpoint. - BridgeToAnnotationPostProcessor - Class in org.springframework.integration.config
-
Post-processor for the
@BridgeTo
annotation. - BridgeToAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.BridgeToAnnotationPostProcessor
- BridgeToRepeatable - Annotation Interface in org.springframework.integration.annotation
-
The repeatable container for
BridgeTo
annotations. - BroadcastCapableChannel - Interface in org.springframework.integration.channel
-
A
SubscribableChannel
variant for implementations with broadcasting capabilities. - BroadcastingDispatcher - Class in org.springframework.integration.dispatcher
-
A broadcasting dispatcher implementation.
- BroadcastingDispatcher() - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
- BroadcastingDispatcher(boolean) - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
- BroadcastingDispatcher(Executor) - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
- BroadcastingDispatcher(Executor, boolean) - Constructor for class org.springframework.integration.dispatcher.BroadcastingDispatcher
- BroadcastPublishSubscribeSpec - Class in org.springframework.integration.dsl
-
An
IntegrationComponentSpec
for configuring sub-flow subscribers on the providedBroadcastCapableChannel
. - BroadcastPublishSubscribeSpec(BroadcastCapableChannel) - Constructor for class org.springframework.integration.dsl.BroadcastPublishSubscribeSpec
- bufferSize(int) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
-
Set the buffer size to use while writing to files; default 8192.
- build() - Method in interface org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapFinalBuilder
- build() - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
- build() - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.CounterBuilder
-
Build the counter.
- build() - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.GaugeBuilder
-
Build the gauge.
- build() - Method in interface org.springframework.integration.support.management.metrics.MetricsCaptor.TimerBuilder
-
Build the timer.
- build() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounterBuilder
- build() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGaugeBuilder
- build() - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimerBuilder
- build() - Method in class org.springframework.integration.support.MessageBuilder
- build() - Method in class org.springframework.integration.support.MutableMessageBuilder
- build() - Method in class org.springframework.integration.transaction.TransactionInterceptorBuilder
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.amqp.config.AmqpChannelParser
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.config.xml.AbstractChannelParser
-
Subclasses must implement this method to create the bean definition.
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PointToPointChannelParser
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.config.xml.PublishSubscribeChannelParser
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.jms.config.JmsChannelParser
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.kafka.config.xml.KafkaChannelParser
- buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.redis.config.RedisChannelParser
- buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.amqp.support.AmqpMessageHeaderErrorMessageStrategy
- buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.jms.support.JmsMessageHeaderErrorMessageStrategy
- buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.kafka.support.RawRecordHeaderErrorMessageStrategy
- buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.support.DefaultErrorMessageStrategy
- buildErrorMessage(Throwable, AttributeAccessor) - Method in interface org.springframework.integration.support.ErrorMessageStrategy
-
Build the error message.
- buildErrorMessage(Message<?>, Exception) - Method in class org.springframework.integration.endpoint.MessageProducerSupport
-
Build an error message for the exception and message using the configured
ErrorMessageStrategy
. - buildErrorMessage(Message<?>, Throwable) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
-
Build an error message for the message and throwable using the configured
ErrorMessageStrategy
. - buildFlow() - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- buildKey(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
-
The default key is the
AbstractPersistentAcceptOnceFileListFilter.prefix
plus the full filename. - buildLambdaMessageProcessor(ResolvableType, AnnotatedBeanDefinition) - Static method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
- buildMessage(Object) - Method in class org.springframework.integration.endpoint.AbstractMessageSource
- buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.AdviceMessageJacksonDeserializer
- buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.ErrorMessageJacksonDeserializer
- buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.GenericMessageJacksonDeserializer
- buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.MessageJacksonDeserializer
- buildMessage(MutableMessageHeaders, Object, JsonNode, DeserializationContext) - Method in class org.springframework.integration.support.json.MutableMessageJacksonDeserializer
- buildNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
- buildNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.TcpNetClientConnectionFactory
- buildNewConnection() - Method in class org.springframework.integration.ip.tcp.connection.TcpNioClientConnectionFactory
- buildReply(MessageConverter, Message) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- buildResolvableType(Class<?>, Class<?>, Class<?>) - Static method in class org.springframework.integration.mapping.support.JsonHeaders
-
Build a
ResolvableType
for provided class components. - buildResolvableType(ClassLoader, Object, Object, Object) - Static method in class org.springframework.integration.mapping.support.JsonHeaders
-
Build a
ResolvableType
for provided class components. - buildResult(Object, Message<?>, Message<?>) - Method in class org.springframework.integration.aggregator.BarrierMessageHandler
-
Override to change the default mechanism by which the inbound and release messages are returned as a result.
- buildReturnedMessage(ReturnedMessage, MessageConverter) - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
- buildSendTimer(boolean, String) - Method in class org.springframework.integration.gateway.MessagingGatewaySupport
- buildSendTimer(boolean, String) - Method in class org.springframework.integration.handler.MessageHandlerSupport
- BYTE_ARRAY - Enum constant in enum class org.springframework.integration.zip.transformer.ZipResultType
- ByteArrayCrLfSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
Reads data in an InputStream to a byte[]; data must be terminated by \r\n (not included in resulting byte[]).
- ByteArrayCrLfSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
- ByteArrayElasticRawDeserializer - Class in org.springframework.integration.ip.tcp.serializer
-
A deserializer that uses a
ByteArrayOutputStream
instead of a fixed buffer, allowing the buffer to grow as needed. - ByteArrayElasticRawDeserializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayElasticRawDeserializer
-
Construct an instance that uses
ByteArrayOutputStream
s with an initial buffer size of 32. - ByteArrayElasticRawDeserializer(int) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayElasticRawDeserializer
-
Construct an instance that uses
ByteArrayOutputStream
s with the provided initial buffer size. - ByteArrayLengthHeaderSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
Reads data in an InputStream to a byte[]; data must be preceded by a binary length (network byte order, not included in resulting byte[]).
- ByteArrayLengthHeaderSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
Construct the serializer using
ByteArrayLengthHeaderSerializer.HEADER_SIZE_INT
. - ByteArrayLengthHeaderSerializer(int) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayLengthHeaderSerializer
-
Construct the serializer using the supplied header size.
- ByteArrayLfSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
The
ByteArraySingleTerminatorSerializer
extension for theLF
message delimiter. - ByteArrayLfSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayLfSerializer
- ByteArrayRawSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
A byte array (de)serializer that does nothing with the payload; sends it raw.
- ByteArrayRawSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
- ByteArrayRawSerializer(boolean) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayRawSerializer
-
Treat socket timeouts as a normal EOF and emit the (possibly partial) message.
- ByteArraySingleTerminatorSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
Reads data in an InputStream to a byte[]; data must be terminated by a single byte (not included in resulting byte[]).
- ByteArraySingleTerminatorSerializer(byte) - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArraySingleTerminatorSerializer
- ByteArrayStxEtxSerializer - Class in org.springframework.integration.ip.tcp.serializer
-
Reads data in an InputStream to a byte[]; data must be prefixed by <stx> and terminated by <etx> (not included in resulting byte[]).
- ByteArrayStxEtxSerializer() - Constructor for class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
- BYTES - Enum constant in enum class org.springframework.integration.json.ObjectToJsonTransformer.ResultType
- BytesMessageMapper - Interface in org.springframework.integration.mapping
- bytesToString(byte[], String) - Static method in class org.springframework.integration.support.utils.IntegrationUtils
-
Utility method for null-safe conversion from byte[] to String.
- ByteStreamReadingMessageSource - Class in org.springframework.integration.stream
-
A pollable source for receiving bytes from an
InputStream
. - ByteStreamReadingMessageSource(InputStream) - Constructor for class org.springframework.integration.stream.ByteStreamReadingMessageSource
- ByteStreamReadingMessageSource(InputStream, int) - Constructor for class org.springframework.integration.stream.ByteStreamReadingMessageSource
- ByteStreamWritingMessageHandler - Class in org.springframework.integration.stream
-
A
MessageHandler
that writes a byte array to anOutputStream
. - ByteStreamWritingMessageHandler(OutputStream) - Constructor for class org.springframework.integration.stream.ByteStreamWritingMessageHandler
- ByteStreamWritingMessageHandler(OutputStream, int) - Constructor for class org.springframework.integration.stream.ByteStreamWritingMessageHandler
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form