| Package | Description | 
|---|---|
| org.apache.hadoop.fs | Implementations of  AbstractFileSystemfor hdfs
    over rpc and hdfs over web. | 
| org.apache.hadoop.fs.adl | Supporting classes for metrics instrumentation. | 
| org.apache.hadoop.fs.azure | 
A distributed implementation of  FileSystemfor reading and writing files on
Azure Block Storage. | 
| org.apache.hadoop.fs.ftp | |
| org.apache.hadoop.fs.impl | This package contains implementation classes for use inside
 filesystems. | 
| org.apache.hadoop.fs.s3native | 
A distributed implementation of  FileSystemfor reading and writing files on
Amazon S3. | 
| org.apache.hadoop.fs.viewfs | ViewFileSystem and ViewFileSystemOverloadScheme classes. | 
| org.apache.hadoop.hdfs.server.namenode | |
| org.apache.hadoop.io | Generic i/o code for use when reading and writing data to the network,
to databases, and to files. | 
| org.apache.hadoop.io.wrappedio | Support for dynamic access to filesystem operations which are not available
 in older hadoop releases. | 
| org.apache.hadoop.mapred | |
| org.apache.hadoop.mapred.lib | |
| org.apache.hadoop.mapred.lib.db | |
| org.apache.hadoop.mapreduce | |
| org.apache.hadoop.mapreduce.lib.input | |
| org.apache.hadoop.mapreduce.lib.output.committer.manifest.files | Persistence formats. | 
| org.apache.hadoop.metrics2.sink | Builtin metrics sinks | 
| org.apache.hadoop.yarn.logaggregation.filecontroller | Licensed to the Apache Software Foundation (ASF) under one
 or more contributor license agreements. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ChecksumFileSystemAbstract Checksumed FileSystem. | 
| class  | FilterFileSystemA  FilterFileSystemcontains
 some other file system, which it uses as
 its  basic file system, possibly transforming
 the data along the way or providing  additional
 functionality. | 
| class  | LocalFileSystemImplement the FileSystem API for the checksumed local filesystem. | 
| class  | RawLocalFileSystemImplement the FileSystem API for the raw local filesystem. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected FileSystem | TrashPolicy. fs | 
| protected FileSystem | FilterFileSystem. fs | 
| Modifier and Type | Method and Description | 
|---|---|
| static FileSystem | FileSystem. get(Configuration conf)Returns the configured FileSystem implementation. | 
| static FileSystem | FileSystem. get(URI uri,
   Configuration conf)Get a FileSystem for this URI's scheme and authority. | 
| static FileSystem | FileSystem. get(URI uri,
   Configuration conf,
   String user)Get a FileSystem instance based on the uri, the passed in
 configuration and the user. | 
| FileSystem[] | FilterFileSystem. getChildFileSystems() | 
| FileSystem | Path. getFileSystem(Configuration conf)Return the FileSystem that owns this Path. | 
| protected FileSystem | FSDataOutputStreamBuilder. getFS() | 
| protected static FileSystem | FileSystem. getFSofPath(Path absOrFqPath,
           Configuration conf) | 
| static FileSystem | FileSystem. getNamed(String name,
        Configuration conf)Deprecated. 
 call  get(URI, Configuration)instead. | 
| FileSystem | LocalFileSystem. getRaw() | 
| FileSystem | ChecksumFileSystem. getRawFileSystem()get the raw file system | 
| FileSystem | FilterFileSystem. getRawFileSystem()Get the raw file system | 
| static FileSystem | FileSystem. newInstance(Configuration conf)Returns a unique configured FileSystem implementation for the default
 filesystem of the supplied configuration. | 
| static FileSystem | FileSystem. newInstance(URI uri,
           Configuration config)Returns the FileSystem for this URI's scheme and authority. | 
| static FileSystem | FileSystem. newInstance(URI uri,
           Configuration conf,
           String user)Returns the FileSystem for this URI's scheme and authority and the
 given user. | 
