Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
U
- udp - Enum constant in enum class org.springframework.integration.syslog.config.SyslogReceivingChannelAdapterFactoryBean.Protocol
- Udp - Class in org.springframework.integration.ip.dsl
- 
Factory methods for UDP.
- UDP_SOCKET_CUSTOMIZER - Static variable in class org.springframework.integration.ip.config.IpAdapterParserUtils
- UdpInboundChannelAdapterParser - Class in org.springframework.integration.ip.config
- 
Channel Adapter that receives UDP datagram packets and maps them to Messages.
- UdpInboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.UdpInboundChannelAdapterParser
- UdpInboundChannelAdapterSpec - Class in org.springframework.integration.ip.dsl
- UdpInboundChannelAdapterSpec(int) - Constructor for class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
- UdpInboundChannelAdapterSpec(int, String) - Constructor for class org.springframework.integration.ip.dsl.UdpInboundChannelAdapterSpec
- UdpMulticastOutboundChannelAdapterSpec - Class in org.springframework.integration.ip.dsl
- UdpMulticastOutboundChannelAdapterSpec(String) - Constructor for class org.springframework.integration.ip.dsl.UdpMulticastOutboundChannelAdapterSpec
- UdpMulticastOutboundChannelAdapterSpec(String, int) - Constructor for class org.springframework.integration.ip.dsl.UdpMulticastOutboundChannelAdapterSpec
- UdpMulticastOutboundChannelAdapterSpec(Function<Message<?>, ?>) - Constructor for class org.springframework.integration.ip.dsl.UdpMulticastOutboundChannelAdapterSpec
- UdpOutboundChannelAdapterParser - Class in org.springframework.integration.ip.config
- UdpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.ip.config.UdpOutboundChannelAdapterParser
- UdpServerListeningEvent - Class in org.springframework.integration.ip.udp
- 
IpIntegrationEventemitted when a server begins listening.
- UdpServerListeningEvent(Object, int) - Constructor for class org.springframework.integration.ip.udp.UdpServerListeningEvent
- UdpSyslogReceivingChannelAdapter - Class in org.springframework.integration.syslog.inbound
- 
UDP implementation of a syslog inbound channel adapter.
- UdpSyslogReceivingChannelAdapter() - Constructor for class org.springframework.integration.syslog.inbound.UdpSyslogReceivingChannelAdapter
- UdpUnicastOutboundChannelAdapterSpec - Class in org.springframework.integration.ip.dsl
- UdpUnicastOutboundChannelAdapterSpec(String) - Constructor for class org.springframework.integration.ip.dsl.UdpUnicastOutboundChannelAdapterSpec
- UdpUnicastOutboundChannelAdapterSpec(String, int) - Constructor for class org.springframework.integration.ip.dsl.UdpUnicastOutboundChannelAdapterSpec
- UdpUnicastOutboundChannelAdapterSpec(Function<Message<?>, ?>) - Constructor for class org.springframework.integration.ip.dsl.UdpUnicastOutboundChannelAdapterSpec
- unbound() - Method in class org.springframework.integration.transaction.IntegrationResourceHolder
- unchecked() - Method in interface org.springframework.integration.util.CheckedFunction
- UNDECODED - Static variable in class org.springframework.integration.syslog.SyslogHeaders
- UNDECODED - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
- UNDEFINED - Enum constant in enum class org.springframework.integration.syslog.RFC5424SyslogParser.Severity
- UnexpiredMessageSelector - Class in org.springframework.integration.selector
- 
AMessageSelectorthat acceptsMessagesthat are not yet expired.
- UnexpiredMessageSelector() - Constructor for class org.springframework.integration.selector.UnexpiredMessageSelector
- ungetc() - Method in class org.springframework.integration.syslog.RFC5424SyslogParser.Reader
- UnicastingDispatcher - Class in org.springframework.integration.dispatcher
- 
Implementation ofMessageDispatcherthat will attempt to send aMessageto at most one of its handlers.
- UnicastingDispatcher() - Constructor for class org.springframework.integration.dispatcher.UnicastingDispatcher
- UnicastingDispatcher(Executor) - Constructor for class org.springframework.integration.dispatcher.UnicastingDispatcher
- UnicastReceivingChannelAdapter - Class in org.springframework.integration.ip.udp
- 
A channel adapter to receive incoming UDP packets.
- UnicastReceivingChannelAdapter(int) - Constructor for class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
- 
Constructs a UnicastReceivingChannelAdapter that listens on the specified port.
- UnicastReceivingChannelAdapter(int, boolean) - Constructor for class org.springframework.integration.ip.udp.UnicastReceivingChannelAdapter
- 
Constructs a UnicastReceivingChannelAdapter that listens for packets on the specified port.
- UnicastSendingMessageHandler - Class in org.springframework.integration.ip.udp
- 
AMessageHandlerimplementation that maps a Message into a UDP datagram packet and sends that to the specified host and port.
- UnicastSendingMessageHandler(String) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- 
Construct UnicastSendingMessageHandler based on the destination SpEL expression to determine the target destination at runtime against requestMessage.
- UnicastSendingMessageHandler(String, int) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- 
Basic constructor; no reliability; no acknowledgment.
- UnicastSendingMessageHandler(String, int, boolean) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- 
Can used to add a length to each packet which can be checked at the destination.
- UnicastSendingMessageHandler(String, int, boolean, boolean, String, int, int) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- 
Add a length and/or acknowledgment request to packets.
- UnicastSendingMessageHandler(String, int, boolean, String, int, int) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- 
Add an acknowledgment request to packets.
- UnicastSendingMessageHandler(Expression) - Constructor for class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- 
Construct UnicastSendingMessageHandler based on the destination SpEL expression to determine the target destination at runtime against requestMessage.
- UniqueExpiryCallback - Interface in org.springframework.integration.store
- 
A marker interface extension of theMessageGroupStore.MessageGroupCallbackfor components which should be registered in theMessageGroupStoreonly once.
- UniqueMethodFilter - Class in org.springframework.integration.util
- UniqueMethodFilter(Class<?>) - Constructor for class org.springframework.integration.util.UniqueMethodFilter
- unlock(File) - Method in interface org.springframework.integration.file.FileLocker
- 
Unlocks the given file.
- unlock(File) - Method in class org.springframework.integration.file.locking.NioFileLocker
- unmarshaller(Unmarshaller) - Method in class org.springframework.integration.ws.dsl.MarshallingWsInboundGatewaySpec
- 
Specify an unmarshaller to use.
- unmarshaller(Unmarshaller) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
- 
Configure the unmarshaller to use.
- UnmarshallingTransformer - Class in org.springframework.integration.xml.transformer
- 
An implementation ofTransformerthat delegates to an OXMUnmarshaller.
- UnmarshallingTransformer(Unmarshaller) - Constructor for class org.springframework.integration.xml.transformer.UnmarshallingTransformer
- UnmarshallingTransformerParser - Class in org.springframework.integration.xml.config
- UnmarshallingTransformerParser() - Constructor for class org.springframework.integration.xml.config.UnmarshallingTransformerParser
- unregisterSender(TcpSender) - Method in class org.springframework.integration.ip.tcp.connection.AbstractConnectionFactory
- 
Unregister a TcpSender.
- unsolicitedMessageChannel(MessageChannel) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
- 
Set the unsolicited message channel.
- unsolicitedMessageChannelName(String) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
- 
Set the unsolicited message channel name.
- unsolictedMessageChannelName(String) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
- 
Deprecated, for removal: This API element is subject to removal in a future version.
- unsolictedMessageChannelName(MessageChannel) - Method in class org.springframework.integration.ip.dsl.TcpOutboundGatewaySpec
- 
Deprecated, for removal: This API element is subject to removal in a future version.in favor ofTcpOutboundGatewaySpec.unsolicitedMessageChannel(MessageChannel)due to the typo in method name.
- unsubscribe(PostgresChannelMessageTableSubscriber.Subscription) - Method in class org.springframework.integration.jdbc.channel.PostgresChannelMessageTableSubscriber
- 
Remove a previous subscription from this subscriber.
- unsubscribe(MessageHandler) - Method in class org.springframework.integration.amqp.channel.PointToPointSubscribableAmqpChannel
- unsubscribe(MessageHandler) - Method in class org.springframework.integration.channel.AbstractSubscribableChannel
- unsubscribe(MessageHandler) - Method in class org.springframework.integration.channel.FixedSubscriberChannel
- unsubscribe(MessageHandler) - Method in class org.springframework.integration.jdbc.channel.PostgresSubscribableChannel
- unsubscribe(MessageHandler) - Method in class org.springframework.integration.jms.SubscribableJmsChannel
- unsubscribe(MessageHandler) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
- unsubscribe(MessageHandler) - Method in class org.springframework.integration.redis.channel.SubscribableRedisChannel
- unsubscribe(MessageHandler) - Method in class org.springframework.integration.zeromq.channel.ZeroMqChannel
- unsubscribeFromTopics(String...) - Method in class org.springframework.integration.zeromq.inbound.ZeroMqMessageProducer
- unwrapExceptionIfNecessary(Exception) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
- 
Unwrap the cause of aAbstractRequestHandlerAdvice.ThrowableHolderException.
- unwrapThrowableIfNecessary(Exception) - Method in class org.springframework.integration.handler.advice.AbstractRequestHandlerAdvice
- 
Unwrap the cause of aAbstractRequestHandlerAdvice.ThrowableHolderException.
- UnZipResultSplitter - Class in org.springframework.integration.zip.splitter
- UnZipResultSplitter() - Constructor for class org.springframework.integration.zip.splitter.UnZipResultSplitter
- UnZipTransformer - Class in org.springframework.integration.zip.transformer
- 
Transformer implementation that applies an UnZip transformation to the message payload.
- UnZipTransformer() - Constructor for class org.springframework.integration.zip.transformer.UnZipTransformer
- UnZipTransformerParser - Class in org.springframework.integration.zip.config.xml
- 
Parser for the 'unzip-transformer' element.
- UnZipTransformerParser() - Constructor for class org.springframework.integration.zip.config.xml.UnZipTransformerParser
- update(String) - Method in class org.springframework.integration.mongodb.dsl.AbstractMongoDbMessageSourceSpec
- 
Configure a MongoDB update.
- update(Update) - Method in class org.springframework.integration.mongodb.dsl.AbstractMongoDbMessageSourceSpec
- 
Configure a MongoDB update.
- update(Expression) - Method in class org.springframework.integration.mongodb.dsl.AbstractMongoDbMessageSourceSpec
- 
Configure a SpEL expression to evaluate a MongoDB update.
- UPDATE - Enum constant in enum class org.springframework.integration.cassandra.outbound.CassandraMessageHandler.Type
- 
Set aCassandraMessageHandlerinto anupdatemode.
- UPDATE - Enum constant in enum class org.springframework.integration.r2dbc.outbound.R2dbcMessageHandler.Type
- 
Set aR2dbcMessageHandlerinto anupdatemode.
- updateAckAddress() - Method in class org.springframework.integration.ip.udp.UnicastSendingMessageHandler
- UPDATED - Enum constant in enum class org.springframework.integration.hazelcast.CacheEventType
- 
The Hazelcast UPDATED event.
- updateNotPropagatedHeaders(String[], boolean) - Method in class org.springframework.integration.handler.AbstractMessageProducingHandler
- 
Set or replace not propagated headers.
- updateSql(String) - Method in class org.springframework.integration.r2dbc.dsl.R2dbcMessageSourceSpec
- 
Configure an update query.
- updateSupplier(Supplier<Update>) - Method in class org.springframework.integration.mongodb.dsl.AbstractMongoDbMessageSourceSpec
- 
Configure aSupplierto produce a MongoDB update on each receive call.
- UPDATING - Enum constant in enum class org.springframework.integration.jpa.support.OutboundGatewayType
- updatingGateway(EntityManager) - Static method in class org.springframework.integration.jpa.dsl.Jpa
- 
Create aJpaUpdatingOutboundEndpointSpecbuilder instance for request-reply gateway based on the providedEntityManager.
- updatingGateway(EntityManagerFactory) - Static method in class org.springframework.integration.jpa.dsl.Jpa
- 
Create aJpaUpdatingOutboundEndpointSpecbuilder instance for request-reply gateway based on the providedEntityManagerFactory.
- updatingGateway(JpaOperations) - Static method in class org.springframework.integration.jpa.dsl.Jpa
- 
Create aJpaUpdatingOutboundEndpointSpecbuilder instance for request-reply gateway based on the providedJpaOperations.
- UpdatingJpaOutboundGatewayParser - Class in org.springframework.integration.jpa.config.xml
- 
The Parser for Updating JPA Outbound Gateway.
- UpdatingJpaOutboundGatewayParser() - Constructor for class org.springframework.integration.jpa.config.xml.UpdatingJpaOutboundGatewayParser
- UploadedMultipartFile - Class in org.springframework.integration.http.multipart
- 
AMultipartFileimplementation that represents an uploaded File.
- UploadedMultipartFile(byte[], String, String, String) - Constructor for class org.springframework.integration.http.multipart.UploadedMultipartFile
- UploadedMultipartFile(File, long, String, String, String) - Constructor for class org.springframework.integration.http.multipart.UploadedMultipartFile
- UpperBound - Class in org.springframework.integration.util
- 
Thin wrapper around a Semaphore that allows to create a potentially unlimited upper bound to by used in buffers of messages (e.g.
- UpperBound(int) - Constructor for class org.springframework.integration.util.UpperBound
- 
Create an UpperBound with the given capacity.
- uri - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- uri(String) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- 
Configure with a URI.
- uriFactory - Variable in class org.springframework.integration.http.outbound.AbstractHttpRequestExecutingMessageHandler
- uriFactory - Variable in class org.springframework.integration.ws.AbstractWebServiceOutboundGateway
- uriVariable(String, String) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
- 
Specify a value SpEL expression for the uri template variable.
- uriVariable(String, Function<Message<P>, ?>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
- 
Specify aFunctionto evaluate a value for the uri template variable.
- uriVariable(String, Expression) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
- 
Specify anExpressionto evaluate a value for the uri template variable.
- uriVariableExpressions(Map<String, Expression>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
- 
Set the Map of URI variable expressions to evaluate against the outbound message when replacing the variable placeholders in a URI template.
- uriVariableExpressions(Map<String, Expression>) - Method in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- 
Set the Map of URI variable expressions to evaluate against the outbound message when replacing the variable placeholders in a URI template.
- uriVariablesExpression(String) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
- 
Specify a SpEL expression to evaluate aMapof URI variables at runtime against request message.
- uriVariablesExpression(Expression) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
- 
Specify a SpEL expression to evaluate aMapof URI variables at runtime against request message.
- uriVariablesFunction(Function<Message<P>, Map<String, ?>>) - Method in class org.springframework.integration.http.dsl.BaseHttpMessageHandlerSpec
- useDefaultFilters() - Element in annotation interface org.springframework.integration.annotation.IntegrationComponentScan
- 
Indicates whether automatic detection of classes annotated with@MessagingGatewayshould be enabled.
- useFlowIdAsPrefix() - Method in interface org.springframework.integration.dsl.context.IntegrationFlowContext.IntegrationFlowRegistrationBuilder
- 
Invoke this method to prefix bean names in the flow with the (required) flow id and a period.
- useFlowIdAsPrefix() - Method in class org.springframework.integration.dsl.context.StandardIntegrationFlowContext.StandardIntegrationFlowRegistrationBuilder
- usePayloadAsParameterSource(Boolean) - Method in class org.springframework.integration.jpa.dsl.JpaBaseOutboundEndpointSpec
- 
Indicates that whether only the payload of the passed inMessagewill be used as a source of parameters.
- USER_PRINCIPAL - Static variable in class org.springframework.integration.http.HttpHeaders
- userFlag(String) - Method in class org.springframework.integration.mail.dsl.ImapIdleChannelAdapterSpec
- 
Set the name of the flag to use to flag messages when the server does not support \Recent but supports user flags; default "spring-integration-mail-adapter".
- userFlag(String) - Method in class org.springframework.integration.mail.dsl.MailInboundChannelAdapterSpec
- 
Set the name of the flag to use to flag messages when the server does not support \Recent but supports user flags; default "spring-integration-mail-adapter".
- UseSpelInvoker - Annotation Interface in org.springframework.integration.annotation
- 
Indicates that a POJO handler method (@ServiceActivator, @Transformer,etc., or such methods invoked from XML definitions) should be invoked using SpEL.
- useTemplateConverter(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
- 
Set to true to use the template's message converter to create theProducerRecordinstead of theproducerRecordCreator.
- useTemporaryFileName(boolean) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- 
Abooleanflag to use temporary files names or not.
- useTemporaryFileName(boolean) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Set whether a temporary file name is used when sending files to the remote system.
- useWatchService(boolean) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
- 
Switch thisFileReadingMessageSourceto use its internalWatchServicedirectory scanner.
- usingCallback(ExpressionEvalMap.EvaluationCallback) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
- usingEvaluationContext(EvaluationContext) - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
- usingEvaluationContext(EvaluationContext) - Method in interface org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapComponentsBuilder
- usingSimpleCallback() - Method in class org.springframework.integration.expression.ExpressionEvalMap.ExpressionEvalMapBuilder
- uuid - Variable in class org.springframework.integration.channel.DefaultHeaderChannelRegistry
- UUIDConverter - Class in org.springframework.integration.util
- 
Utility to help generate UUID instances from generic objects.
- UUIDConverter() - Constructor for class org.springframework.integration.util.UUIDConverter
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
TcpOutboundGatewaySpec.unsolicitedMessageChannelName(String)due to the typo in method name.