Package org.apache.flink.core.fs
-
Interface Summary Interface Description BlockLocation A BlockLocation lists hosts, offset and length of block.ByteBufferReadable An interface mark that a filesystem supports to read bytes from aByteBuffer
and its given position.EntropyInjectingFileSystem An interface to be implemented by aFileSystem
that is aware of entropy injection.FileStatus Interface that represents the client side information for a file independent of the file system.FileSystemFactory A factory to create file systems.ICloseableRegistry This class allows to register instances ofCloseable
, which are all closed if this registry is closed.IFileSystem Interface of all file systems used by Flink.LocatedFileStatus ALocatedFileStatus
is aFileStatus
that contains additionally the location information of the file directly.PathsCopyingFileSystem An interface marking that givenFileSystem
have an optimised path for copying paths instead of usingFSDataOutputStream
orFSDataInputStream
.PathsCopyingFileSystem.CopyRequest A pair of source and destination to duplicate a file.RecoverableFsDataOutputStream.Committer A committer can publish the file of a stream that was closed.RecoverableWriter The RecoverableWriter creates and recoversRecoverableFsDataOutputStream
.RecoverableWriter.CommitRecoverable A handle to an in-progress stream with a defined and persistent amount of data.RecoverableWriter.ResumeRecoverable A handle to an in-progress stream with a defined and persistent amount of data.WrappingProxyCloseable<T extends Closeable> WrappingProxy
forCloseable
that is also closeable. -
Class Summary Class Description AutoCloseableRegistry This class allows to register instances ofAutoCloseable
, which are all closed if this registry is closed.BackPressuringExecutor An executor decorator that allows only a certain number of concurrent executions.ByteBufferReadableClosingFSDataInputStream AClosingFSDataInputStream
which isByteBufferReadable
.CloseableRegistry ICloseableRegistry
implementation.ClosingFSDataInputStream This class is aWrappingProxy
forFSDataInputStream
that is used to implement a safety net against unclosed streams.ClosingFSDataOutputStream This class is aWrappingProxy
forFSDataOutputStream
that is used to implement a safety net against unclosed streams.CommitterFromPersistRecoverableFsDataOutputStream<RESUME_RECOVERABLE extends RecoverableWriter.ResumeRecoverable> RecoverableFsDataOutputStream
with fixed implementation ofCommitterFromPersistRecoverableFsDataOutputStream.closeForCommit()
that is based on usingCommitterFromPersistRecoverableFsDataOutputStream.persist()
to ensure durability and creates theRecoverableFsDataOutputStream.Committer
from the correspondingRecoverableWriter.ResumeRecoverable
.ConnectionLimitingFactory A wrapping factory that adds aLimitedConnectionsFileSystem
to a file system.EntropyInjector This class offers utilities for entropy injection for FileSystems that implementEntropyInjectingFileSystem
.FileInputSplit A file input split provides information on a particular part of a file, possibly hosted on a distributed file system and replicated among several hosts.FileSystem Abstract base class of all file systems used by Flink.FileSystem.FSKey An identifier of a file system, via its scheme and its authority.FileSystemSafetyNet The FileSystemSafetyNet can be used to guard a thread againstFileSystem
stream resource leaks.FSDataInputStream Interface for a data input stream to a file on aFileSystem
.FSDataInputStreamWrapper Simple forwarding wrapper aroundFSDataInputStream
.FSDataOutputStream An output stream to a file that is created via aFileSystem
.FSDataOutputStreamWrapper Simple forwarding wrapper aroundFSDataInputStream
.LimitedConnectionsFileSystem A file system that limits the number of concurrently open input streams, output streams, and total streams for a target file system.LimitedConnectionsFileSystem.ConnectionLimitingSettings A simple configuration data object capturing the settings for limited connections.OffsetAwareOutputStream AnOutputStream
that keeps track of its current length.OutputStreamAndPath An output stream and a path.Path Names a file or directory in aFileSystem
.PluginFileSystemFactory A wrapper aroundFileSystemFactory
that ensures the plugin classloader is used for allFileSystem
operations.RecoverableFsDataOutputStream An output stream to a file system that can be recovered at well defined points.RefCountedBufferingFileStream ARefCountedFileWithStream
that also uses an in-memory buffer for buffering small writes.RefCountedFile A reference counted file which is deleted as soon as no caller holds a reference to the wrappedFile
.RefCountedFileWithStream A reference counted file which is deleted as soon as no caller holds a reference to the wrappedFile
.RefCountedFSOutputStream AFSDataOutputStream
with theRefCounted
functionality.RefCountedTmpFileCreator A utility class that creates localreference counted files
that serve as temporary files.SafetyNetCloseableRegistry This implementation of anAbstractAutoCloseableRegistry
registersWrappingProxyCloseable
.SafetyNetWrapperFileSystem This is aWrappingProxy
aroundFileSystem
which (i) wraps all opened streams asClosingFSDataInputStream
orClosingFSDataOutputStream
and (ii) registers them to aSafetyNetCloseableRegistry
. -
Enum Summary Enum Description FileSystem.WriteMode The possible write modes.FileSystemKind An enumeration defining the kind and characteristics of aFileSystem
. -
Exception Summary Exception Description LimitedConnectionsFileSystem.StreamTimeoutException A special IOException, indicating a timeout in the data output stream.UnsupportedFileSystemSchemeException An exception to indicate that a specific file system scheme is not supported.