Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
F
- FACILITY - Static variable in class org.springframework.integration.syslog.SyslogHeaders
- FACILITY - Static variable in class org.springframework.integration.transformer.SyslogToMapTransformer
- FAIL - Enum constant in enum class org.springframework.integration.file.support.FileExistsMode
- 
Raise an exception in case the file to be written already exists.
- FAILED_MESSAGE_CONTEXT_KEY - Static variable in class org.springframework.integration.support.ErrorMessageUtils
- 
The context key for the message object.
- failedDeclarationRetryInterval(long) - Method in class org.springframework.integration.amqp.dsl.AbstractMessageListenerContainerSpec
- 
Set the interval between passive queue declaration attempts in milliseconds.
- failover - Variable in class org.springframework.integration.dsl.LoadBalancingChannelSpec
- failover(Boolean) - Method in class org.springframework.integration.dsl.LoadBalancingChannelSpec
- FailoverClientConnectionFactory - Class in org.springframework.integration.ip.tcp.connection
- 
Given a list of connection factories, serves upTcpConnections that can iterate over a connection from each factory until the write succeeds or the list is exhausted.
- FailoverClientConnectionFactory(List<AbstractClientConnectionFactory>) - Constructor for class org.springframework.integration.ip.tcp.connection.FailoverClientConnectionFactory
- 
Construct an instance with the provided delegate factories.
- FATAL - Enum constant in enum class org.springframework.integration.handler.LoggingHandler.Level
- FATAL_WHEN_NO_BEANFACTORY - Static variable in class org.springframework.integration.support.utils.IntegrationUtils
- 
Should be set to TRUE on CI plans and framework developer systems.
- faultMessageResolver - Variable in class org.springframework.integration.ws.dsl.BaseWsOutboundGatewaySpec
- faultMessageResolver(FaultMessageResolver) - Method in class org.springframework.integration.ws.dsl.MarshallingWsOutboundGatewaySpec.MarshallingWsOutboundGatewayNoTemplateSpec
- 
Specify theFaultMessageResolverto use.
- faultMessageResolver(FaultMessageResolver) - Method in class org.springframework.integration.ws.dsl.SimpleWsOutboundGatewaySpec.SimpleWsOutboundGatewayNoTemplateSpec
- 
Specify theFaultMessageResolverto use.
- Feed - Class in org.springframework.integration.feed.dsl
- 
The Spring Integration Feed components Factory.
- FeedEntryMessageSource - Class in org.springframework.integration.feed.inbound
- 
This implementation ofMessageSourcewill produce individualSyndEntrys for a feed identified with the 'feedUrl' attribute.
- FeedEntryMessageSource(URL, String) - Constructor for class org.springframework.integration.feed.inbound.FeedEntryMessageSource
- 
Creates a FeedEntryMessageSource that will use a HttpURLFeedFetcher to read feeds from the given URL.
- FeedEntryMessageSource(Resource, String) - Constructor for class org.springframework.integration.feed.inbound.FeedEntryMessageSource
- 
Creates a FeedEntryMessageSource that will read feeds from the givenResource.
- FeedEntryMessageSourceSpec - Class in org.springframework.integration.feed.dsl
- 
AMessageSourceSpecfor aFeedEntryMessageSource.
- FeedEntryMessageSourceSpec(URL, String) - Constructor for class org.springframework.integration.feed.dsl.FeedEntryMessageSourceSpec
- FeedEntryMessageSourceSpec(Resource, String) - Constructor for class org.springframework.integration.feed.dsl.FeedEntryMessageSourceSpec
- FeedInboundChannelAdapterParser - Class in org.springframework.integration.feed.config
- 
Handles parsing the configuration for the feed inbound-channel-adapter.
- FeedInboundChannelAdapterParser() - Constructor for class org.springframework.integration.feed.config.FeedInboundChannelAdapterParser
- FeedNamespaceHandler - Class in org.springframework.integration.feed.config
- 
NamespaceHandler for the feed module.
- FeedNamespaceHandler() - Constructor for class org.springframework.integration.feed.config.FeedNamespaceHandler
- fetchMessages(Message[]) - Method in class org.springframework.integration.mail.AbstractMailReceiver
- 
Fetches the specified messages from this receiver's folder.
- file(File) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
- FileAggregatingMessageGroupProcessor - Class in org.springframework.integration.file.aggregator
- 
AnAbstractAggregatingMessageGroupProcessorimplementation for file content collecting previously splitted by theFileSplitterwith themarkersoption turned on.
- FileAggregatingMessageGroupProcessor() - Constructor for class org.springframework.integration.file.aggregator.FileAggregatingMessageGroupProcessor
- FileAggregator - Class in org.springframework.integration.file.aggregator
- 
A convenient component to utilize aFileSplitter.FileMarker-based aggregation logic.
- FileAggregator() - Constructor for class org.springframework.integration.file.aggregator.FileAggregator
- FileCopyingMultipartFileReader - Class in org.springframework.integration.http.multipart
- 
MultipartFileReaderimplementation that copies the MultipartFile's content to a new temporary File in the specified directory.
- FileCopyingMultipartFileReader() - Constructor for class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
- 
Create aFileCopyingMultipartFileReaderthat creates temporary Files in the default temporary directory.
- FileCopyingMultipartFileReader(File) - Constructor for class org.springframework.integration.http.multipart.FileCopyingMultipartFileReader
- 
Create aFileCopyingMultipartFileReaderthat creates temporary Files in the given directory.
- fileDelay(long) - Method in class org.springframework.integration.file.dsl.TailAdapterSpec
- 
The delay in milliseconds between attempts to tail a non-existent file, or between attempts to execute a process if it fails for any reason.
- fileExistsMode(FileExistsMode) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- 
Set theFileExistsModethat specifies what will happen in case the destination exists.
- fileExistsMode(FileExistsMode) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Determine the action to take when using GET and MGET operations when the file already exists locally, or PUT and MPUT when the file exists on the remote system.
- FileExistsMode - Enum Class in org.springframework.integration.file.support
- 
When writing file, this enumeration indicates what action shall be taken in case the destination file already exists.
- fileFilters - Variable in class org.springframework.integration.file.filters.CompositeFileListFilter
- FileHeaders - Class in org.springframework.integration.file
- 
Pre-defined header names to be used when storing or retrieving File-related values to/from integration Message Headers.
- FileHeaders() - Constructor for class org.springframework.integration.file.FileHeaders
- FileInboundChannelAdapterParser - Class in org.springframework.integration.file.config
- 
Parser for the <inbound-channel-adapter> element of the 'file' namespace.
- FileInboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.FileInboundChannelAdapterParser
- FileInboundChannelAdapterSpec - Class in org.springframework.integration.file.dsl
- FileInboundChannelAdapterSpec() - Constructor for class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
- FileInboundChannelAdapterSpec(Comparator<File>) - Constructor for class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
- FileInfo<F> - Interface in org.springframework.integration.file.remote
- 
Represents a remote file info - an abstraction over the underlying implementation.
- FileIntegrationEvent - Class in org.springframework.integration.file.event
- FileIntegrationEvent(Object) - Constructor for class org.springframework.integration.file.event.FileIntegrationEvent
- FileKryoRegistrar - Class in org.springframework.integration.codec.kryo
- 
AKryoRegistrarused to validateRegistration a File serializer.
- FileKryoRegistrar() - Constructor for class org.springframework.integration.codec.kryo.FileKryoRegistrar
- FileKryoRegistrar(int) - Constructor for class org.springframework.integration.codec.kryo.FileKryoRegistrar
- FileListFilter<F> - Interface in org.springframework.integration.file.filters
- 
Strategy interface for filtering a group of files.
- fileListFilterFactoryBean - Variable in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
- FileListFilterFactoryBean - Class in org.springframework.integration.file.config
- FileListFilterFactoryBean() - Constructor for class org.springframework.integration.file.config.FileListFilterFactoryBean
- FileLocker - Interface in org.springframework.integration.file
- 
A FileLocker is a strategy that can ensure that files are only processed a single time.
- FileMarker() - Constructor for class org.springframework.integration.file.splitter.FileSplitter.FileMarker
- FileMarker(String, FileSplitter.FileMarker.Mark, long) - Constructor for class org.springframework.integration.file.splitter.FileSplitter.FileMarker
- FileMarkerReleaseStrategy - Class in org.springframework.integration.file.aggregator
- 
AReleaseStrategywhich makes a decision based on the presence ofFileSplitter.FileMarker.Mark.ENDmessage in the group and itsFileHeaders.LINE_COUNTheader.
- FileMarkerReleaseStrategy() - Constructor for class org.springframework.integration.file.aggregator.FileMarkerReleaseStrategy
- fileName(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- fileName(File) - Method in class org.springframework.integration.file.filters.FileSystemPersistentAcceptOnceFileListFilter
- fileName(SmbFile) - Method in class org.springframework.integration.smb.filters.SmbPersistentAcceptOnceFileListFilter
- fileName(FTPFile) - Method in class org.springframework.integration.ftp.filters.FtpPersistentAcceptOnceFileListFilter
- fileName(SftpClient.DirEntry) - Method in class org.springframework.integration.sftp.filters.SftpPersistentAcceptOnceFileListFilter
- FILENAME - Static variable in class org.springframework.integration.file.FileHeaders
- fileNameExpression(String) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- 
Set theDefaultFileNameGeneratorbased on the provided SpEL expression.
- fileNameExpression(String) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- 
Set theDefaultFileNameGeneratorbased on the provided SpEL expression.
- fileNameExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Set the file name expression to determine the full path to the remote file.
- fileNameExpression(Expression) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Set the file name expression to determine the full path to the remote file.
- fileNameFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Set the file name function to determine the full path to the remote file.
- fileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- 
Set the file name generator used to generate the remote filename to be used when transferring files to the remote system.
- fileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- 
Set the file name generator used to generate the target file name.
- fileNameGenerator(FileNameGenerator) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Set the file name generator used to generate the remote filename to be used when transferring files to the remote system.
- FileNameGenerator - Interface in org.springframework.integration.file
- 
Strategy interface for generating a file name from a message.
- FileNamespaceHandler - Class in org.springframework.integration.file.config
- 
Namespace handler for Spring Integration's 'file' namespace.
- FileNamespaceHandler() - Constructor for class org.springframework.integration.file.config.FileNamespaceHandler
- fileNotFound() - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
- FileOutboundChannelAdapterParser - Class in org.springframework.integration.file.config
- 
Parser for the <outbound-channel-adapter/> element of the 'file' namespace.
- FileOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.FileOutboundChannelAdapterParser
- FileOutboundGatewayParser - Class in org.springframework.integration.file.config
- 
Parser for the 'outbound-gateway' element of the file namespace.
- FileOutboundGatewayParser() - Constructor for class org.springframework.integration.file.config.FileOutboundGatewayParser
- FileParserUtils - Class in org.springframework.integration.file.config
- FileReadingMessageSource - Class in org.springframework.integration.file
- 
MessageSourcethat creates messages from a file system directory.
- FileReadingMessageSource() - Constructor for class org.springframework.integration.file.FileReadingMessageSource
- 
Create a FileReadingMessageSource with a naturally ordered queue of unbounded capacity.
- FileReadingMessageSource(int) - Constructor for class org.springframework.integration.file.FileReadingMessageSource
- 
Create a FileReadingMessageSource with a bounded queue of the given capacity.
- FileReadingMessageSource(Comparator<File>) - Constructor for class org.springframework.integration.file.FileReadingMessageSource
- 
Create a FileReadingMessageSource with aPriorityBlockingQueueordered with the passed inComparator.
- FileReadingMessageSource.WatchEventType - Enum Class in org.springframework.integration.file
- FileReadingMessageSourceFactoryBean - Class in org.springframework.integration.file.config
- FileReadingMessageSourceFactoryBean() - Constructor for class org.springframework.integration.file.config.FileReadingMessageSourceFactoryBean
- fileRotated() - Method in class org.springframework.integration.file.tail.ApacheCommonsFileTailingMessageProducer
- Files - Class in org.springframework.integration.file.dsl
- 
The Spring Integration File components Factory.
- Files() - Constructor for class org.springframework.integration.file.dsl.Files
- FileSerializer - Class in org.springframework.integration.codec.kryo
- 
A custom KryoSerializerfor serializing File payloads.
- FileSerializer() - Constructor for class org.springframework.integration.codec.kryo.FileSerializer
- FileServerEvent - Class in org.springframework.integration.file.remote.server
- 
Base class for file server events.
- FileServerEvent(Object) - Constructor for class org.springframework.integration.file.remote.server.FileServerEvent
- FileServerEvent(Object, Throwable) - Constructor for class org.springframework.integration.file.remote.server.FileServerEvent
- FileSplitter - Class in org.springframework.integration.file.splitter
- 
TheAbstractMessageSplitterimplementation to split theFileMessage payload to lines.
- FileSplitter() - Constructor for class org.springframework.integration.file.splitter.FileSplitter
- 
Construct a splitter where theFileSplitter.splitMessage(Message)method returns an iterator and the file is read line-by-line during iteration.
- FileSplitter(boolean) - Constructor for class org.springframework.integration.file.splitter.FileSplitter
- 
Construct a splitter where theFileSplitter.splitMessage(Message)method returns an iterator, and the file is read line-by-line during iteration, or a list of lines from the file.
- FileSplitter(boolean, boolean) - Constructor for class org.springframework.integration.file.splitter.FileSplitter
- 
Construct a splitter where theFileSplitter.splitMessage(Message)method returns an iterator, and the file is read line-by-line during iteration, or a list of lines from the file.
- FileSplitter(boolean, boolean, boolean) - Constructor for class org.springframework.integration.file.splitter.FileSplitter
- 
Construct a splitter where theFileSplitter.splitMessage(Message)method returns an iterator, and the file is read line-by-line during iteration, or a list of lines from the file.
- FileSplitter.FileMarker - Class in org.springframework.integration.file.splitter
- FileSplitter.FileMarker.Mark - Enum Class in org.springframework.integration.file.splitter
- FileSplitterParser - Class in org.springframework.integration.file.config
- FileSplitterParser() - Constructor for class org.springframework.integration.file.config.FileSplitterParser
- FileSplitterSpec - Class in org.springframework.integration.file.dsl
- 
TheMessageHandlerSpecfor theFileSplitter.
- FileSplitterSpec() - Constructor for class org.springframework.integration.file.dsl.FileSplitterSpec
- FileSplitterSpec(boolean) - Constructor for class org.springframework.integration.file.dsl.FileSplitterSpec
- FileSplitterSpec(boolean, boolean) - Constructor for class org.springframework.integration.file.dsl.FileSplitterSpec
- fileStillExists(F) - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- 
Check if the file still exists; default implementation returns true.
- fileStillExists(File) - Method in class org.springframework.integration.file.filters.FileSystemPersistentAcceptOnceFileListFilter
- 
Check that the file still exists, to avoid a race condition when multi-threaded and another thread removed the file while we were waiting for the lock.
- FileSystemMarkerFilePresentFileListFilter - Class in org.springframework.integration.file.filters
- 
File system implementation ofAbstractMarkerFilePresentFileListFilter.
- FileSystemMarkerFilePresentFileListFilter(Map<FileListFilter<File>, Function<String, String>>) - Constructor for class org.springframework.integration.file.filters.FileSystemMarkerFilePresentFileListFilter
- FileSystemMarkerFilePresentFileListFilter(FileListFilter<File>) - Constructor for class org.springframework.integration.file.filters.FileSystemMarkerFilePresentFileListFilter
- FileSystemMarkerFilePresentFileListFilter(FileListFilter<File>, String) - Constructor for class org.springframework.integration.file.filters.FileSystemMarkerFilePresentFileListFilter
- FileSystemMarkerFilePresentFileListFilter(FileListFilter<File>, Function<String, String>) - Constructor for class org.springframework.integration.file.filters.FileSystemMarkerFilePresentFileListFilter
- FileSystemPersistentAcceptOnceFileListFilter - Class in org.springframework.integration.file.filters
- FileSystemPersistentAcceptOnceFileListFilter(ConcurrentMetadataStore, String) - Constructor for class org.springframework.integration.file.filters.FileSystemPersistentAcceptOnceFileListFilter
- FileTailInboundChannelAdapterFactoryBean - Class in org.springframework.integration.file.config
- FileTailInboundChannelAdapterFactoryBean() - Constructor for class org.springframework.integration.file.config.FileTailInboundChannelAdapterFactoryBean
- FileTailInboundChannelAdapterParser - Class in org.springframework.integration.file.config
- FileTailInboundChannelAdapterParser() - Constructor for class org.springframework.integration.file.config.FileTailInboundChannelAdapterParser
- FileTailingEvent(Object, String, File) - Constructor for class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingEvent
- FileTailingIdleEvent(Object, File, long) - Constructor for class org.springframework.integration.file.tail.FileTailingMessageProducerSupport.FileTailingIdleEvent
- FileTailingMessageProducerSupport - Class in org.springframework.integration.file.tail
- 
Base class for file tailing inbound adapters.
- FileTailingMessageProducerSupport() - Constructor for class org.springframework.integration.file.tail.FileTailingMessageProducerSupport
- FileTailingMessageProducerSupport.FileTailingEvent - Class in org.springframework.integration.file.tail
- FileTailingMessageProducerSupport.FileTailingIdleEvent - Class in org.springframework.integration.file.tail
- FileToByteArrayTransformer - Class in org.springframework.integration.file.transformer
- 
A payload transformer that copies a File's contents to a byte array.
- FileToByteArrayTransformer() - Constructor for class org.springframework.integration.file.transformer.FileToByteArrayTransformer
- FileToByteArrayTransformerParser - Class in org.springframework.integration.file.config
- 
Parser for the <file-to-bytes-transformer> element.
- FileToByteArrayTransformerParser() - Constructor for class org.springframework.integration.file.config.FileToByteArrayTransformerParser
- FileToStringTransformer - Class in org.springframework.integration.file.transformer
- 
A payload transformer that copies a File's contents to a String.
- FileToStringTransformer() - Constructor for class org.springframework.integration.file.transformer.FileToStringTransformer
- FileToStringTransformerParser - Class in org.springframework.integration.file.config
- 
Parser for the <file-to-string-transformer> element.
- FileToStringTransformerParser() - Constructor for class org.springframework.integration.file.config.FileToStringTransformerParser
- FileTransferringMessageHandler<F> - Class in org.springframework.integration.file.remote.handler
- 
AMessageHandlerimplementation that transfers files to a remote server.
- FileTransferringMessageHandler(RemoteFileTemplate<F>) - Constructor for class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
- FileTransferringMessageHandler(RemoteFileTemplate<F>, FileExistsMode) - Constructor for class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
- FileTransferringMessageHandler(SessionFactory<F>) - Constructor for class org.springframework.integration.file.remote.handler.FileTransferringMessageHandler
- FileTransferringMessageHandlerSpec<F,S extends FileTransferringMessageHandlerSpec<F, S>> - Class in org.springframework.integration.file.dsl 
- 
TheMessageHandlerSpecfor theFileTransferringMessageHandler.
- FileTransferringMessageHandlerSpec() - Constructor for class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- FileTransferringMessageHandlerSpec(RemoteFileTemplate<F>) - Constructor for class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- FileTransferringMessageHandlerSpec(RemoteFileTemplate<F>, FileExistsMode) - Constructor for class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- FileTransferringMessageHandlerSpec(SessionFactory<F>) - Constructor for class org.springframework.integration.file.dsl.FileTransferringMessageHandlerSpec
- FileUtils - Class in org.springframework.integration.file.support
- 
Utilities for operations on Files.
- FileWritingMessageHandler - Class in org.springframework.integration.file
- 
AMessageHandlerimplementation that writes the Message payload to a file.
- FileWritingMessageHandler(File) - Constructor for class org.springframework.integration.file.FileWritingMessageHandler
- 
Constructor which sets theFileWritingMessageHandler.destinationDirectoryExpressionusing aLiteralExpression.
- FileWritingMessageHandler(Expression) - Constructor for class org.springframework.integration.file.FileWritingMessageHandler
- 
Constructor which sets theFileWritingMessageHandler.destinationDirectoryExpression.
- FileWritingMessageHandler.FlushPredicate - Interface in org.springframework.integration.file
- 
When usingFileExistsMode.APPEND_NO_FLUSH, an implementation of this interface is called for each file that has pending data to flush and close whenFileWritingMessageHandler.flushIfNeeded(FlushPredicate)is invoked.
- FileWritingMessageHandler.MessageFlushPredicate - Interface in org.springframework.integration.file
- 
When usingFileExistsMode.APPEND_NO_FLUSHan implementation of this interface is called for each file that has pending data to flush when a trigger message is received.
- FileWritingMessageHandlerFactoryBean - Class in org.springframework.integration.file.config
- 
Factory bean used to createFileWritingMessageHandlers.
- FileWritingMessageHandlerFactoryBean() - Constructor for class org.springframework.integration.file.config.FileWritingMessageHandlerFactoryBean
- FileWritingMessageHandlerSpec - Class in org.springframework.integration.file.dsl
- 
TheMessageHandlerSpecfor theFileWritingMessageHandler.
- FileWritingMessageHandlerSpec(File) - Constructor for class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- FileWritingMessageHandlerSpec(String) - Constructor for class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- FileWritingMessageHandlerSpec(Function<Message<P>, ?>) - Constructor for class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- FileWritingMessageHandlerSpec(Expression) - Constructor for class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- FileWrittenEvent - Class in org.springframework.integration.ftp.server
- 
An event that is emitted when a file is written.
- FileWrittenEvent - Class in org.springframework.integration.sftp.server
- 
An event that is emitted when a file is written.
- FileWrittenEvent(Object, String, Path, int, Throwable) - Constructor for class org.springframework.integration.sftp.server.FileWrittenEvent
- FileWrittenEvent(FtpSession, FtpRequest, boolean) - Constructor for class org.springframework.integration.ftp.server.FileWrittenEvent
- fillToCrLf(InputStream, byte[]) - Method in class org.springframework.integration.ip.tcp.serializer.ByteArrayCrLfSerializer
- filter - Enum constant in enum class org.springframework.integration.IntegrationPatternType
- filter(Class<P>, GenericSelector<P>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- filter(Class<P>, GenericSelector<P>, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- filter(Object) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate aMessageFilterwithMethodInvokingSelectorfor the discovered method of the provided service.
- filter(Object, String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate aMessageFilterwithMethodInvokingSelectorfor the method of the provided service.
- filter(Object, String, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate aMessageFilterwithMethodInvokingSelectorfor the method of the provided service.
- filter(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate aMessageFilterwithMessageSelectorfor the provided SpEL expression.
- filter(String, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate aMessageFilterwithMessageSelectorfor the provided SpEL expression.
- filter(Collection<T>) - Method in class org.springframework.integration.util.AcceptOnceCollectionFilter
- filter(Collection<T>) - Method in interface org.springframework.integration.util.CollectionFilter
- filter(List<Method>) - Method in class org.springframework.integration.expression.ControlBusMethodFilter
- filter(List<Method>) - Method in class org.springframework.integration.util.AnnotatedMethodFilter
- filter(List<Method>) - Method in class org.springframework.integration.util.FixedMethodFilter
- filter(GenericSelector<P>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
- filter(GenericSelector<P>, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowDefinition
- filter(MessageProcessorSpec<?>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate aMessageFilterwithMethodInvokingSelectorfor theMessageProcessorfrom the providedMessageProcessorSpec.
- filter(MessageProcessorSpec<?>, Consumer<FilterEndpointSpec>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate aMessageFilterwithMethodInvokingSelectorfor theMessageProcessorfrom the providedMessageProcessorSpec.
- filter(FileListFilter<F>) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
- 
Configure aFileListFilterto be applied to the remote files before copying them.
- filter(FileListFilter<F>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Set aFileListFilterto filter remote files.
- filter(FileListFilter<F>) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
- 
Configure aFileListFilterto be applied to the remote files before copying them.
- filter(FileListFilter<File>) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
- 
Configure the filter.
- Filter - Annotation Interface in org.springframework.integration.annotation
- 
Indicates that a method is capable of playing the role of a Message Filter.
- FILTER_ATTRIBUTE - Static variable in class org.springframework.integration.file.config.FileParserUtils
- filterAndCopyHeadersIfAbsent(Map<String, ?>, String...) - Method in class org.springframework.integration.support.AbstractIntegrationMessageBuilder
- 
Remove headers from the provided map matching to the provided pattens and only after that copy the result into the target message headers.
- FilterAnnotationPostProcessor - Class in org.springframework.integration.config
- 
Post-processor for Methods annotated with@Filter.
- FilterAnnotationPostProcessor() - Constructor for class org.springframework.integration.config.FilterAnnotationPostProcessor
- FilterEndpointSpec - Class in org.springframework.integration.dsl
- 
AConsumerEndpointSpecimplementation for theMessageFilter.
- FilterEndpointSpec(MessageFilter) - Constructor for class org.springframework.integration.dsl.FilterEndpointSpec
- filterExpression(String) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
- 
Configure theExpressionFileListFilter.
- filterExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
- 
Configure theExpressionFileListFilter.
- filterExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Configure theExpressionFileListFilter.
- filterExpression(String) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
- 
Configure theExpressionFileListFilter.
- FilterFactoryBean - Class in org.springframework.integration.config
- 
Factory bean for creating a Message Filter.
- FilterFactoryBean() - Constructor for class org.springframework.integration.config.FilterFactoryBean
- filterFile(F) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- filterFiles(F[]) - Method in class org.springframework.integration.file.filters.AbstractFileListFilter
- filterFiles(F[]) - Method in class org.springframework.integration.file.filters.AbstractMarkerFilePresentFileListFilter
- filterFiles(F[]) - Method in class org.springframework.integration.file.filters.ChainFileListFilter
- filterFiles(F[]) - Method in class org.springframework.integration.file.filters.CompositeFileListFilter
- filterFiles(F[]) - Method in interface org.springframework.integration.file.filters.FileListFilter
- 
Filters out files and returns the files that are left in a list, or an empty list when a null is passed in.
- filterFiles(F[]) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- filterFiles(F[]) - Method in class org.springframework.integration.file.remote.synchronizer.AbstractInboundFileSynchronizer
- filterFiles(File[]) - Method in class org.springframework.integration.file.filters.LastModifiedFileListFilter
- filterFunction(Function<F, Boolean>) - Method in class org.springframework.integration.file.dsl.RemoteFileInboundChannelAdapterSpec
- 
Configure theExpressionFileListFilter.
- filterFunction(Function<F, Boolean>) - Method in class org.springframework.integration.file.dsl.RemoteFileOutboundGatewaySpec
- 
Configure theExpressionFileListFilter.
- filterFunction(Function<F, Boolean>) - Method in class org.springframework.integration.file.dsl.RemoteFileStreamingInboundChannelAdapterSpec
- 
Configure theExpressionFileListFilter.
- filterFunction(Function<File, Boolean>) - Method in class org.springframework.integration.file.dsl.FileInboundChannelAdapterSpec
- 
Configure theExpressionFileListFilter.
- filterInRetry(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
- 
Thebooleanflag to specify the order in which the filter and retry operations are performed.
- filterMputFiles(File[]) - Method in class org.springframework.integration.file.remote.gateway.AbstractRemoteFileOutboundGateway
- FilterParser - Class in org.springframework.integration.config.xml
- 
Parser for the <filter/> element.
- FilterParser() - Constructor for class org.springframework.integration.config.xml.FilterParser
- Filters - Annotation Interface in org.springframework.integration.annotation
- 
The repeatable container forFilterannotations.
- finalizeRaw() - Method in class org.springframework.integration.file.remote.session.CachingSessionFactory.CachedSession
- finalizeRaw() - Method in interface org.springframework.integration.file.remote.session.Session
- 
Invoke after closing the InputStream fromSession.readRaw(String).
- finalizeRaw() - Method in class org.springframework.integration.ftp.session.FtpSession
- finalizeRaw() - Method in class org.springframework.integration.sftp.session.SftpSession
- finalizeRaw() - Method in class org.springframework.integration.smb.session.SmbSession
- find(Class<T>, Object) - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
- find(Class<T>, Object) - Method in interface org.springframework.integration.jpa.core.JpaOperations
- 
Find an Entity of given type with the given primary key type.
- findAnnotatedMethod(Object, Class<? extends Annotation>) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
- findClosestMatch(Class<?>, Set<Class<?>>, boolean) - Static method in class org.springframework.integration.util.ClassUtils
- findLastReleasedSequenceNumber(Object, Collection<Message<?>>) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- findMessagePartAnnotation(Annotation[], boolean) - Static method in class org.springframework.integration.util.MessagingAnnotationUtils
- findProtocolHandler(WebSocketSession) - Method in class org.springframework.integration.websocket.support.SubProtocolHandlerRegistry
- fireAndForget - Enum constant in enum class org.springframework.integration.rsocket.RSocketInteractionModel
- 
The model forRSocket.fireAndForget(io.rsocket.Payload)operation.
- firstId() - Method in class org.springframework.integration.store.MessageGroupMetadata
- firstLineAsHeader(String) - Method in class org.springframework.integration.file.dsl.FileSplitterSpec
- 
Specify the header name for the first line to be carried as a header in the messages emitted for the remaining lines.
- firstResult(int) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
- 
Specify a first result in the query executed.
- firstResultExpression(String) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
- 
Specify a SpEL expression that will be evaluated to get the first result in the query executed.
- firstResultExpression(Expression) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
- 
Specify a SpEL expression that will be evaluated to get the first result in the query executed.
- fixedDelay() - Element in annotation interface org.springframework.integration.annotation.Poller
- fixedDelay(long) - Method in class org.springframework.integration.dsl.PollerFactory
- fixedDelay(long) - Static method in class org.springframework.integration.dsl.Pollers
- fixedDelay(long, long) - Method in class org.springframework.integration.dsl.PollerFactory
- fixedDelay(long, long) - Static method in class org.springframework.integration.dsl.Pollers
- fixedDelay(long, TimeUnit) - Method in class org.springframework.integration.dsl.PollerFactory
- fixedDelay(long, TimeUnit) - Static method in class org.springframework.integration.dsl.Pollers
- 
Deprecated, for removal: This API element is subject to removal in a future version.
- fixedDelay(long, TimeUnit, long) - Method in class org.springframework.integration.dsl.PollerFactory
- fixedDelay(long, TimeUnit, long) - Static method in class org.springframework.integration.dsl.Pollers
- 
Deprecated, for removal: This API element is subject to removal in a future version.since 6.0 in favor ofPollers.fixedDelay(Duration, Duration)
- fixedDelay(Duration) - Static method in class org.springframework.integration.dsl.Pollers
- fixedDelay(Duration, Duration) - Static method in class org.springframework.integration.dsl.Pollers
- FixedMethodFilter - Class in org.springframework.integration.util
- 
AMethodFilterimplementation that will always return the same Method instance within a single-element list if it is present in the candidate list.
- FixedMethodFilter(Method) - Constructor for class org.springframework.integration.util.FixedMethodFilter
- fixedRate() - Element in annotation interface org.springframework.integration.annotation.Poller
- fixedRate(long) - Method in class org.springframework.integration.dsl.PollerFactory
- fixedRate(long) - Static method in class org.springframework.integration.dsl.Pollers
- fixedRate(long, long) - Method in class org.springframework.integration.dsl.PollerFactory
- fixedRate(long, long) - Static method in class org.springframework.integration.dsl.Pollers
- fixedRate(long, TimeUnit) - Method in class org.springframework.integration.dsl.PollerFactory
- fixedRate(long, TimeUnit) - Static method in class org.springframework.integration.dsl.Pollers
- 
Deprecated, for removal: This API element is subject to removal in a future version.since 6.0 in favor ofPollers.fixedRate(Duration)
- fixedRate(long, TimeUnit, long) - Method in class org.springframework.integration.dsl.PollerFactory
- fixedRate(long, TimeUnit, long) - Static method in class org.springframework.integration.dsl.Pollers
- 
Deprecated, for removal: This API element is subject to removal in a future version.since 6.0 in favor ofPollers.fixedRate(Duration, Duration)
- fixedRate(Duration) - Static method in class org.springframework.integration.dsl.Pollers
- fixedRate(Duration, Duration) - Static method in class org.springframework.integration.dsl.Pollers
- fixedSubscriberChannel() - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate anFixedSubscriberChannelinstance at the currentIntegrationFlowchain position.
- fixedSubscriberChannel(String) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate anFixedSubscriberChannelinstance at the currentIntegrationFlowchain position.
- FixedSubscriberChannel - Class in org.springframework.integration.channel
- 
SpecializedSubscribableChannelfor a single final subscriber set up during bean instantiation (unlike otherSubscribableChannels where theMessageHandleris subscribed when the endpoint is started).
- FixedSubscriberChannel() - Constructor for class org.springframework.integration.channel.FixedSubscriberChannel
- FixedSubscriberChannel(MessageHandler) - Constructor for class org.springframework.integration.channel.FixedSubscriberChannel
- FixedSubscriberChannelBeanFactoryPostProcessor - Class in org.springframework.integration.config
- 
Used to post process candidates forFixedSubscriberChannelMessageHandlers.
- FixedSubscriberChannelPrototype - Class in org.springframework.integration.dsl.support
- 
An "artificial"MessageChannelimplementation which will be unwrapped to theFixedSubscriberChannelon the bean registration phase.
- FixedSubscriberChannelPrototype() - Constructor for class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
- FixedSubscriberChannelPrototype(String) - Constructor for class org.springframework.integration.dsl.support.FixedSubscriberChannelPrototype
- FLAGS - Static variable in class org.springframework.integration.mail.MailHeaders
- FLOAT - Enum constant in enum class org.springframework.integration.jdbc.config.JdbcTypesEnum
- flush() - Method in class org.springframework.integration.jpa.core.DefaultJpaOperations
- flush() - Method in interface org.springframework.integration.jpa.core.JpaOperations
- 
ExecutesEntityManager.flush().
- flush() - Method in class org.springframework.integration.metadata.PropertiesPersistingMetadataStore
- flush(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaUpdatingOutboundEndpointSpec
- 
If set totruetheEntityManager.flush()will be called after persistence operation.
- flush(Function<Message<P>, Boolean>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
- 
Configure aFunctionthat will be invoked at runtime to determine whether to flush the producer after send.
- FLUSH - Static variable in class org.springframework.integration.kafka.support.KafkaIntegrationHeaders
- 
Set toBoolean.TRUEto flush after sending.
- flushableStore - Variable in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- flushAfterDelete(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaInboundChannelAdapterSpec
- 
If set totruetheEntityManager.flush()will be called after persistence operation.
- flushAfterDelete(boolean) - Method in class org.springframework.integration.jpa.dsl.JpaRetrievingOutboundGatewaySpec
- 
If set totruetheEntityManager.flush()will be called after persistence operation.
- flushExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
- 
Configure a SpEL expression to determine whether to flush the producer after a send.
- flushExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
- 
Configure anExpressionto determine whether to flush the producer after a send.
- flushIfNeeded() - Method in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- 
Flush the store if it's aFlushableandflushOnUpdateis true.
- flushIfNeeded(FileWritingMessageHandler.FlushPredicate) - Method in class org.springframework.integration.file.FileWritingMessageHandler
- 
When usingFileExistsMode.APPEND_NO_FLUSHyou can invoke this method to selectively flush and close open files.
- flushIfNeeded(FileWritingMessageHandler.MessageFlushPredicate, Message<?>) - Method in class org.springframework.integration.file.FileWritingMessageHandler
- 
When usingFileExistsMode.APPEND_NO_FLUSHyou can invoke this method to selectively flush and close open files.
- flushInterval(long) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- 
Set the frequency to flush buffers whenFileExistsMode.APPEND_NO_FLUSHis being used.
- flushOnUpdate - Variable in class org.springframework.integration.file.filters.AbstractPersistentAcceptOnceFileListFilter
- flushPredicate(FileWritingMessageHandler.MessageFlushPredicate) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- 
Specify aFileWritingMessageHandler.MessageFlushPredicatefor flush task when theFileExistsMode.APPEND_NO_FLUSHis in use.
- flushSize(int) - Method in class org.springframework.integration.jpa.dsl.JpaUpdatingOutboundEndpointSpec
- 
If the provided value is greater than0, thenEntityManager.flush()will be called after persistence operations as well as within batch operations.
- flushWhenIdle(boolean) - Method in class org.springframework.integration.file.dsl.FileWritingMessageHandlerSpec
- 
Set the flush when idle flag to false if you wish the interval to apply to when the file was opened rather than when the file was last written.
- flux() - Method in class org.springframework.integration.dsl.Channels
- flux() - Static method in class org.springframework.integration.dsl.MessageChannels
- flux(String) - Method in class org.springframework.integration.dsl.Channels
- flux(String) - Static method in class org.springframework.integration.dsl.MessageChannels
- FluxAggregatorMessageHandler - Class in org.springframework.integration.aggregator
- 
TheAbstractMessageProducingHandlerimplementation for aggregation logic based on Reactor'sFlux.groupBy(java.util.function.Function<? super T, ? extends K>)andFlux.window(int)operators.
- FluxAggregatorMessageHandler() - Constructor for class org.springframework.integration.aggregator.FluxAggregatorMessageHandler
- 
Create an instance with aFlux.create(java.util.function.Consumer<? super reactor.core.publisher.FluxSink<T>>)and applyFlux.groupBy(java.util.function.Function<? super T, ? extends K>)andFlux.window(int)transformation into it.
- FluxMessageChannel - Class in org.springframework.integration.channel
- 
TheAbstractMessageChannelimplementation for the Reactive StreamsPublisherbased on the Project ReactorFlux.
- FluxMessageChannel() - Constructor for class org.springframework.integration.channel.FluxMessageChannel
- FluxMessageChannelSpec - Class in org.springframework.integration.dsl
- FluxMessageChannelSpec() - Constructor for class org.springframework.integration.dsl.FluxMessageChannelSpec
- fluxTransform(Function<? super Flux<Message<I>>, ? extends Publisher<O>>) - Method in class org.springframework.integration.dsl.BaseIntegrationFlowDefinition
- 
Populate aFluxMessageChannelto start a reactive processing for upstream data, wrap it to aFlux, apply providedFunctionviaFlux.transform(Function)and emit the result to one moreFluxMessageChannel, subscribed in the downstream flow.
- forceClose(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.AbstractClientConnectionFactory
- 
Force close the connection and null the field if it's a shared connection.
- forceClose(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.CachingClientConnectionFactory
- forceClose(TcpConnection) - Method in class org.springframework.integration.ip.tcp.connection.ThreadAffinityClientConnectionFactory
- forceComplete(MessageGroup) - Method in class org.springframework.integration.aggregator.AbstractCorrelatingMessageHandler
- forceReleaseAdvice(Advice...) - Method in class org.springframework.integration.dsl.CorrelationHandlerSpec
- 
Configure a list ofAdviceobjects to be applied to theforceComplete()operation.
- forLevel(Level) - Static method in class org.springframework.integration.test.rule.Log4j2LevelAdjuster
- 
The factory to produce Log4j2LevelAdjuster instances for arbitrary loggingLevelwith theorg.springframework.integrationas default category.
- from(Class<?>) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate theMessageChannelto the newIntegrationFlowBuilderchain, which becomes as arequestChannelfor the Messaging Gateway(s) built on the provided service interface.
- from(Class<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(Class<?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate theMessageChannelto the newIntegrationFlowBuilderchain, which becomes as arequestChannelfor the Messaging Gateway(s) built on the provided service interface.
- from(Class<?>, Consumer<GatewayProxySpec>) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate theMessageChannelto the newIntegrationFlowBuilderchain, which becomes as arequestChannelfor the Messaging Gateway(s) built on the provided service interface.
- from(Class<?>, Consumer<GatewayProxySpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- 
Start a flow from a proxy for the service interface.
- from(Class<?>, Consumer<GatewayProxySpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate theMessageChannelto the newIntegrationFlowBuilderchain, which becomes as arequestChannelfor the Messaging Gateway(s) built on the provided service interface.
- from(String) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate theMessageChannelname to the newIntegrationFlowBuilderchain.
- from(String) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(String) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate theMessageChannelname to the newIntegrationFlowBuilderchain.
- from(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set the From: address.
- from(String, boolean) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate theMessageChannelname to the newIntegrationFlowBuilderchain.
- from(String, boolean) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(String, boolean) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate theMessageChannelname to the newIntegrationFlowBuilderchain.
- from(Map<String, ?>) - Static method in class org.springframework.integration.expression.ExpressionEvalMap
- from(Publisher<? extends Message<?>>) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate aFluxMessageChannelto theIntegrationFlowBuilderchain and subscribe it to the providedPublisher.
- from(Publisher<? extends Message<?>>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(Publisher<? extends Message<?>>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate aFluxMessageChannelto theIntegrationFlowBuilderchain and subscribe it to the providedPublisher.
- from(MessageSource<?>) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate the providedMessageSourceobject to theIntegrationFlowBuilderchain.
- from(MessageSource<?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(MessageSource<?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate the providedMessageSourceobject to theIntegrationFlowBuilderchain.
- from(MessageSource<?>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate the providedMessageSourceobject to theIntegrationFlowBuilderchain.
- from(MessageSource<?>, Consumer<SourcePollingChannelAdapterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(MessageSource<?>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate the providedMessageSourceobject to theIntegrationFlowBuilderchain.
- from(IntegrationFlow) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Start the flow with a composition from theIntegrationFlow.
- from(IntegrationFlow) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Start the flow with a composition from theIntegrationFlow.
- from(MessageChannelSpec<?, ?>) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate theMessageChannelobject to theIntegrationFlowBuilderchain using the fluent API fromMessageChannelSpec.
- from(MessageChannelSpec<?, ?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(MessageChannelSpec<?, ?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate theMessageChannelobject to theIntegrationFlowBuilderchain using the fluent API fromMessageChannelSpec.
- from(MessageProducerSpec<?, ?>) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate theMessageProducerSupportobject to theIntegrationFlowBuilderchain using the fluent API from theMessageProducerSpec.
- from(MessageProducerSpec<?, ?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(MessageProducerSpec<?, ?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate theMessageProducerSupportobject to theIntegrationFlowBuilderchain using the fluent API from theMessageProducerSpec.
- from(MessageSourceSpec<?, ? extends MessageSource<?>>) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate theMessageSourceobject to theIntegrationFlowBuilderchain using the fluent API from the providedMessageSourceSpec.
- from(MessageSourceSpec<?, ? extends MessageSource<?>>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(MessageSourceSpec<?, ? extends MessageSource<?>>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate theMessageSourceobject to theIntegrationFlowBuilderchain using the fluent API from the providedMessageSourceSpec.
- from(MessageSourceSpec<?, ? extends MessageSource<?>>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate theMessageSourceobject to theIntegrationFlowBuilderchain using the fluent API from the providedMessageSourceSpec.
- from(MessageSourceSpec<?, ? extends MessageSource<?>>, Consumer<SourcePollingChannelAdapterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(MessageSourceSpec<?, ? extends MessageSource<?>>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate theMessageSourceobject to theIntegrationFlowBuilderchain using the fluent API from the providedMessageSourceSpec.
- from(MessagingGatewaySpec<?, ?>) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate theMessagingGatewaySupportobject to theIntegrationFlowBuilderchain using the fluent API from theMessagingGatewaySpec.
- from(MessagingGatewaySpec<?, ?>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(MessagingGatewaySpec<?, ?>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate theMessagingGatewaySupportobject to theIntegrationFlowBuilderchain using the fluent API from theMessagingGatewaySpec.
- from(MessageProducerSupport) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate the providedMessageProducerSupportobject to theIntegrationFlowBuilderchain.
- from(MessageProducerSupport) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(MessageProducerSupport) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate the providedMessageProducerSupportobject to theIntegrationFlowBuilderchain.
- from(MessagingGatewaySupport) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate the providedMessagingGatewaySupportobject to theIntegrationFlowBuilderchain.
- from(MessagingGatewaySupport) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(MessagingGatewaySupport) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate the providedMessagingGatewaySupportobject to theIntegrationFlowBuilderchain.
- from(MessageChannel) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
Populate the providedMessageChannelobject to theIntegrationFlowBuilderchain.
- from(MessageChannel) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- from(MessageChannel) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.Populate the providedMessageChannelobject to theIntegrationFlowBuilderchain.
- FROM - Static variable in class org.springframework.integration.mail.MailHeaders
- FROM - Static variable in class org.springframework.integration.xmpp.XmppHeaders
- fromExpression(String) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set the expression that will be evaluated to determine the From: address.
- fromFunction(Function<Message<P>, String>) - Method in class org.springframework.integration.mail.dsl.MailHeadersBuilder
- 
Set a function that will be invoked to determine the From: address based on the message.
- fromHeaders(MessageHeaders, Message) - Method in class org.springframework.integration.jms.DefaultJmsHeaderMapper
- fromHeaders(MessageHeaders, MimeMessage) - Method in class org.springframework.integration.mail.support.DefaultMailHeaderMapper
- fromHeaders(MessageHeaders, Message) - Method in class org.springframework.integration.camel.support.CamelHeaderMapper
- fromHeaders(MessageHeaders, MqttProperties) - Method in class org.springframework.integration.mqtt.support.MqttHeaderMapper
- fromHeaders(MessageHeaders, HttpHeaders) - Method in class org.springframework.integration.http.support.DefaultHttpHeaderMapper
- 
Map from the integration MessageHeaders to an HttpHeaders instance.
- fromHeaders(MessageHeaders, StompHeaders) - Method in class org.springframework.integration.stomp.support.StompHeaderMapper
- fromHeaders(MessageHeaders, T) - Method in interface org.springframework.integration.mapping.HeaderMapper
- fromHeadersToReply(MessageHeaders, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
- fromHeadersToReply(MessageHeaders, T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
- 
Map from the givenMessageHeadersto the specified reply target.
- fromHeadersToRequest(MessageHeaders, T) - Method in class org.springframework.integration.mapping.AbstractHeaderMapper
- fromHeadersToRequest(MessageHeaders, T) - Method in interface org.springframework.integration.mapping.RequestReplyHeaderMapper
- 
Map from the givenMessageHeadersto the specified request target.
- fromJson() - Static method in class org.springframework.integration.dsl.Transformers
- fromJson(JsonParser, Type) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
- fromJson(Class<?>) - Static method in class org.springframework.integration.dsl.Transformers
- fromJson(Class<?>, JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.Transformers
- fromJson(Object, JavaType) - Method in class org.springframework.integration.support.json.Jackson2JsonObjectMapper
- fromJson(Object, J) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
- fromJson(Object, Class<T>) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
- fromJson(Object, Class<T>) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
- fromJson(Object, Map<String, Object>) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
- fromJson(Object, Map<String, Object>) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
- fromJson(Object, ResolvableType) - Method in class org.springframework.integration.support.json.AbstractJacksonJsonObjectMapper
- fromJson(Object, ResolvableType) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
- 
Deserialize a JSON to an expectedResolvableType.
- fromJson(ResolvableType) - Static method in class org.springframework.integration.dsl.Transformers
- 
Construct aJsonToObjectTransformerbased on the providedResolvableType.
- fromJson(ResolvableType, JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.Transformers
- fromJson(JsonObjectMapper<?, ?>) - Static method in class org.springframework.integration.dsl.Transformers
- fromJson(P, Type) - Method in interface org.springframework.integration.support.json.JsonObjectMapper
- fromMap(Class<?>) - Static method in class org.springframework.integration.dsl.Transformers
- fromMap(String) - Static method in class org.springframework.integration.dsl.Transformers
- fromMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.MessageConvertingTcpMessageMapper
- fromMessage(Message<?>) - Method in class org.springframework.integration.ip.tcp.connection.TcpMessageMapper
- fromMessage(Message<?>) - Method in class org.springframework.integration.ip.udp.DatagramPacketMessageMapper
- 
Raw byte[] from message, possibly with a length field up front.
- fromMessage(Message<?>) - Method in class org.springframework.integration.mapping.ConvertingBytesMessageMapper
- fromMessage(Message<?>) - Method in interface org.springframework.integration.mapping.OutboundMessageMapper
- fromMessage(Message<?>) - Method in class org.springframework.integration.support.json.EmbeddedJsonHeadersMessageMapper
- fromMessage(Message<?>) - Method in class org.springframework.integration.support.json.JsonOutboundMessageMapper
- fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.codec.CodecMessageConverter
- fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.mqtt.support.DefaultPahoMessageConverter
- fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.support.converter.DefaultDatatypeChannelMessageConverter
- fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.support.converter.MapMessageConverter
- fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.support.converter.PassThruMessageConverter
- fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.support.converter.SimpleMessageConverter
- fromMessage(Message<T>) - Method in class org.springframework.integration.support.DefaultMessageBuilderFactory
- fromMessage(Message<T>) - Static method in class org.springframework.integration.support.MessageBuilder
- 
Create a builder for a newMessageinstance pre-populated with all of the headers copied from the provided message.
- fromMessage(Message<T>) - Method in interface org.springframework.integration.support.MessageBuilderFactory
- fromMessage(Message<T>) - Static method in class org.springframework.integration.support.MutableMessageBuilder
- 
Create a builder for a newMessageinstance pre-populated with all of the headers copied from the provided message.
- fromMessage(Message<T>) - Method in class org.springframework.integration.support.MutableMessageBuilderFactory
- fromSoapHeaders(MessageContext, AbstractIntegrationMessageBuilder<?>) - Method in class org.springframework.integration.ws.AbstractWebServiceInboundGateway
- fromStream() - Static method in class org.springframework.integration.dsl.Transformers
- 
The factory method for theStreamTransformer.
- fromStream(String) - Static method in class org.springframework.integration.dsl.Transformers
- 
Create an instance with the charset to convert the stream to a String; if null abyte[]will be produced instead.
- fromSupplier(Supplier<T>) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
ProvidesSupplieras source of messages to the integration flow which will be triggered by the application context's default poller (which must be declared).
- fromSupplier(Supplier<T>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- fromSupplier(Supplier<T>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.ProvidesSupplieras source of messages to the integration flow which will be triggered by the application context's default poller (which must be declared).
- fromSupplier(Supplier<T>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in interface org.springframework.integration.dsl.IntegrationFlow
- 
ProvidesSupplieras source of messages to the integration flow.
- fromSupplier(Supplier<T>, Consumer<SourcePollingChannelAdapterSpec>) - Method in class org.springframework.integration.dsl.IntegrationFlowAdapter
- fromSupplier(Supplier<T>, Consumer<SourcePollingChannelAdapterSpec>) - Static method in class org.springframework.integration.dsl.IntegrationFlows
- 
Deprecated.ProvidesSupplieras source of messages to the integration flow.
- fromSyslog(Message<?>) - Method in class org.springframework.integration.syslog.DefaultMessageConverter
- fromSyslog(Message<?>) - Method in interface org.springframework.integration.syslog.MessageConverter
- fromSyslog(Message<?>) - Method in class org.springframework.integration.syslog.RFC5424MessageConverter
- Ftp - Class in org.springframework.integration.ftp.dsl
- 
The factory for FTP components.
- FtpFileInfo - Class in org.springframework.integration.ftp.session
- 
AFileInfoimplementation for FTP/FTPS.
- FtpFileInfo(FTPFile) - Constructor for class org.springframework.integration.ftp.session.FtpFileInfo
- FtpInboundChannelAdapterParser - Class in org.springframework.integration.ftp.config
- 
Parser for the FTP 'inbound-channel-adapter' element.
- FtpInboundChannelAdapterParser() - Constructor for class org.springframework.integration.ftp.config.FtpInboundChannelAdapterParser
- FtpInboundChannelAdapterSpec - Class in org.springframework.integration.ftp.dsl
- FtpInboundChannelAdapterSpec(SessionFactory<FTPFile>, Comparator<File>) - Constructor for class org.springframework.integration.ftp.dsl.FtpInboundChannelAdapterSpec
- FtpInboundFileSynchronizer - Class in org.springframework.integration.ftp.inbound
- 
An implementation ofAbstractInboundFileSynchronizerfor FTP.
- FtpInboundFileSynchronizer(SessionFactory<FTPFile>) - Constructor for class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizer
- 
Create a synchronizer with theSessionFactoryused to acquireSessioninstances.
- FtpInboundFileSynchronizingMessageSource - Class in org.springframework.integration.ftp.inbound
- 
AMessageSourceimplementation for FTP.
- FtpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<FTPFile>) - Constructor for class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizingMessageSource
- FtpInboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<FTPFile>, Comparator<File>) - Constructor for class org.springframework.integration.ftp.inbound.FtpInboundFileSynchronizingMessageSource
- FtpMessageHandler - Class in org.springframework.integration.ftp.outbound
- 
The FTP specificFileTransferringMessageHandlerextension.
- FtpMessageHandler(SessionFactory<FTPFile>) - Constructor for class org.springframework.integration.ftp.outbound.FtpMessageHandler
- FtpMessageHandler(FtpRemoteFileTemplate) - Constructor for class org.springframework.integration.ftp.outbound.FtpMessageHandler
- FtpMessageHandler(FtpRemoteFileTemplate, FileExistsMode) - Constructor for class org.springframework.integration.ftp.outbound.FtpMessageHandler
- 
Constructor which sets the FtpRemoteFileTemplate and FileExistsMode.
- FtpMessageHandlerSpec - Class in org.springframework.integration.ftp.dsl
- 
AFileTransferringMessageHandlerSpecfor FTP.
- FtpMessageHandlerSpec(SessionFactory<FTPFile>) - Constructor for class org.springframework.integration.ftp.dsl.FtpMessageHandlerSpec
- FtpMessageHandlerSpec(FtpRemoteFileTemplate) - Constructor for class org.springframework.integration.ftp.dsl.FtpMessageHandlerSpec
- FtpMessageHandlerSpec(FtpRemoteFileTemplate, FileExistsMode) - Constructor for class org.springframework.integration.ftp.dsl.FtpMessageHandlerSpec
- FtpNamespaceHandler - Class in org.springframework.integration.ftp.config
- 
Provides namespace support for using FTP
- FtpNamespaceHandler() - Constructor for class org.springframework.integration.ftp.config.FtpNamespaceHandler
- FtpOutboundChannelAdapterParser - Class in org.springframework.integration.ftp.config
- 
Parser for FTP Outbound Channel Adapters.
- FtpOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.ftp.config.FtpOutboundChannelAdapterParser
- FtpOutboundGateway - Class in org.springframework.integration.ftp.gateway
- 
Outbound Gateway for performing remote file operations via FTP/FTPS.
- FtpOutboundGateway(RemoteFileTemplate<FTPFile>, String) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- 
Construct an instance with the supplied remote file template and command ('ls', 'nlst', 'put' or 'mput').
- FtpOutboundGateway(RemoteFileTemplate<FTPFile>, String, String) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- 
Construct an instance with the supplied remote file template, a command ('ls', 'get' etc), and an expression to determine the filename.
- FtpOutboundGateway(RemoteFileTemplate<FTPFile>, MessageSessionCallback<FTPFile, ?>) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- 
Construct an instance with the supplied remote file template and callback for performing operations on the session.
- FtpOutboundGateway(SessionFactory<FTPFile>, String) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- 
Construct an instance with the supplied session factory and command ('ls', 'nlst', 'put' or 'mput').
- FtpOutboundGateway(SessionFactory<FTPFile>, String, String) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- 
Construct an instance with the supplied session factory, a command ('ls', 'get' etc), and an expression to determine the filename.
- FtpOutboundGateway(SessionFactory<FTPFile>, MessageSessionCallback<FTPFile, ?>) - Constructor for class org.springframework.integration.ftp.gateway.FtpOutboundGateway
- 
Construct an instance using the provided session factory and callback for performing operations on the session.
- FtpOutboundGatewayParser - Class in org.springframework.integration.ftp.config
- FtpOutboundGatewayParser() - Constructor for class org.springframework.integration.ftp.config.FtpOutboundGatewayParser
- FtpOutboundGatewaySpec - Class in org.springframework.integration.ftp.dsl
- 
ARemoteFileOutboundGatewaySpecfor FTP.
- FtpOutboundGatewaySpec(FtpOutboundGateway) - Constructor for class org.springframework.integration.ftp.dsl.FtpOutboundGatewaySpec
- FtpPersistentAcceptOnceFileListFilter - Class in org.springframework.integration.ftp.filters
- 
Persistent file list filter using the server's file timestamp to detect if we've already 'seen' this file.
- FtpPersistentAcceptOnceFileListFilter(ConcurrentMetadataStore, String) - Constructor for class org.springframework.integration.ftp.filters.FtpPersistentAcceptOnceFileListFilter
- FtpRegexPatternFileListFilter - Class in org.springframework.integration.ftp.filters
- 
Implementation ofAbstractRegexPatternFileListFilterfor FTP.
- FtpRegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.ftp.filters.FtpRegexPatternFileListFilter
- FtpRegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.ftp.filters.FtpRegexPatternFileListFilter
- FtpRemoteFileTemplate - Class in org.springframework.integration.ftp.session
- 
FTP version ofRemoteFileTemplateproviding type-safe access to the underlying FTPClient object.
- FtpRemoteFileTemplate(SessionFactory<FTPFile>) - Constructor for class org.springframework.integration.ftp.session.FtpRemoteFileTemplate
- FtpRemoteFileTemplate.ExistsMode - Enum Class in org.springframework.integration.ftp.session
- 
TheFtpRemoteFileTemplate.exists(String)operation mode.
- FtpRequestEvent - Class in org.springframework.integration.ftp.server
- 
Base class for all events having anFtpRequest.
- FtpRequestEvent(FtpSession, FtpRequest) - Constructor for class org.springframework.integration.ftp.server.FtpRequestEvent
- FtpSession - Class in org.springframework.integration.ftp.session
- 
Implementation ofSessionfor FTP.
- FtpSession(FTPClient) - Constructor for class org.springframework.integration.ftp.session.FtpSession
- FtpSimplePatternFileListFilter - Class in org.springframework.integration.ftp.filters
- 
Implementation ofAbstractSimplePatternFileListFilterfor FTP.
- FtpSimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.ftp.filters.FtpSimplePatternFileListFilter
- FtpStreamingInboundChannelAdapterParser - Class in org.springframework.integration.ftp.config
- FtpStreamingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.ftp.config.FtpStreamingInboundChannelAdapterParser
- FtpStreamingInboundChannelAdapterSpec - Class in org.springframework.integration.ftp.dsl
- FtpStreamingInboundChannelAdapterSpec(RemoteFileTemplate<FTPFile>, Comparator<FTPFile>) - Constructor for class org.springframework.integration.ftp.dsl.FtpStreamingInboundChannelAdapterSpec
- FtpStreamingMessageSource - Class in org.springframework.integration.ftp.inbound
- 
Message source for streaming FTP remote file contents.
- FtpStreamingMessageSource(RemoteFileTemplate<FTPFile>) - Constructor for class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
- 
Construct an instance with the supplied template.
- FtpStreamingMessageSource(RemoteFileTemplate<FTPFile>, Comparator<FTPFile>) - Constructor for class org.springframework.integration.ftp.inbound.FtpStreamingMessageSource
- 
Construct an instance with the supplied template and comparator.
- FtpSystemMarkerFilePresentFileListFilter - Class in org.springframework.integration.ftp.filters
- 
FTP implementation ofAbstractMarkerFilePresentFileListFilter.
- FtpSystemMarkerFilePresentFileListFilter(Map<FileListFilter<FTPFile>, Function<String, String>>) - Constructor for class org.springframework.integration.ftp.filters.FtpSystemMarkerFilePresentFileListFilter
- FtpSystemMarkerFilePresentFileListFilter(FileListFilter<FTPFile>) - Constructor for class org.springframework.integration.ftp.filters.FtpSystemMarkerFilePresentFileListFilter
- FtpSystemMarkerFilePresentFileListFilter(FileListFilter<FTPFile>, String) - Constructor for class org.springframework.integration.ftp.filters.FtpSystemMarkerFilePresentFileListFilter
- FtpSystemMarkerFilePresentFileListFilter(FileListFilter<FTPFile>, Function<String, String>) - Constructor for class org.springframework.integration.ftp.filters.FtpSystemMarkerFilePresentFileListFilter
- FUNCTION_APPLY_METHOD - Static variable in class org.springframework.integration.util.ClassUtils
- 
TheFunction.apply(Object)method object.
- FunctionExpression<S> - Class in org.springframework.integration.expression
- FunctionExpression(Function<S, ?>) - Constructor for class org.springframework.integration.expression.FunctionExpression
- FunctionIterator<T,V> - Class in org.springframework.integration.util 
- 
AnIteratorimplementation to convert each item from the targetFunctionIterator.iteratorto a new object applying theFunctionIterator.functiononFunctionIterator.next().
- FunctionIterator(AutoCloseable, Iterable<T>, Function<? super T, ? extends V>) - Constructor for class org.springframework.integration.util.FunctionIterator
- 
Construct an instance with the provided root object, iterable and function.
- FunctionIterator(AutoCloseable, Iterator<T>, Function<? super T, ? extends V>) - Constructor for class org.springframework.integration.util.FunctionIterator
- 
Construct an instance with the provided root object, iterator and function.
- FunctionIterator(Iterable<T>, Function<? super T, ? extends V>) - Constructor for class org.springframework.integration.util.FunctionIterator
- 
Construct an instance with the provided iterable and function.
- FunctionIterator(Iterator<T>, Function<? super T, ? extends V>) - Constructor for class org.springframework.integration.util.FunctionIterator
- 
Construct an instance with the provided iterator and function.
- FUTURE_TOKEN - Static variable in class org.springframework.integration.kafka.support.KafkaIntegrationHeaders
- 
Set to a token to correlate a send Future.
- futuresChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
- 
Set the channel to which send futures are sent.
- futuresChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
- 
Set the channel to which send futures are sent.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
Pollers.fixedDelay(Duration)