| static FileSystem | FileUtil. write(FileSystem fs,
     Path path,
     byte[] bytes)Writes bytes to a file. | 
| static FileSystem | FileUtil. write(FileSystem fs,
     Path path,
     CharSequence charseq)Write a line of text to a file. | 
| static FileSystem | FileUtil. write(FileSystem fs,
     Path path,
     CharSequence charseq,
     Charset cs)Write a line of text to a file. | 
| static FileSystem | FileUtil. write(FileSystem fs,
     Path path,
     Iterable<? extends CharSequence> lines,
     Charset cs)Write lines of text to a file. | 
| Modifier and Type | Method and Description | 
|---|---|
| static Class<? extends FileSystem> | FileSystem. getFileSystemClass(String scheme,
                  Configuration conf)Get the FileSystem implementation class of a filesystem. | 
| Modifier and Type | Method and Description | 
|---|---|
| static boolean | FileUtil. checkFSSupportsEC(FileSystem fs,
                 Path path)Return true if the FS implements  WithErasureCodingand
 supports EC_POLICY option inOptions.OpenFileOptions. | 
| static boolean | FileUtil. compareFs(FileSystem srcFs,
         FileSystem destFs) | 
| static boolean | FileUtil. copy(File src,
    FileSystem dstFS,
    Path dst,
    boolean deleteSource,
    Configuration conf)Copy local files to a FileSystem. | 
| static boolean | FileUtil. copy(FileSystem srcFS,
    FileStatus srcStatus,
    FileSystem dstFS,
    Path dst,
    boolean deleteSource,
    boolean overwrite,
    Configuration conf)Copy a file/directory tree within/between filesystems. | 
| static boolean | FileUtil. copy(FileSystem srcFS,
    Path[] srcs,
    FileSystem dstFS,
    Path dst,
    boolean deleteSource,
    boolean overwrite,
    Configuration conf) | 
| static boolean | FileUtil. copy(FileSystem srcFS,
    Path src,
    File dst,
    boolean deleteSource,
    Configuration conf)Copy FileSystem files to local files. | 
| static boolean | FileUtil. copy(FileSystem srcFS,
    Path src,
    FileSystem dstFS,
    Path dst,
    boolean deleteSource,
    boolean overwrite,
    Configuration conf)Copy files between FileSystems. | 
| static boolean | FileUtil. copy(FileSystem srcFS,
    Path src,
    FileSystem dstFS,
    Path dst,
    boolean deleteSource,
    Configuration conf)Copy files between FileSystems. | 
| static FSDataOutputStream | FileSystem. create(FileSystem fs,
      Path file,
      FsPermission permission)Create a file with the provided permission. | 
| protected static FSDataOutputStreamBuilder | FileSystem. createDataOutputStreamBuilder(FileSystem fileSystem,
                             Path path)Create instance of the standard FSDataOutputStreamBuilder for the
 given filesystem and path. | 
| static void | FileUtil. fullyDelete(FileSystem fs,
           Path dir)Deprecated. 
 | 
| static TrashPolicy | TrashPolicy. getInstance(Configuration conf,
           FileSystem fs)Get an instance of the configured TrashPolicy based on the value
 of the configuration parameter fs.trash.classname. | 
| static TrashPolicy | TrashPolicy. getInstance(Configuration conf,
           FileSystem fs,
           Path home)Deprecated. 
 Use  TrashPolicy.getInstance(Configuration, FileSystem)instead. | 
| void | TrashPolicy. initialize(Configuration conf,
          FileSystem fs)Used to setup the trash policy. | 
| abstract void | TrashPolicy. initialize(Configuration conf,
          FileSystem fs,
          Path home)Deprecated. 
 Use  TrashPolicy.initialize(Configuration, FileSystem)instead. | 
| Path | Path. makeQualified(FileSystem fs)Deprecated. 
 | 
