Index

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

E

EmbeddedJsonHeadersMessageMapper - Class in org.springframework.integration.support.json
For outbound messages, uses a message-aware Jackson object mapper to render the message as JSON.
EmbeddedJsonHeadersMessageMapper() - Constructor for class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
Construct an instance that embeds all headers, using the default JSON Object mapper.
EmbeddedJsonHeadersMessageMapper(ObjectMapper) - Constructor for class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
Construct an instance that embeds all headers, using the supplied JSON object mapper.
EmbeddedJsonHeadersMessageMapper(ObjectMapper, String...) - Constructor for class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
Construct an instance that embeds headers matching the supplied patterns using the supplied JSON object mapper.
EmbeddedJsonHeadersMessageMapper(String...) - Constructor for class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
Construct an instance that embeds headers matching the supplied patterns, using the default JSON object mapper.
embeddedPartsAsBytes(boolean) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
When a header mapper is provided determine whether an embedded Part (e.g Message or Multipart content is rendered as a byte[] in the payload.
embeddedPartsAsBytes(boolean) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
When a header mapper is provided determine whether an embedded Part (e.g Message or Multipart content is rendered as a byte[] in the payload.
EMERGENCY - Enum constant in enum class org.springframework.integration.syslog.RFC5424SyslogParser.Severity
 
enableBatch(boolean) - Method in class org.springframework.integration.debezium.dsl.DebeziumMessageProducerSpec
Enable the ChangeEvent batch mode handling.
enableEmptyPayload(boolean) - Method in class org.springframework.integration.debezium.dsl.DebeziumMessageProducerSpec
Enable support for tombstone (aka delete) messages.
EnableIntegration - Annotation Interface in org.springframework.integration.config
The main configuration annotation to enable Spring Integration infrastructure: - Registers some built-in beans; - Adds several BeanFactoryPostProcessors; - Adds several BeanPostProcessors; - Adds annotations processors.
EnableIntegrationGraphController - Annotation Interface in org.springframework.integration.http.config
Enables the IntegrationGraphController if org.springframework.web.servlet.DispatcherServlet or org.springframework.web.reactive.DispatcherHandler is present in the classpath.
EnableIntegrationManagement - Annotation Interface in org.springframework.integration.config
Enables default configuring of management in Spring Integration components in an existing application.
EnableIntegrationMBeanExport - Annotation Interface in org.springframework.integration.jmx.config
Enables default exporting for Spring Integration components in an existing application, as well as well all @ManagedResource annotated beans.
enableManualListenerRegistration() - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
Set whether to automatically (default) or manually add a TcpListener to the connections created by this factory.
enableManualListenerRegistration() - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
enableManualListenerRegistration() - Method in class org.springframework.integration.ip.tcp.connection.TcpConnectionSupport
Set whether or not automatic or manual registration of the TcpListener is to be used.
enableManualListenerRegistration() - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
 
EnableMessageHistory - Annotation Interface in org.springframework.integration.config
Enables MessageHistory for Spring Integration components.
EnablePublisher - Annotation Interface in org.springframework.integration.config
Provides the registration for the PublisherAnnotationBeanPostProcessor to allow the use of the Publisher annotation.
enableStatusReader(boolean) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
This field control the stderr events.
encode(Object) - Method in interface org.springframework.integration.codec.Codec
Encode an object to a byte array.
encode(Object) - Method in class org.springframework.integration.codec.CompositeCodec
 
encode(Object) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
 
encode(Object, OutputStream) - Method in interface org.springframework.integration.codec.Codec
Encode (encode) an object to an OutputStream.
encode(Object, OutputStream) - Method in class org.springframework.integration.codec.CompositeCodec
 
encode(Object, OutputStream) - Method in class org.springframework.integration.codec.kryo.AbstractKryoCodec
 
encode(Map<String, Object>, byte[]) - Method in class org.springframework.integration.websocket.support.ClientStompEncoder
 
encoding(String) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
 
encoding(Codec) - Static method in class org.springframework.integration.dsl.Transformers
The factory method for the EncodingPayloadTransformer.
encodingMode(DefaultUriBuilderFactory.EncodingMode) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a DefaultUriBuilderFactory.EncodingMode for uri construction.
encodingMode(DefaultUriBuilderFactory.EncodingMode) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
Specify a DefaultUriBuilderFactory.EncodingMode for uri construction.
EncodingPayloadTransformer<T> - Class in org.springframework.integration.transformer
AbstractPayloadTransformer that delegates to a codec to encode the payload into a byte[].
EncodingPayloadTransformer(Codec) - Constructor for class org.springframework.integration.transformer.EncodingPayloadTransformer
 
end(boolean) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
If true, tail from the end of the file, otherwise include all lines from the beginning.
END - Enum constant in enum class org.springframework.integration.file.splitter.FileSplitter.FileMarker.Mark
 
endpointFactoryBean - Variable in class org.springframework.integration.dsl.EndpointSpec
 
EndpointId - Annotation Interface in org.springframework.integration.annotation
When used alongside an EIP annotation (and no @Bean), specifies the bean name of the consumer bean with the handler bean being id.handler (for a consuming endpoint) or id.source for a message source (e.g.
endpointIdValue(Method) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
Return the EndpointId.value() property, if present.
endpointIdValue(MergedAnnotations) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
Return the EndpointId.value() property, if present.
endpointInit() - Method in class org.springframework.integration.amqp.outbound.AbstractAmqpOutboundEndpoint
Subclasses can override to perform any additional initialization.
endpointInit() - Method in class org.springframework.integration.amqp.outbound.AmqpOutboundEndpoint
 
EndpointNode - Class in org.springframework.integration.graph
Base class for all endpoints.
EndpointNode(int, String, Object, String) - Constructor for class org.springframework.integration.graph.EndpointNode
 
ENDPOINTS_DEFAULT_TIMEOUT - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies the default timeout for blocking operations like send and receive messages.
ENDPOINTS_NO_AUTO_STARTUP - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies the value of AbstractEndpoint.autoStartup.
EndpointSpec<S extends EndpointSpec<S,F,H>,F extends BeanNameAware & FactoryBean<? extends AbstractEndpoint>,H> - Class in org.springframework.integration.dsl
An IntegrationComponentSpec for endpoints.
EndpointSpec(H, F) - Constructor for class org.springframework.integration.dsl.EndpointSpec
 
endpointUri(String) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
 
endpointUri(Function<Message<?>, String>) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
 
endpointUriExpression(String) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
 
endpointUriExpression(Expression) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
 
EndpointUtils - Class in org.springframework.integration.amqp.support
Utility methods for messaging endpoints.
enhanceNameWithSubDirectory(F, String) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
 
enhanceNameWithSubDirectory(SmbFile, String) - Method in class org.springframework.integration.smb.outbound.SmbOutboundGateway
 
enhanceNameWithSubDirectory(FTPFile, String) - Method in class org.springframework.integration.ftp.gateway.FtpOutboundGateway
 
enhanceNameWithSubDirectory(SftpClient.DirEntry, String) - Method in class org.springframework.integration.sftp.gateway.SftpOutboundGateway
 
enrich(Consumer<EnricherSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a ContentEnricher to the current integration flow position with provided options.
EnricherParser - Class in org.springframework.integration.config.xml
Parser for the 'enricher' element.
EnricherParser() - Constructor for class org.springframework.integration.config.xml.EnricherParser
 
EnricherSpec - Class in org.springframework.integration.dsl
EnricherSpec() - Constructor for class org.springframework.integration.dsl.EnricherSpec
 
enrichHeaders(Consumer<HeaderEnricherSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageTransformingHandler for a HeaderEnricher as the result of provided Consumer.
enrichHeaders(Map<String, Object>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Accept a Map of values to be used for the Message header enrichment.
enrichHeaders(Map<String, Object>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Accept a Map of values to be used for the Message header enrichment.
enrichHeaders(MapBuilder<?, String, Object>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageTransformingHandler for a HeaderEnricher using header values from provided MapBuilder.
enrichHeaders(MapBuilder<?, String, Object>, Consumer<GenericEndpointSpec<MessageTransformingHandler>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
Populate a MessageTransformingHandler for a HeaderEnricher using header values from provided MapBuilder.
entityClass(Class<?>) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
Specify the class type which is being used for retrieving entities from the database.
entityClass(Class<?>) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
Specify the class type which is being used for retrieving entities from the database.
entityClass(Class<?>) - Method in class org.springframework.integration.mongodb.dsl.AbstractMongoDbMessageSourceSpec
Allow you to set the type of the entityClass that will be passed to the MongoDB query method.
entityClass(Class<?>) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
The fully qualified name of the entity class to be passed to find(..) or findOne(..) method in MongoOperations.
Entry() - Constructor for class org.springframework.integration.history.MessageHistory.Entry
 
ENTRY - Enum constant in enum class org.springframework.integration.hazelcast.DistributedSQLIterationType
The IMap.entrySet() to iterate.
entryAdded(EntryEvent<K, V>) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer.HazelcastEntryListener
 
EntryEventMessagePayload<K,V> - Class in org.springframework.integration.hazelcast.message
Hazelcast Message Payload for Entry Events.
EntryEventMessagePayload(K, V, V) - Constructor for class org.springframework.integration.hazelcast.message.EntryEventMessagePayload
 
entryEvicted(EntryEvent<K, V>) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer.HazelcastEntryListener
 
entryExpired(EntryEvent<K, V>) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer.HazelcastEntryListener
 
entryRemoved(EntryEvent<K, V>) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer.HazelcastEntryListener
 
entrySet() - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
entryUpdated(EntryEvent<K, V>) - Method in class org.springframework.integration.hazelcast.inbound.AbstractHazelcastMessageProducer.HazelcastEntryListener
 
equals(Object) - Method in record class org.springframework.integration.channel.DefaultHeaderChannelRegistry.MessageChannelWrapper
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in record class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor.BeanDefinitionPropertiesMapper
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in record class org.springframework.integration.config.MessagingAnnotationBeanPostProcessor.MessagingMetaAnnotation
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in record class org.springframework.integration.dsl.support.MessageChannelReference
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in class org.springframework.integration.expression.ExpressionEvalMap
 
equals(Object) - Method in class org.springframework.integration.handler.DelayHandler.DelayedMessageWrapper
 
equals(Object) - Method in class org.springframework.integration.hazelcast.message.EntryEventMessagePayload
 
equals(Object) - Method in class org.springframework.integration.history.MessageHistory
 
equals(Object) - Method in exception org.springframework.integration.http.support.IntegrationWebExchangeBindException
 
equals(Object) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
 
equals(Object) - Method in record class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in class org.springframework.integration.message.AdviceMessage
 
equals(Object) - Method in class org.springframework.integration.smb.session.SmbShare
Tests to see if two SmbShare objects are equal.
equals(Object) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroCounter
 
equals(Object) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroGauge
 
equals(Object) - Method in class org.springframework.integration.support.management.micrometer.MicrometerMetricsCaptor.MicroTimer
 
equals(Object) - Method in class org.springframework.integration.support.MutableMessage
 
equals(Object) - Method in class org.springframework.integration.test.util.OnlyOnceTrigger
 
equals(Object) - Method in record class org.springframework.integration.test.util.TestUtils.LevelsContainer
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in class org.springframework.integration.util.DynamicPeriodicTrigger
 
equalsResult(Supplier<U>) - Static method in class org.springframework.integration.test.matcher.EqualsResultMatcher
 
EqualsResultMatcher<U> - Class in org.springframework.integration.test.matcher
A matcher that evaluates against the result of invoking a function, wrapped by the Supplier The goal is to defer the computation until the matcher needs to be actually evaluated.
EqualsResultMatcher(Supplier<U>) - Constructor for class org.springframework.integration.test.matcher.EqualsResultMatcher
 
error - Enum constant in enum class org.springframework.integration.graph.LinkNode.Type
 
ERROR - Enum constant in enum class org.springframework.integration.handler.LoggingHandler.Level
 
ERROR - Enum constant in enum class org.springframework.integration.syslog.RFC5424SyslogParser.Severity
 
ERROR_CHANNEL_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
ERROR_CHANNEL_IGNORE_FAILURES - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies the value for PublishSubscribeChannel.ignoreFailures on a global default IntegrationContextUtils.ERROR_CHANNEL_BEAN_NAME.
ERROR_CHANNEL_REQUIRE_SUBSCRIBERS - Static variable in class org.springframework.integration.context.IntegrationProperties
Specifies the value for PublishSubscribeChannel.requireSubscribers on a global default IntegrationContextUtils.ERROR_CHANNEL_BEAN_NAME.
ERROR_LOGGER_BEAN_NAME - Static variable in class org.springframework.integration.context.IntegrationContextUtils
 
ErrorCapableCompositeMessageHandlerNode - Class in org.springframework.integration.graph
Represents a composite message handler that can emit error messages (pollable endpoint).
ErrorCapableCompositeMessageHandlerNode(int, String, CompositeMessageHandler, String, String, String, List<CompositeMessageHandlerNode.InnerHandler>) - Constructor for class org.springframework.integration.graph.ErrorCapableCompositeMessageHandlerNode
 
ErrorCapableDiscardingMessageHandlerNode - Class in org.springframework.integration.graph
Represents an endpoint that has a discard channel and can emit errors (pollable endpoint).
ErrorCapableDiscardingMessageHandlerNode(int, String, MessageHandler, String, String, String, String) - Constructor for class org.springframework.integration.graph.ErrorCapableDiscardingMessageHandlerNode
 
ErrorCapableEndpointNode - Class in org.springframework.integration.graph
Represents nodes that can natively handle errors.
ErrorCapableEndpointNode(int, String, Object, String, String) - Constructor for class org.springframework.integration.graph.ErrorCapableEndpointNode
 
ErrorCapableMessageHandlerNode - Class in org.springframework.integration.graph
Represents a message handler that can produce errors (pollable).
ErrorCapableMessageHandlerNode(int, String, MessageHandler, String, String, String) - Constructor for class org.springframework.integration.graph.ErrorCapableMessageHandlerNode
 
ErrorCapableNode - Interface in org.springframework.integration.graph
Nodes implementing this interface are capable of emitting errors.
ErrorCapableRoutingNode - Class in org.springframework.integration.graph
Represents an endpoint that can route to multiple channels and can emit errors (pollable endpoint).
ErrorCapableRoutingNode(int, String, MessageHandler, String, String, String, Collection<String>) - Constructor for class org.springframework.integration.graph.ErrorCapableRoutingNode
 
errorChannel() - Element in annotation interface org.springframework.integration.annotation.MessagingGateway
Identifies a channel that error messages will be sent to if a failure occurs in the gateway's proxy invocation.
errorChannel() - Element in annotation interface org.springframework.integration.annotation.Poller
 
errorChannel(Object) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.ERROR_CHANNEL header: bean name or instance.
errorChannel(Object, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.ERROR_CHANNEL header: bean name or instance.
errorChannel(String) - Method in class org.springframework.integration.dsl.EnricherSpec
 
errorChannel(String) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
Set an error channel.
errorChannel(String) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Identifies a channel that error messages will be sent to if a failure occurs in the gateway's proxy invocation.
errorChannel(String) - Method in class org.springframework.integration.dsl.MessageProducerSpec
Configure the bean name of the MessageChannel to which error messages will be sent.
errorChannel(String) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
An error channel name to use.
errorChannel(String) - Method in class org.springframework.integration.dsl.PollerSpec
Specify a bean name for the MessageChannel to use for sending error message in case of polling failures.
errorChannel(String) - Method in class org.springframework.integration.dsl.ScatterGatherSpec
Specify a MessageChannel bean name for async error processing.
errorChannel(String) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
 
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.EnricherSpec
 
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
Set an error channel.
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.GatewayProxySpec
Identifies a channel that error messages will be sent to if a failure occurs in the gateway's proxy invocation.
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessageProducerSpec
Configure the MessageChannel to which error messages will be sent.
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
An error channel to use.
errorChannel(MessageChannel) - Method in class org.springframework.integration.dsl.PollerSpec
Specify a MessageChannel to use for sending error message in case of polling failures.
errorChannel(MessageChannel) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
 
errorChannelExpression(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.ERROR_CHANNEL header where the value is a SpEL Expression evaluation result.
errorChannelExpression(String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.ERROR_CHANNEL header where the value is a SpEL Expression evaluation result.
errorChannelFunction(Function<Message<P>, ?>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.ERROR_CHANNEL header where the value is obtained by invoking the Function callback.
errorChannelFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a MessageHeaders.ERROR_CHANNEL header where the value is obtained by invoking the Function callback.
errorCode(String) - Method in class org.springframework.integration.http.dsl.HttpControllerEndpointSpec
The error code to use to signal an error in the message handling.
errorHandler(CommonErrorHandler) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Specify an CommonErrorHandler for the AbstractMessageListenerContainer.
errorHandler(ErrorHandler) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.dsl.PollerSpec
Specify the ErrorHandler to wrap a taskExecutor to the ErrorHandlingTaskExecutor.
errorHandler(ErrorHandler) - Method in class org.springframework.integration.dsl.PublishSubscribeChannelSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
 
errorHandler(ErrorHandler) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
 
errorHandler(ResponseErrorHandler) - Method in class org.springframework.integration.http.dsl.HttpMessageHandlerSpec
Set the ResponseErrorHandler for the underlying RestTemplate.
ErrorHandlingTaskExecutor - Class in org.springframework.integration.util
A TaskExecutor implementation that wraps an existing Executor instance in order to catch any exceptions.
ErrorHandlingTaskExecutor(Executor, ErrorHandler) - Constructor for class org.springframework.integration.util.ErrorHandlingTaskExecutor
 
ErrorMessageExceptionTypeRouter - Class in org.springframework.integration.router
A Message Router that resolves the target MessageChannel for messages whose payload is a Throwable.
ErrorMessageExceptionTypeRouter() - Constructor for class org.springframework.integration.router.ErrorMessageExceptionTypeRouter
 
ErrorMessageExceptionTypeRouterParser - Class in org.springframework.integration.config.xml
Parser for the <exception-type-router/> element.
ErrorMessageExceptionTypeRouterParser() - Constructor for class org.springframework.integration.config.xml.ErrorMessageExceptionTypeRouterParser
 
ErrorMessageJacksonDeserializer - Class in org.springframework.integration.support.json
The MessageJacksonDeserializer implementation for the ErrorMessage.
ErrorMessageJacksonDeserializer() - Constructor for class org.springframework.integration.support.json.ErrorMessageJacksonDeserializer
 
errorMessagePayload(List<Message>, Channel, boolean, Exception) - Static method in class org.springframework.integration.amqp.support.EndpointUtils
Return an ListenerExecutionFailedException or a ManualAckListenerExecutionFailedException depending on whether isManualAck is false or true.
errorMessagePayload(Message, Channel, boolean, Exception) - Static method in class org.springframework.integration.amqp.support.EndpointUtils
Return an ListenerExecutionFailedException or a ManualAckListenerExecutionFailedException depending on whether isManualAck is false or true.
ErrorMessagePublisher - Class in org.springframework.integration.core
The component which can be used as general purpose of errors publishing.
ErrorMessagePublisher() - Constructor for class org.springframework.integration.core.ErrorMessagePublisher
 
ErrorMessageSendingRecoverer - Class in org.springframework.integration.handler.advice
A RecoveryCallback that sends the final throwable as an ErrorMessage after retry exhaustion.
ErrorMessageSendingRecoverer() - Constructor for class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
Construct instance with the default errorChannel to publish recovery error message.
ErrorMessageSendingRecoverer(MessageChannel) - Constructor for class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
Construct instance based on the provided message channel.
ErrorMessageSendingRecoverer(MessageChannel, ErrorMessageStrategy) - Constructor for class org.springframework.integration.handler.advice.ErrorMessageSendingRecoverer
Construct instance based on the provided message channel and ErrorMessageStrategy.
ErrorMessageSendingRecoverer.RetryExceptionNotAvailableException - Exception in org.springframework.integration.handler.advice
 
errorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
Set the error message strategy to use for returned (or negatively confirmed) messages.
errorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.dsl.MessageProducerSpec
Set an ErrorMessageStrategy to use to build an error message when a exception occurs.
errorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
 
ErrorMessageStrategy - Interface in org.springframework.integration.support
A strategy to build an ErrorMessage based on the provided Throwable and AttributeAccessor as a context.
ErrorMessageUtils - Class in org.springframework.integration.support
Utilities for building error messages.
errorOnTimeout() - Element in annotation interface org.springframework.integration.annotation.MessagingGateway
If errorOnTimeout is true, null won't be returned as a result of a gateway method invocation when a timeout occurs.
errorOnTimeout(boolean) - Method in class org.springframework.integration.dsl.GatewayEndpointSpec
Set a error on timeout flag.
errorOnTimeout(boolean) - Method in class org.springframework.integration.dsl.MessagingGatewaySpec
If errorOnTimeout is true, construct an instance that will send an ErrorMessage with a MessageTimeoutException payload to the error channel if a reply is expected but none is received.
ERRORS - Static variable in class org.springframework.integration.syslog.SyslogHeaders
 
errorsKey(String) - Method in class org.springframework.integration.http.dsl.HttpControllerEndpointSpec
The key used to expose Errors in the core, in the case that message handling fails.
escapeRegexSpecials(String) - Static method in class org.springframework.integration.ip.util.RegexUtils
Escapes (precedes with \) any characters in the parameter in the set
ETX - Static variable in class org.springframework.integration.ip.tcp.serializer.ByteArrayStxEtxSerializer
 
evaluate(Object, String, Predicate...) - Static method in class org.springframework.integration.json.JsonPathUtils
 
evaluate(Object, String, Object...) - Static method in class org.springframework.integration.xml.xpath.XPathUtils
Utility method to evaluate an xpath on the provided object.
evaluate(Expression) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ComponentsEvaluationCallback
 
evaluate(Expression) - Method in interface org.springframework.integration.expression.ExpressionEvalMap.EvaluationCallback
 
evaluateCollectionNameExpression() - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
 
evaluateExecutionCondition(ExtensionContext) - Method in class org.springframework.integration.test.condition.LogLevelsCondition
 
evaluateExpression(String, Object) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateExpression(String, Object, Class<T>) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateExpression(Expression) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateExpression(Expression, Class<T>) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateExpression(Expression, Object) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateExpression(Expression, Object, Class<T>) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateExpression(Expression, Message<?>, Class<T>) - Method in class org.springframework.integration.util.AbstractExpressionEvaluator
 
evaluateHttpStatus(HttpEntity<?>) - Method in class org.springframework.integration.http.inbound.BaseHttpInboundEndpoint
 
evaluatePayloadExpression(Object) - Method in class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
evaluateQueryExpression() - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
 
evaluateTypeFromExpression(Message<?>, Expression, String) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
evaluateUpdateExpression() - Method in class org.springframework.integration.mongodb.inbound.AbstractMongoDbMessageSource
 
evaluateXPath(XPathExpression, Node) - Method in enum class org.springframework.integration.xml.xpath.XPathEvaluationType
 
EVENT_TYPE - Static variable in class org.springframework.integration.hazelcast.HazelcastHeaders
The event type header name.
EventDrivenConsumer - Class in org.springframework.integration.endpoint
Message Endpoint that connects any MessageHandler implementation to a SubscribableChannel.
EventDrivenConsumer(SubscribableChannel, MessageHandler) - Constructor for class org.springframework.integration.endpoint.EventDrivenConsumer
 
EventInboundChannelAdapterParser - Class in org.springframework.integration.event.config
 
EventInboundChannelAdapterParser() - Constructor for class org.springframework.integration.event.config.EventInboundChannelAdapterParser
 
EventNamespaceHandler - Class in org.springframework.integration.event.config
Namespace handler for Spring Integration's 'event' namespace.
EventNamespaceHandler() - Constructor for class org.springframework.integration.event.config.EventNamespaceHandler
 
EventOutboundChannelAdapterParser - Class in org.springframework.integration.event.config
 
EventOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.event.config.EventOutboundChannelAdapterParser
 
EVICT_ALL - Enum constant in enum class org.springframework.integration.hazelcast.CacheEventType
The Hazelcast EVICT_ALL event.
EVICTED - Enum constant in enum class org.springframework.integration.hazelcast.CacheEventType
The Hazelcast EVICTED event.
EXCEPTION_VARIABLE_NAME - Static variable in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
EXCEPTION_WHEN_EMPTY - Enum constant in enum class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway.Option
(-x) Throw an exception if no files returned (mget).
exceptionListener(ExceptionListener) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
 
exchange(Object, HttpMethod, HttpEntity<?>, Object, Message<?>, Map<String, ?>) - Method in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
 
exchange(Object, HttpMethod, HttpEntity<?>, Object, Message<?>, Map<String, ?>) - Method in class org.springframework.integration.http.outbound.HttpRequestExecutingMessageHandler
 
exchange(Object, HttpMethod, HttpEntity<?>, Object, Message<?>, Map<String, ?>) - Method in class org.springframework.integration.webflux.outbound.WebFluxRequestExecutingMessageHandler
 
exchange(FanoutExchange) - Method in class org.springframework.integration.amqp.dsl.AmqpPublishSubscribeMessageChannelSpec
 
exchange(Message<?>) - Method in interface org.springframework.integration.gateway.RequestReplyExchanger
 
exchangeName(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
Configure an AMQP exchange name for sending messages.
exchangeNameExpression(String) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
Configure a SpEL expression to evaluate an exchange name at runtime.
exchangeNameExpression(Expression) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
Configure a SpEL expression to evaluate an exchange name at runtime.
exchangeNameFunction(Function<Message<?>, String>) - Method in class org.springframework.integration.amqp.dsl.AmqpBaseOutboundEndpointSpec
Configure a Function to evaluate an exchange name at runtime.
exchangePattern(Function<Message<?>, ExchangePattern>) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
 
exchangePattern(ExchangePattern) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
 
exchangePatternExpression(String) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
 
exchangePatternExpression(Expression) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
 
exchangeProperties(Map<String, Object>) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
 
exchangePropertiesExpression(String) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
 
exchangePropertiesExpression(Expression) - Method in class org.springframework.integration.camel.dsl.CamelMessageHandlerSpec
 
excludeFilters() - Element in annotation interface org.springframework.integration.annotation.IntegrationComponentScan
Specifies which types are not eligible for component scanning.
exclusive(boolean) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
 
exclusiveConsumerExceptionLogger(ConditionalExceptionLogger) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
Set a ConditionalExceptionLogger for logging exclusive consumer failures.
execute() - Method in interface org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice.ExecutionCallback
Call this for a normal invocation.proceed().
execute(Runnable) - Method in class org.springframework.integration.util.CompositeExecutor
Execute using the primary executor.
execute(Runnable) - Method in class org.springframework.integration.util.ErrorHandlingTaskExecutor
 
execute(SessionCallback<F, T>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Execute the callback's doInSession method after obtaining a session.
execute(SessionCallback<F, T>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
execute(MessageGroupStore, MessageGroup) - Method in interface org.springframework.integration.store.MessageGroupStore.MessageGroupCallback
 
execute2(Runnable) - Method in class org.springframework.integration.util.CompositeExecutor
Execute using the secondary executor.
executeLocked(Object, Duration, CheckedCallable<T, E>) - Method in interface org.springframework.integration.support.locks.LockRegistry
Perform the provided task when the lock for the key is locked.
executeLocked(Object, Duration, CheckedRunnable<E>) - Method in interface org.springframework.integration.support.locks.LockRegistry
Perform the provided task when the lock for the key is locked.
executeLocked(Object, CheckedCallable<T, E>) - Method in interface org.springframework.integration.support.locks.LockRegistry
Perform the provided task when the lock for the key is locked.
executeLocked(Object, CheckedRunnable<E>) - Method in interface org.springframework.integration.support.locks.LockRegistry
Perform the provided task when the lock for the key is locked.
executeOutboundJpaOperation(Message<?>) - Method in class org.springframework.integration.jpa.core.JpaExecutor
Execute the actual Jpa Operation.
executeScript(ScriptSource) - Method in interface org.springframework.integration.scripting.ScriptExecutor
Execute a script from the provided ScriptSource
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.groovy.GroovyCommandMessageProcessor
 
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
 
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.scripting.AbstractScriptExecutingMessageProcessor
Subclasses must implement this method.
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.scripting.jsr223.AbstractScriptExecutor
 
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.scripting.jsr223.ScriptExecutingMessageProcessor
 
executeScript(ScriptSource, Map<String, Object>) - Method in class org.springframework.integration.scripting.PolyglotScriptExecutor
 
executeScript(ScriptSource, Map<String, Object>) - Method in interface org.springframework.integration.scripting.ScriptExecutor
Execute a script from the provided ScriptSource with an optional binding variables.
executeStoredProcedure() - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Execute a Stored Procedure or Function - Use when no Message is available to extract ProcedureParameter values from it.
executeStoredProcedure(Message<?>) - Method in class org.springframework.integration.jdbc.StoredProcExecutor
Execute a Stored Procedure or Function - Use with Message is available to extract ProcedureParameter values from it.
executeUpdate(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
executeUpdate(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
Executes the given update statement and uses the given parameter source to set the required query parameters.
executeUpdateQuery(Message<?>, boolean) - Method in class org.springframework.integration.jdbc.JdbcMessageHandler
Execute an update for the provided message and generated keys flag.
executeUpdateWithNamedQuery(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
executeUpdateWithNamedQuery(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
 
executeUpdateWithNativeQuery(String, ParameterSource) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
 
executeUpdateWithNativeQuery(String, ParameterSource) - Method in interface org.springframework.integration.jpa.core.JpaOperations
 
executeWithClient(ClientCallback<C, T>) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Execute the callback's doWithClient method after obtaining a session's client, providing access to low level methods.
executeWithClient(ClientCallback<C, T>) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
executeWithClient(ClientCallback<C, T>) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
 
executeWithClient(ClientCallback<C, T>) - Method in class org.springframework.integration.sftp.session.SftpRemoteFileTemplate
 
executionId(Function<Message<?>, String>) - Method in class org.springframework.integration.graphql.dsl.GraphQlMessageHandlerSpec
 
executionIdExpression(String) - Method in class org.springframework.integration.graphql.dsl.GraphQlMessageHandlerSpec
 
executionIdExpression(Expression) - Method in class org.springframework.integration.graphql.dsl.GraphQlMessageHandlerSpec
 
executor - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
 
executor(String, Executor) - Method in class org.springframework.integration.dsl.Channels
 
executor(String, Executor) - Static method in class org.springframework.integration.dsl.MessageChannels
 
executor(Executor) - Method in class org.springframework.integration.dsl.Channels
 
executor(Executor) - Static method in class org.springframework.integration.dsl.MessageChannels
 
executor_channel - Enum constant in enum class org.springframework.integration.IntegrationPatternType
 
ExecutorChannel - Class in org.springframework.integration.channel
An implementation of MessageChannel that delegates to an instance of UnicastingDispatcher which in turn delegates all dispatching invocations to an Executor.
ExecutorChannel(Executor) - Constructor for class org.springframework.integration.channel.ExecutorChannel
Create an ExecutorChannel that delegates to the provided Executor when dispatching Messages.
ExecutorChannel(Executor, LoadBalancingStrategy) - Constructor for class org.springframework.integration.channel.ExecutorChannel
Create an ExecutorChannel with a LoadBalancingStrategy that delegates to the provided Executor when dispatching Messages.
ExecutorChannelInterceptorAware - Interface in org.springframework.integration.channel
The InterceptableChannel extension for the cases when the ExecutorChannelInterceptors may have reason (e.g.
ExecutorChannelSpec - Class in org.springframework.integration.dsl
 
ExecutorChannelSpec(Executor) - Constructor for class org.springframework.integration.dsl.ExecutorChannelSpec
 
executorInterceptorsSize - Variable in class org.springframework.integration.channel.AbstractExecutorChannel
 
exists(String) - Method in interface org.springframework.integration.file.remote.RemoteFileOperations
Check if a file exists on the remote server.
exists(String) - Method in class org.springframework.integration.file.remote.RemoteFileTemplate
 
exists(String) - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
 
exists(String) - Method in interface org.springframework.integration.file.remote.session.Session
Check if the remote file or directory exists.
exists(String) - Method in class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
This particular FTP implementation is based on the FTPClient.getStatus(String) by default, but since not all FTP servers properly implement the STAT command, the framework internal FtpRemoteFileTemplate instances are switched to the FTPClient.listNames(String) for only files operations.
exists(String) - Method in class org.springframework.integration.ftp.session.FtpSession
 
exists(String) - Method in class org.springframework.integration.sftp.session.SftpSession
 
exists(String) - Method in class org.springframework.integration.smb.session.SmbSession
Check whether the remote resource exists.
expect(char) - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
 
expectedResponseType(Class<?>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify the expected response type for the REST request.
expectedResponseType(Class<?>) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Specify the expected response type for the RSocket response.
expectedResponseType(String) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Specify the Expression to determine the type for the RSocket response.
expectedResponseType(Function<Message<P>, ?>) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Specify the Function to determine the type for the RSocket response.
expectedResponseType(ParameterizedTypeReference<?>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a ParameterizedTypeReference for the expected response type for the REST request.
expectedResponseType(Expression) - Method in class org.springframework.integration.rsocket.dsl.RSocketOutboundGatewaySpec
Specify an Expression to determine the type for the RSocket response.
expectedResponseTypeExpression(Expression) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a SpEL Expression to determine the type for the expected response The returned value of the expression could be an instance of Class or String representing a fully qualified class name.
expectedResponseTypeFunction(Function<Message<P>, ?>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify a Function to determine the type for the expected response The returned value of the expression could be an instance of Class or String representing a fully qualified class name.
expectedType(Class<?>) - Method in class org.springframework.integration.dsl.SplitterSpec
Set a Function input argument type.
expectedType(Class<P>) - Method in class org.springframework.integration.dsl.TransformerEndpointSpec
Set a GenericTransformer input argument type.
expectReply - Variable in class org.springframework.integration.amqp.dsl.AmqpOutboundEndpointSpec
 
expectReply(boolean) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
 
expectReply(boolean) - Method in class org.springframework.integration.webflux.dsl.WebFluxMessageHandlerSpec
 
expectSingleResult(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
This parameter indicates that only one result object shall be returned as a result from the executed JPA operation.
expectSingleResult(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
This parameter indicates that only one result object shall be returned as a result from the executed JPA operation.
expectSingleResult(boolean) - Method in class org.springframework.integration.mongodb.dsl.AbstractMongoDbMessageSourceSpec
Allow you to manage which find* method to invoke.
expectSingleResult(boolean) - Method in class org.springframework.integration.mongodb.dsl.MongoDbOutboundGatewaySpec
This parameter indicates that only one result object will be returned from the database by using a findOne query.
expectSingleResult(boolean) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
The flag to manage which find* method to invoke on R2dbcEntityOperations.
ExpirableLockRegistry - Interface in org.springframework.integration.support.locks
A LockRegistry implementing this interface supports the removal of aged locks that are not currently locked.
EXPIRATION_DATE - Static variable in class org.springframework.integration.IntegrationMessageHeaderAccessor
 
expirationDate(Object) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
expirationDate(Object, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
expirationDateExpression(String) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.EXPIRATION_DATE header where the value is a SpEL Expression evaluation result.
expirationDateExpression(String, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.EXPIRATION_DATE header where the value is a SpEL Expression evaluation result.
expirationDateFunction(Function<Message<P>, ?>, Boolean) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.EXPIRATION_DATE header where the value is obtained by invoking the Function callback.
expirationDateFunction(Function<Message<P>, Object>) - Method in class org.springframework.integration.dsl.HeaderEnricherSpec
Add a IntegrationMessageHeaderAccessor.EXPIRATION_DATE header where the value is obtained by invoking the Function callback.
expireAt() - Method in record class org.springframework.integration.channel.DefaultHeaderChannelRegistry.MessageChannelWrapper
Returns the value of the expireAt record component.
EXPIRED - Enum constant in enum class org.springframework.integration.hazelcast.CacheEventType
The Hazelcast EXPIRED event.
expireDuration(Duration) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure a Duration how often to run a scheduled purge task.
expireGroup(Object, MessageGroup, Lock) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
 
expireGroupsUponCompletion(boolean) - Method in class org.springframework.integration.dsl.AggregatorSpec
 
expireGroupsUponTimeout(boolean) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Expire (completely remove) a group if it is completed due to timeout.
expireMessageGroups(long) - Method in class org.springframework.integration.store.AbstractMessageGroupStore
 
expireMessageGroups(long) - Method in interface org.springframework.integration.store.MessageGroupStore
Extract all expired groups (whose timestamp is older than the current time less the threshold provided) and call each of the registered callbacks on them in turn.
expireTimeout(long) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
Configure a timeout for old groups in the store to purge.
expireUnusedOlderThan(long) - Method in class org.springframework.integration.jdbc.lock.JdbcLockRegistry
 
expireUnusedOlderThan(long) - Method in class org.springframework.integration.redis.util.RedisLockRegistry
 
expireUnusedOlderThan(long) - Method in interface org.springframework.integration.support.locks.ExpirableLockRegistry
Remove locks last acquired more than 'age' ago that are not currently locked.
expireUnusedOlderThan(long) - Method in class org.springframework.integration.zookeeper.lock.ZookeeperLockRegistry
Remove locks last acquired more than 'age' ago that are not currently locked.
explicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
explicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.dsl.JmsPollableMessageChannelSpec
 
explicitQosEnabled(boolean) - Method in class org.springframework.integration.jms.dsl.JmsTemplateSpec
 
explicitQosEnabledForReplies(boolean) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
exposedHeaders(String...) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec.CrossOriginSpec
List of response headers that the user-agent will allow the client to access.
exposeListenerChannel(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpMessageChannelSpec
 
exposeListenerSession(boolean) - Method in class org.springframework.integration.jms.dsl.JmsListenerContainerSpec
 
exposeListenerSession(boolean) - Method in class org.springframework.integration.jms.dsl.JmsMessageChannelSpec
 
expression() - Element in annotation interface org.springframework.integration.annotation.GatewayHeader
 
expression(String) - Method in class org.springframework.integration.dsl.SplitterSpec
Provide an expression to use an ExpressionEvaluatingSplitter for the target handler.
expression(String) - Method in class org.springframework.integration.dsl.TransformerEndpointSpec
Provide an expression to use an ExpressionEvaluatingTransformer for the target handler.
expression(Expression) - Method in class org.springframework.integration.dsl.SplitterSpec
Provide an expression to use an ExpressionEvaluatingSplitter for the target handler.
expression(Expression) - Method in class org.springframework.integration.dsl.TransformerEndpointSpec
Provide an expression to use an ExpressionEvaluatingTransformer for the target handler.
EXPRESSION_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
 
EXPRESSION_ATTRIBUTE - Static variable in class org.springframework.integration.config.xml.IntegrationNamespaceUtils
 
EXPRESSION_PARSER - Static variable in class org.springframework.integration.aop.MethodAnnotationPublisherMetadataSource
 
EXPRESSION_PARSER - Static variable in class org.springframework.integration.context.IntegrationObjectSupport
 
EXPRESSION_PARSER - Static variable in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
 
EXPRESSION_PARSER - Static variable in class org.springframework.integration.util.AbstractExpressionEvaluator
 
ExpressionArgumentsStrategy - Class in org.springframework.integration.redis.outbound
 
ExpressionArgumentsStrategy(String[]) - Constructor for class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
 
ExpressionArgumentsStrategy(String[], boolean) - Constructor for class org.springframework.integration.redis.outbound.ExpressionArgumentsStrategy
 
ExpressionCapable - Interface in org.springframework.integration.context
Components that implement this interface are capable of supporting a primary SpEL expression as part of their configuration.
ExpressionCommandMessageProcessor - Class in org.springframework.integration.handler
A MessageProcessor implementation that expects an Expression or expressionString as the Message payload.
ExpressionCommandMessageProcessor() - Constructor for class org.springframework.integration.handler.ExpressionCommandMessageProcessor
 
ExpressionCommandMessageProcessor(MethodFilter) - Constructor for class org.springframework.integration.handler.ExpressionCommandMessageProcessor
 
ExpressionCommandMessageProcessor(MethodFilter, BeanFactory) - Constructor for class org.springframework.integration.handler.ExpressionCommandMessageProcessor
 
ExpressionControlBusFactoryBean - Class in org.springframework.integration.config
FactoryBean for creating MessageHandler instances to handle a message as a SpEL expression.
ExpressionControlBusFactoryBean() - Constructor for class org.springframework.integration.config.ExpressionControlBusFactoryBean
 
ExpressionEvalMap - Class in org.springframework.integration.expression
An immutable AbstractMap implementation that wraps a Map<String, Object>, where values must be instances of String or Expression, and evaluates an expression for the provided key from the underlying original Map.
ExpressionEvalMap.ComponentsEvaluationCallback - Class in org.springframework.integration.expression
The ExpressionEvalMap.EvaluationCallback implementation which evaluates an expression using the provided context, root and returnType variables.
ExpressionEvalMap.EvaluationCallback - Interface in org.springframework.integration.expression
Implementations of this interface can be provided to build 'on demand ExpressionEvalMap.get(Object) logic' for ExpressionEvalMap.
ExpressionEvalMap.ExpressionEvalMapBuilder - Class in org.springframework.integration.expression
The builder class to instantiate ExpressionEvalMap.
ExpressionEvalMap.ExpressionEvalMapComponentsBuilder - Interface in org.springframework.integration.expression
 
ExpressionEvalMap.ExpressionEvalMapFinalBuilder - Interface in org.springframework.integration.expression
 
ExpressionEvaluatingCorrelationStrategy - Class in org.springframework.integration.aggregator
CorrelationStrategy implementation that evaluates an expression.
ExpressionEvaluatingCorrelationStrategy(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
 
ExpressionEvaluatingCorrelationStrategy(Expression) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingCorrelationStrategy
 
ExpressionEvaluatingHeaderValueMessageProcessor<T> - Class in org.springframework.integration.transformer.support
 
ExpressionEvaluatingHeaderValueMessageProcessor(String, Class<T>) - Constructor for class org.springframework.integration.transformer.support.ExpressionEvaluatingHeaderValueMessageProcessor
Create a header value processor for the given expression string and the expected type of the expression evaluation result.
ExpressionEvaluatingHeaderValueMessageProcessor(Expression, Class<T>) - Constructor for class org.springframework.integration.transformer.support.ExpressionEvaluatingHeaderValueMessageProcessor
Create a header value processor for the given Expression and the expected type of the expression evaluation result.
ExpressionEvaluatingMessageGroupProcessor - Class in org.springframework.integration.aggregator
A MessageGroupProcessor implementation that evaluates a SpEL expression.
ExpressionEvaluatingMessageGroupProcessor(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageGroupProcessor
 
ExpressionEvaluatingMessageHandler - Class in org.springframework.integration.handler
A MessageHandler that evaluates the provided Expression expecting a void return.
ExpressionEvaluatingMessageHandler(Expression) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageHandler
 
ExpressionEvaluatingMessageListProcessor - Class in org.springframework.integration.aggregator
A base class for aggregators that evaluates a SpEL expression with the message list as the root object within the evaluation context.
ExpressionEvaluatingMessageListProcessor(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Construct ExpressionEvaluatingMessageListProcessor for the provided SpEL expression and expected result type.
ExpressionEvaluatingMessageListProcessor(String, Class<?>) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Construct ExpressionEvaluatingMessageListProcessor for the provided SpEL expression and expected result type.
ExpressionEvaluatingMessageListProcessor(Expression) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Construct ExpressionEvaluatingMessageListProcessor for the provided expression.
ExpressionEvaluatingMessageListProcessor(Expression, Class<?>) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingMessageListProcessor
Construct ExpressionEvaluatingMessageListProcessor for the provided expression and expected result type.
ExpressionEvaluatingMessageProcessor<T> - Class in org.springframework.integration.handler
A MessageProcessor implementation that evaluates a SpEL expression with the Message itself as the root object within the evaluation context.
ExpressionEvaluatingMessageProcessor(String) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
Create an ExpressionEvaluatingMessageProcessor for the given expression.
ExpressionEvaluatingMessageProcessor(String, Class<T>) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
Construct ExpressionEvaluatingMessageProcessor for the provided SpEL expression and expected result type.
ExpressionEvaluatingMessageProcessor(Expression) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
Create an ExpressionEvaluatingMessageProcessor for the given expression.
ExpressionEvaluatingMessageProcessor(Expression, Class<T>) - Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
Create an ExpressionEvaluatingMessageProcessor for the given expression and expected type for its evaluation result.
ExpressionEvaluatingMessageSource<T> - Class in org.springframework.integration.endpoint
 
ExpressionEvaluatingMessageSource(Expression, Class<T>) - Constructor for class org.springframework.integration.endpoint.ExpressionEvaluatingMessageSource
 
ExpressionEvaluatingParameterSource(Object, List<JpaParameter>, ExpressionEvaluatingParameterSourceUtils.ParameterExpressionEvaluator) - Constructor for class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory.ExpressionEvaluatingParameterSource
 
ExpressionEvaluatingParameterSourceFactory - Class in org.springframework.integration.jpa.support.parametersource
A SpEL expression based ParameterSourceFactory implementation.
ExpressionEvaluatingParameterSourceFactory() - Constructor for class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
 
ExpressionEvaluatingParameterSourceFactory(BeanFactory) - Constructor for class org.springframework.integration.jpa.support.parametersource.ExpressionEvaluatingParameterSourceFactory
 
ExpressionEvaluatingParameterSourceFactory.ExpressionEvaluatingParameterSource - Class in org.springframework.integration.jpa.support.parametersource
 
ExpressionEvaluatingReleaseStrategy - Class in org.springframework.integration.aggregator
A ReleaseStrategy that evaluates an expression.
ExpressionEvaluatingReleaseStrategy(String) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingReleaseStrategy
 
ExpressionEvaluatingReleaseStrategy(Expression) - Constructor for class org.springframework.integration.aggregator.ExpressionEvaluatingReleaseStrategy
 
ExpressionEvaluatingRequestHandlerAdvice - Class in org.springframework.integration.handler.advice
Used to advise MessageHandlers.
ExpressionEvaluatingRequestHandlerAdvice() - Constructor for class org.springframework.integration.handler.advice.ExpressionEvaluatingRequestHandlerAdvice
 
ExpressionEvaluatingRequestHandlerAdvice.MessageHandlingExpressionEvaluatingAdviceException - Exception in org.springframework.integration.handler.advice
 
ExpressionEvaluatingRouter - Class in org.springframework.integration.router
A Message Router implementation that evaluates the specified SpEL expression.
ExpressionEvaluatingRouter(String) - Constructor for class org.springframework.integration.router.ExpressionEvaluatingRouter
Construct an instance by parsing the supplied expression string.
ExpressionEvaluatingRouter(Expression) - Constructor for class org.springframework.integration.router.ExpressionEvaluatingRouter
Construct an instance with the supplied Expression.
ExpressionEvaluatingRoutingSlipRouteStrategy - Class in org.springframework.integration.routingslip
The Expression based RoutingSlipRouteStrategy implementation.
ExpressionEvaluatingRoutingSlipRouteStrategy(String) - Constructor for class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
ExpressionEvaluatingRoutingSlipRouteStrategy(Expression) - Constructor for class org.springframework.integration.routingslip.ExpressionEvaluatingRoutingSlipRouteStrategy
 
ExpressionEvaluatingRoutingSlipRouteStrategy.RequestAndReply - Class in org.springframework.integration.routingslip
 
ExpressionEvaluatingSelector - Class in org.springframework.integration.filter
A MessageSelector implementation that evaluates a SpEL expression.
ExpressionEvaluatingSelector(String) - Constructor for class org.springframework.integration.filter.ExpressionEvaluatingSelector
 
ExpressionEvaluatingSelector(Expression) - Constructor for class org.springframework.integration.filter.ExpressionEvaluatingSelector
 
ExpressionEvaluatingSplitter - Class in org.springframework.integration.splitter
A Message Splitter implementation that evaluates the specified SpEL expression.
ExpressionEvaluatingSplitter(Expression) - Constructor for class org.springframework.integration.splitter.ExpressionEvaluatingSplitter
 
ExpressionEvaluatingSqlParameterSourceFactory - Class in org.springframework.integration.jdbc
An implementation of SqlParameterSourceFactory which creates an SqlParameterSource that evaluates Spring EL expressions.
ExpressionEvaluatingSqlParameterSourceFactory() - Constructor for class org.springframework.integration.jdbc.ExpressionEvaluatingSqlParameterSourceFactory
 
ExpressionEvaluatingTransactionSynchronizationProcessor - Class in org.springframework.integration.transaction
This implementation of TransactionSynchronizationFactory allows you to configure SpEL expressions, with their execution being coordinated (synchronized) with a transaction - see TransactionSynchronization.
ExpressionEvaluatingTransactionSynchronizationProcessor() - Constructor for class org.springframework.integration.transaction.ExpressionEvaluatingTransactionSynchronizationProcessor
 
ExpressionEvaluatingTransformer - Class in org.springframework.integration.transformer
A Message Transformer implementation that evaluates the specified SpEL expression.
ExpressionEvaluatingTransformer(Expression) - Constructor for class org.springframework.integration.transformer.ExpressionEvaluatingTransformer
 
ExpressionFactoryBean - Class in org.springframework.integration.config
FactoryBean for creating Expression instances.
ExpressionFactoryBean(String) - Constructor for class org.springframework.integration.config.ExpressionFactoryBean
 
ExpressionFileListFilter<F> - Class in org.springframework.integration.file.filters
A SpEL expression based AbstractFileListFilter implementation.
ExpressionFileListFilter(String) - Constructor for class org.springframework.integration.file.filters.ExpressionFileListFilter
 
ExpressionFileListFilter(Expression) - Constructor for class org.springframework.integration.file.filters.ExpressionFileListFilter
 
ExpressionMessageProducerSupport - Class in org.springframework.integration.endpoint
A MessageProducerSupport sub-class that provides ExpressionMessageProducerSupport.payloadExpression evaluation with result as a payload for Message to send.
ExpressionMessageProducerSupport() - Constructor for class org.springframework.integration.endpoint.ExpressionMessageProducerSupport
 
ExpressionSource - Interface in org.springframework.integration.expression
Strategy interface for retrieving Expressions.
expressionToFile(Expression, EvaluationContext, Message<?>, String) - Static method in class org.springframework.integration.expression.ExpressionUtils
Evaluate an expression and return a File object; the expression can evaluate to a String or File.
ExpressionUtils - Class in org.springframework.integration.expression
Utility class with static methods for helping with evaluation of SpEL expressions.
EXPUNGED - Static variable in class org.springframework.integration.mail.MailHeaders
 
externalReceiver - Variable in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
 
externalReceiver - Variable in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
 
extract(ClientHttpResponse, BodyExtractor.Context) - Method in class org.springframework.integration.webflux.support.ClientHttpResponseBodyExtractor
 
EXTRACT_PAYLOADS - Enum constant in enum class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchMode
Payload is a List<?> where each element is the converted body of the Spring AMQP Message.
EXTRACT_PAYLOADS_WITH_HEADERS - Enum constant in enum class org.springframework.integration.amqp.inbound.AmqpInboundChannelAdapter.BatchMode
Payload is a List<?> where each element is the converted body of the Spring AMQP Message.
extractAdviceChain(String, List<Annotation>) - Method in class org.springframework.integration.config.AbstractMethodAnnotationPostProcessor
 
extractBody(boolean) - Method in class org.springframework.integration.mongodb.dsl.MongoDbChangeStreamMessageProducerSpec
Configure a flag to extract body from a change event or use event as a payload.
extractData(WebServiceMessage) - Method in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway.ResponseMessageExtractor
 
extractJavaType(Map<String, Object>) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
 
extractJavaType(Map<String, Object>) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
 
extractPayload - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
 
extractPayload() - Method in class org.springframework.integration.test.support.AbstractResponseValidator
If true will extract the payload as the parameter for validateResponse()
extractPayload() - Method in class org.springframework.integration.test.support.MessageValidator
 
extractPayload() - Method in class org.springframework.integration.test.support.PayloadValidator
 
extractPayload(boolean) - Method in class org.springframework.integration.amqp.dsl.AmqpPollableMessageChannelSpec
Configure whether normal spring-messaging to AMQP message mapping is enabled.
extractPayload(boolean) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
Specify whether the outbound message's payload should be extracted when preparing the request body.
extractPayload(boolean) - Method in class org.springframework.integration.jms.dsl.JmsMessageDrivenChannelAdapterSpec
 
extractPayload(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundChannelAdapterSpec
 
extractPayload(boolean) - Method in class org.springframework.integration.ws.dsl.SimpleWsInboundGatewaySpec
Specify true to extract the payloadSource from the request or use the entire request as the payload; default true.
extractPayload(boolean) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec
Specify a flag to return the whole WebServiceMessage or build the payload based on WebServiceMessage and populated headers according headerMapper configuration.
extractPayload(boolean) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
Specify a flag to return the whole WebServiceMessage or build the payload based on WebServiceMessage and populated headers according headerMapper configuration.
extractProxyTarget(Object) - Static method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
 
extractReplyPayload(boolean) - Method in class org.springframework.integration.http.dsl.HttpInboundEndpointSupportSpec
Specify whether only the reply Message's payload should be passed in the response.
extractReplyPayload(boolean) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
extractReplyPayload(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
extractRequestBody(ServletServerHttpRequest) - Method in class org.springframework.integration.http.inbound.HttpRequestHandlingEndpointSupport
 
extractRequestPayload(boolean) - Method in class org.springframework.integration.jms.dsl.JmsInboundGatewaySpec
 
extractRequestPayload(boolean) - Method in class org.springframework.integration.jms.dsl.JmsOutboundGatewaySpec
 
extractResponseBody(boolean) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
The flag to extract a body of the ResponseEntity for reply message payload.
extractStandardHeaders(Message) - Static method in class org.springframework.integration.mail.support.MailUtils
Map the message headers to a Map using MailHeaders keys; specifically maps the address headers and the subject.
extractStandardHeaders(MessageBuilder) - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
 
extractStandardHeaders(MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
Extract "standard" headers from an AMQP MessageProperties instance.
extractStandardHeaders(SoapMessage) - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
extractStandardHeaders(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Extract the standard headers from the specified source.
extractTypeIfPossible(Object, Class<T>) - Static method in class org.springframework.integration.context.IntegrationObjectSupport
 
extractUserDefinedHeaders(MessageBuilder) - Method in class org.springframework.integration.xmpp.support.DefaultXmppHeaderMapper
 
extractUserDefinedHeaders(MessageProperties) - Method in class org.springframework.integration.amqp.support.DefaultAmqpHeaderMapper
Extract user-defined headers from an AMQP MessageProperties instance.
extractUserDefinedHeaders(SoapMessage) - Method in class org.springframework.integration.ws.DefaultSoapHeaderMapper
 
extractUserDefinedHeaders(T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
Extract the user-defined headers from the specified source.
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form