| static void | FileUtil. maybeIgnoreMissingDirectory(FileSystem fs,
                           Path path,
                           FileNotFoundException e)Method to call after a FNFE has been raised on a treewalk, so as to
 decide whether to throw the exception (default), or, if the FS
 supports inconsistent directory listings, to log and ignore it. | 
| static boolean | FileSystem. mkdirs(FileSystem fs,
      Path dir,
      FsPermission permission)Create a directory with the provided permission. | 
| static boolean | Trash. moveToAppropriateTrash(FileSystem fs,
                      Path p,
                      Configuration conf)In case of the symlinks or mount points, one has to move the appropriate
 trashbin in the actual volume of the path p being deleted. | 
| static FileSystem | FileUtil. write(FileSystem fs,
     Path path,
     byte[] bytes)Writes bytes to a file. | 
| static FileSystem | FileUtil. write(FileSystem fs,
     Path path,
     CharSequence charseq)Write a line of text to a file. | 
| static FileSystem | FileUtil. write(FileSystem fs,
     Path path,
     CharSequence charseq,
     Charset cs)Write a line of text to a file. | 
| static FileSystem | FileUtil. write(FileSystem fs,
     Path path,
     Iterable<? extends CharSequence> lines,
     Charset cs)Write lines of text to a file. | 
| Modifier and Type | Method and Description | 
|---|---|
| static org.apache.hadoop.fs.FileSystem.Statistics | FileSystem. getStatistics(String scheme,
             Class<? extends FileSystem> cls)Deprecated. 
 | 
| Constructor and Description | 
|---|
| ChecksumFileSystem(FileSystem fs) | 
| FilterFileSystem(FileSystem fs) | 
| FSDataOutputStreamBuilder(FileSystem fileSystem,
                         Path p)Constructor. | 
| LocalFileSystem(FileSystem rawLocalFileSystem) | 
| Trash(FileSystem fs,
     Configuration conf)Construct a trash can accessor for the FileSystem provided. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AdlFileSystemA FileSystem to access Azure Data Lake Store. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | NativeAzureFileSystemA  FileSystemfor reading and writing files stored on Windows Azure. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | WasbFsck. setMockFileSystemForTesting(FileSystem fileSystem)For testing purposes, set the file system to use here instead of relying on
 getting it from the FileSystem class based on the URI. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FTPFileSystem
 A  FileSystembacked by an FTP client provided by Apache Commons Net. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected FileSystem | MultipartUploaderBuilderImpl. getFS() | 
| protected FileSystem | FutureDataInputStreamBuilderImpl. getFS() | 
| Constructor and Description | 
|---|
| FutureDataInputStreamBuilderImpl(FileSystem fileSystem,
                                Path path)Constructor. | 
| FutureDataInputStreamBuilderImpl(FileSystem fileSystem,
                                PathHandle pathHandle)Constructor with PathHandle. | 
| MultipartUploaderBuilderImpl(FileSystem fileSystem,
                            Path p)Constructor. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | NativeS3FileSystemDeprecated. 
 Replaced by the S3A client. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ViewFileSystemViewFileSystem (extends the FileSystem interface) implements a client-side
 mount table. | 
| Modifier and Type | Method and Description | 
|---|---|
| FileSystem[] | ViewFileSystem. getChildFileSystems() | 
| Modifier and Type | Method and Description | 
|---|---|
| static Map<org.apache.hadoop.fs.viewfs.ViewFileSystem.MountPoint,FsStatus> | ViewFileSystemUtil. getStatus(FileSystem fileSystem,
         Path path)Get FsStatus for all ViewFsMountPoints matching path for the given
 ViewFileSystem. | 
| static boolean | ViewFileSystemUtil. isViewFileSystem(FileSystem fileSystem)Check if the FileSystem is a ViewFileSystem. | 
| static boolean | ViewFileSystemUtil. isViewFileSystemOverloadScheme(FileSystem fileSystem)Check if the FileSystem is a ViewFileSystemOverloadScheme. | 
| Constructor and Description | 
|---|
| TreePath(FileStatus stat,
        long parentId,
        org.apache.hadoop.hdfs.server.namenode.TreeWalk.TreeIterator i,
        FileSystem fs,
        AclStatus acls) | 
| Modifier and Type | Method and Description | 
|---|---|
| static org.apache.hadoop.io.SequenceFile.Writer | SequenceFile. createWriter(FileSystem fs,
            Configuration conf,
            Path name,
            Class keyClass,
            Class valClass)Deprecated. 
 | 
| static org.apache.hadoop.io.SequenceFile.Writer | SequenceFile. createWriter(FileSystem fs,
            Configuration conf,
            Path name,
            Class keyClass,
            Class valClass,
            int bufferSize,
            short replication,
            long blockSize,
            boolean createParent,
            org.apache.hadoop.io.SequenceFile.CompressionType compressionType,
            CompressionCodec codec,
            org.apache.hadoop.io.SequenceFile.Metadata metadata)Deprecated.  | 
| static org.apache.hadoop.io.SequenceFile.Writer | SequenceFile. createWriter(FileSystem fs,
            Configuration conf,
            Path name,
            Class keyClass,
            Class valClass,
            int bufferSize,
            short replication,
            long blockSize,
            org.apache.hadoop.io.SequenceFile.CompressionType compressionType,
            CompressionCodec codec,
            Progressable progress,
            org.apache.hadoop.io.SequenceFile.Metadata metadata)Deprecated. 
 | 
| static org.apache.hadoop.io.SequenceFile.Writer | SequenceFile. createWriter(FileSystem fs,
            Configuration conf,
            Path name,
            Class keyClass,
            Class valClass,
            org.apache.hadoop.io.SequenceFile.CompressionType compressionType)Deprecated. 
 | 
| static org.apache.hadoop.io.SequenceFile.Writer | SequenceFile. createWriter(FileSystem fs,
            Configuration conf,
            Path name,
            Class keyClass,
            Class valClass,
            org.apache.hadoop.io.SequenceFile.CompressionType compressionType,
            CompressionCodec codec)Deprecated. 
 | 
| static org.apache.hadoop.io.SequenceFile.Writer | SequenceFile. createWriter(FileSystem fs,
            Configuration conf,
            Path name,
            Class keyClass,
            Class valClass,
            org.apache.hadoop.io.SequenceFile.CompressionType compressionType,
            CompressionCodec codec,
            Progressable progress)Deprecated. 
 | 
| static org.apache.hadoop.io.SequenceFile.Writer | SequenceFile. createWriter(FileSystem fs,
            Configuration conf,
            Path name,
            Class keyClass,
            Class valClass,
            org.apache.hadoop.io.SequenceFile.CompressionType compressionType,
            CompressionCodec codec,
            Progressable progress,
            org.apache.hadoop.io.SequenceFile.Metadata metadata)Deprecated. 
 | 
| static org.apache.hadoop.io.SequenceFile.Writer | SequenceFile. createWriter(FileSystem fs,
            Configuration conf,
            Path name,
            Class keyClass,
            Class valClass,
            org.apache.hadoop.io.SequenceFile.CompressionType compressionType,
            Progressable progress)Deprecated. 
 | 
| static void | MapFile. delete(FileSystem fs,
      String name)Deletes the named map file. | 
| static void | BloomMapFile. delete(FileSystem fs,
      String name) | 
| static long | MapFile. fix(FileSystem fs,
   Path dir,
   Class<? extends Writable> keyClass,
   Class<? extends Writable> valueClass,
   boolean dryrun,
   Configuration conf)This method attempts to fix a corrupt MapFile by re-creating its index. | 
| static void | MapFile. rename(FileSystem fs,
      String oldName,
      String newName)Renames an existing map directory. | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<Map.Entry<Path,String>> | WrappedIO. bulkDelete_delete(FileSystem fs,
                 Path base,
                 Collection<Path> paths)Delete a list of files/objects. | 
| static int | WrappedIO. bulkDelete_pageSize(FileSystem fs,
                   Path path)Get the maximum number of objects/files to delete in a single request. | 
| static Path | WrappedIO. fileSystem_getEnclosingRoot(FileSystem fs,
                           Path path)Return path of the enclosing root for a given path. | 
| static FSDataInputStream | WrappedIO. fileSystem_openFile(FileSystem fs,
                   Path path,
                   String policy,
                   FileStatus status,
                   Long length,
                   Map<String,String> options)OpenFile assistant, easy reflection-based access to
  openFile(Path)and blocks
 awaiting the operation completion. | 
| static Serializable | WrappedStatistics. iostatisticsSnapshot_load(FileSystem fs,
                         Path path)Load IOStatisticsSnapshot from a Hadoop filesystem. | 
| static void | WrappedStatistics. iostatisticsSnapshot_save(Serializable snapshot,
                         FileSystem fs,
                         Path path,
                         boolean overwrite)Save IOStatisticsSnapshot to a Hadoop filesystem as a JSON file. | 
| Modifier and Type | Method and Description | 
|---|---|
| FileSystem | JobClient. getFs()Get a filesystem handle. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | FileInputFormat. addInputPathRecursively(List<FileStatus> result,
                       FileSystem fs,
                       Path path,
                       PathFilter inputFilter)Add files in the input path recursively into the results. | 
| void | FileOutputFormat. checkOutputSpecs(FileSystem ignored,
                JobConf job) | 
| void | OutputFormat. checkOutputSpecs(FileSystem ignored,
                JobConf job)Check for validity of the output-specification for the job. | 
| void | SequenceFileAsBinaryOutputFormat. checkOutputSpecs(FileSystem ignored,
                JobConf job) | 
| static org.apache.hadoop.io.MapFile.Reader[] | MapFileOutputFormat. getReaders(FileSystem ignored,
          Path dir,
          Configuration conf)Open the output generated by this format. | 
| RecordWriter<K,V> | TextOutputFormat. getRecordWriter(FileSystem ignored,
               JobConf job,
               String name,
               Progressable progress) | 
| RecordWriter<K,V> | SequenceFileOutputFormat. getRecordWriter(FileSystem ignored,
               JobConf job,
               String name,
               Progressable progress) | 
| abstract RecordWriter<K,V> | FileOutputFormat. getRecordWriter(FileSystem ignored,
               JobConf job,
               String name,
               Progressable progress) | 
| RecordWriter<K,V> | OutputFormat. getRecordWriter(FileSystem ignored,
               JobConf job,
               String name,
               Progressable progress)Get the  RecordWriterfor the given job. | 
| RecordWriter<BytesWritable,BytesWritable> | SequenceFileAsBinaryOutputFormat. getRecordWriter(FileSystem ignored,
               JobConf job,
               String name,
               Progressable progress) | 
| RecordWriter<WritableComparable,Writable> | MapFileOutputFormat. getRecordWriter(FileSystem ignored,
               JobConf job,
               String name,
               Progressable progress) | 
| static boolean | JobClient. isJobDirValid(Path jobDirPath,
             FileSystem fs)Checks if the job directory is clean and has all the required components
 for (re) starting the job | 
| protected boolean | FixedLengthInputFormat. isSplitable(FileSystem fs,
           Path file) | 
| protected boolean | TextInputFormat. isSplitable(FileSystem fs,
           Path file) | 
| protected boolean | FileInputFormat. isSplitable(FileSystem fs,
           Path filename)Is the given filename splittable? Usually, true, but if the file is
 stream compressed, it will not be. | 
| protected boolean | KeyValueTextInputFormat. isSplitable(FileSystem fs,
           Path file) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FilterOutputFormat. checkOutputSpecs(FileSystem ignored,
                JobConf job) | 
| void | NullOutputFormat. checkOutputSpecs(FileSystem ignored,
                JobConf job) | 
| void | LazyOutputFormat. checkOutputSpecs(FileSystem ignored,
                JobConf job) | 
| protected RecordWriter<K,V> | MultipleTextOutputFormat. getBaseRecordWriter(FileSystem fs,
                   JobConf job,
                   String name,
                   Progressable arg3) | 
| protected abstract RecordWriter<K,V> | MultipleOutputFormat. getBaseRecordWriter(FileSystem fs,
                   JobConf job,
                   String name,
                   Progressable arg3) | 
| protected RecordWriter<K,V> | MultipleSequenceFileOutputFormat. getBaseRecordWriter(FileSystem fs,
                   JobConf job,
                   String name,
                   Progressable arg3) | 
| RecordWriter<K,V> | FilterOutputFormat. getRecordWriter(FileSystem ignored,
               JobConf job,
               String name,
               Progressable progress) | 
| RecordWriter<K,V> | MultipleOutputFormat. getRecordWriter(FileSystem fs,
               JobConf job,
               String name,
               Progressable arg3)Create a composite record writer that can write key/value data to different
 output files | 
| RecordWriter<K,V> | NullOutputFormat. getRecordWriter(FileSystem ignored,
               JobConf job,
               String name,
               Progressable progress) | 
| RecordWriter<K,V> | LazyOutputFormat. getRecordWriter(FileSystem ignored,
               JobConf job,
               String name,
               Progressable progress) | 
| protected boolean | CombineFileInputFormat. isSplitable(FileSystem fs,
           Path file) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DBOutputFormat. checkOutputSpecs(FileSystem filesystem,
                JobConf job)Check for validity of the output-specification for the job. | 
| RecordWriter<K,V> | DBOutputFormat. getRecordWriter(FileSystem filesystem,
               JobConf job,
               String name,
               Progressable progress)Get the  RecordWriterfor the given job. | 
| Modifier and Type | Method and Description | 
|---|---|
| FileSystem | Cluster. getFileSystem()Get the file system where job-specific files are stored | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | Job. addArchiveToClassPath(Path archive,
                     Configuration conf,
                     FileSystem fs)Add an archive path to the current set of classpath entries. | 
| static void | Job. addFileToClassPath(Path file,
                  Configuration conf,
                  FileSystem fs)Add a file path to the current set of classpath entries. | 
| static void | Job. addFileToClassPath(Path file,
                  Configuration conf,
                  FileSystem fs,
                  boolean addToCache)Add a file path to the current set of classpath entries. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | FileInputFormat. addInputPathRecursively(List<FileStatus> result,
                       FileSystem fs,
                       Path path,
                       PathFilter inputFilter)Add files in the input path recursively into the results. | 
| protected BlockLocation[] | CombineFileInputFormat. getFileBlockLocations(FileSystem fs,
                     FileStatus stat) | 
| Modifier and Type | Method and Description | 
|---|---|
| static ManifestSuccessData | ManifestSuccessData. load(FileSystem fs,
    Path path)Load an instance from a file, then validate it. | 
| void | ManifestSuccessData. save(FileSystem fs,
    Path path,
    boolean overwrite) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected static FileSystem | RollingFileSystemSink. suppliedFilesystem | 
| Modifier and Type | Method and Description | 
|---|---|
| protected FileSystem | LogAggregationFileController. getFileSystem(Configuration conf) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected boolean | LogAggregationFileController. checkExists(FileSystem fs,
           Path path,
           FsPermission fsPerm) | 
| protected void | LogAggregationFileController. createDir(FileSystem fs,
         Path path,
         FsPermission fsPerm) | 
Copyright © 2025 Apache Software Foundation. All rights reserved.