| Package | Description | 
|---|---|
| org.apache.hadoop.filecache | |
| 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.azurebfs | 
A distributed implementation of  FileSystemfor reading and writing files on
Azure 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.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.mapreduce.lib.input | |
| org.apache.hadoop.mapreduce.v2.hs | |
| org.apache.hadoop.yarn.logaggregation.filecontroller | Licensed to the Apache Software Foundation (ASF) under one
 or more contributor license agreements. | 
| Modifier and Type | Method and Description | 
|---|---|
| static FileStatus | DistributedCache. getFileStatus(Configuration conf,
             URI cache)Deprecated.  | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PartialListing<T extends FileStatus>A partial listing of the children of a parent directory. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | LocatedFileStatusThis class defines a FileStatus that includes a file's block locations. | 
| Modifier and Type | Method and Description | 
|---|---|
| FileStatus | FileSystem. getFileLinkStatus(Path f) | 
| FileStatus | AbstractFileSystem. getFileLinkStatus(Path f)The specification of this method matches that of
  FileContext.getFileLinkStatus(Path)except that an UnresolvedLinkException may be thrown if a symlink is  
 encountered in the path leading up to the final path component. | 
| FileStatus | FilterFileSystem. getFileLinkStatus(Path f) | 
| FileStatus | RawLocalFileSystem. getFileLinkStatus(Path f)Return a FileStatus representing the given path. | 
| FileStatus | LocalFileSystem. getFileLinkStatus(Path f) | 
| FileStatus | FileContext. getFileLinkStatus(Path f)Return a file status object that represents the path. | 
| abstract FileStatus | FileSystem. getFileStatus(Path f)Return a file status object that represents the path. | 
| abstract FileStatus | AbstractFileSystem. getFileStatus(Path f)The specification of this method matches that of
  FileContext.getFileStatus(Path)except that an UnresolvedLinkException may be thrown if a symlink is 
 encountered in the path. | 
| FileStatus | FilterFileSystem. getFileStatus(Path f)Get file status. | 
| FileStatus | RawLocalFileSystem. getFileStatus(Path f) | 
| FileStatus | FileContext. getFileStatus(Path f)Return a file status object that represents the path. | 
| FileStatus[] | FileSystem. globStatus(Path pathPattern)Return all the files that match filePattern and are not checksum
 files. | 
| FileStatus[] | FileSystem. globStatus(Path pathPattern,
          PathFilter filter)Return an array of  FileStatusobjects whose path names matchpathPatternand is accepted by the user-supplied path filter. | 
| FileStatus[] | ChecksumFileSystem. listStatus(Path f)List the statuses of the files/directories in the given path if the path is
 a directory. | 
| abstract FileStatus[] | FileSystem. listStatus(Path f)List the statuses of the files/directories in the given path if the path is
 a directory. | 
| abstract FileStatus[] | AbstractFileSystem. listStatus(Path f)The specification of this method matches that of
  FileContext.Util.listStatus(Path)except that Path f must be 
 for this file system. | 
| FileStatus[] | FilterFileSystem. listStatus(Path f)List files in a directory. | 
| FileStatus[] | RawLocalFileSystem. listStatus(Path f)List the statuses of the files/directories in the given path if the path is
 a directory. | 
| FileStatus[] | FileSystem. listStatus(Path[] files)Filter files/directories in the given list of paths using default
 path filter. | 
| FileStatus[] | FileSystem. listStatus(Path[] files,
          PathFilter filter)Filter files/directories in the given list of paths using user-supplied
 path filter. | 
| FileStatus[] | FileSystem. listStatus(Path f,
          PathFilter filter)Filter files/directories in the given path using the user-supplied path
 filter. | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.fs.RemoteIterator<PartialListing<FileStatus>> | BatchListingOperations. batchedListStatusIterator(List<Path> paths)Batched listing API that returns  PartialListings for the
 passed Paths. | 
| Collection<FileStatus> | FileSystem. getTrashRoots(boolean allUsers)Get all the trash roots for current user or all users. | 
| Collection<FileStatus> | FilterFileSystem. getTrashRoots(boolean allUsers) | 
| org.apache.hadoop.fs.RemoteIterator<FileStatus> | FileContext. listStatus(Path f)List the statuses of the files/directories in the given path if the path is
 a directory. | 
| org.apache.hadoop.fs.RemoteIterator<FileStatus> | ChecksumFileSystem. listStatusIterator(Path p) | 
| org.apache.hadoop.fs.RemoteIterator<FileStatus> | FileSystem. listStatusIterator(Path p)Returns a remote iterator so that followup calls are made on demand
 while consuming the entries. | 
| org.apache.hadoop.fs.RemoteIterator<FileStatus> | AbstractFileSystem. listStatusIterator(Path f)The specification of this method matches that of
  FileContext.listStatus(Path)except that Path f must be for this
 file system. | 
| org.apache.hadoop.fs.RemoteIterator<FileStatus> | FilterFileSystem. listStatusIterator(Path f)Return a remote iterator for listing in a directory | 
| Modifier and Type | Method and Description | 
|---|---|
| int | LocatedFileStatus. compareTo(FileStatus o)Compare this FileStatus to another FileStatus | 
| int | FileStatus. compareTo(FileStatus o)Compare this FileStatus to another FileStatus based on lexicographical
 order of path. | 
| 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. | 
| protected PathHandle | FileSystem. createPathHandle(FileStatus stat,
                org.apache.hadoop.fs.Options.HandleOpt... opt)Hook to implement support for  PathHandleoperations. | 
| protected PathHandle | FilterFileSystem. createPathHandle(FileStatus stat,
                org.apache.hadoop.fs.Options.HandleOpt... opts) | 
| protected PathHandle | RawLocalFileSystem. createPathHandle(FileStatus stat,
                org.apache.hadoop.fs.Options.HandleOpt... opts)Hook to implement support for  PathHandleoperations. | 
| BlockLocation[] | FileSystem. getFileBlockLocations(FileStatus file,
                     long start,
                     long len)Return an array containing hostnames, offset and size of
 portions of the given file. | 
| BlockLocation[] | FilterFileSystem. getFileBlockLocations(FileStatus file,
                     long start,
                     long len) | 
| PathHandle | FileSystem. getPathHandle(FileStatus stat,
             org.apache.hadoop.fs.Options.HandleOpt... opt)Create a durable, serializable handle to the referent of the given
 entity. | 
| static Path[] | FileUtil. stat2Paths(FileStatus[] stats)convert an array of FileStatus to an array of Path | 
| static Path[] | FileUtil. stat2Paths(FileStatus[] stats,
          Path path)convert an array of FileStatus to an array of Path. | 
| default FutureDataInputStreamBuilder | FutureDataInputStreamBuilder. withFileStatus(FileStatus status)A FileStatus may be provided to the open request. | 
| Constructor and Description | 
|---|
| FileStatus(FileStatus other)Copy constructor. | 
| LocatedFileStatus(FileStatus stat,
                 BlockLocation[] locations)Constructor | 
| Modifier and Type | Method and Description | 
|---|---|
| FileStatus | AdlFileSystem. getFileStatus(Path f)Return a file status object that represents the path. | 
| FileStatus[] | AdlFileSystem. listStatus(Path f)List the statuses of the files/directories in the given path if the path is
 a directory. | 
| Modifier and Type | Method and Description | 
|---|---|
| FileStatus | NativeAzureFileSystem. getFileStatus(Path f) | 
| FileStatus[] | NativeAzureFileSystem. listStatus(Path f)Retrieve the status of a given path if it is a file, or of all the
 contained files if it is a directory. | 
| Modifier and Type | Method and Description | 
|---|---|
| FileStatus | AzureBlobFileSystemStore. getFileStatus(Path path,
             org.apache.hadoop.fs.azurebfs.utils.TracingContext tracingContext) | 
| FileStatus[] | AzureBlobFileSystemStore. listStatus(Path path,
          String startFrom,
          org.apache.hadoop.fs.azurebfs.utils.TracingContext tracingContext) | 
| FileStatus[] | AzureBlobFileSystemStore. listStatus(Path path,
          org.apache.hadoop.fs.azurebfs.utils.TracingContext tracingContext) | 
| Modifier and Type | Method and Description | 
|---|---|
| String | AzureBlobFileSystemStore. listStatus(Path path,
          String startFrom,
          List<FileStatus> fileStatuses,
          boolean fetchAll,
          String continuation,
          org.apache.hadoop.fs.azurebfs.utils.TracingContext tracingContext) | 
| Modifier and Type | Method and Description | 
|---|---|
| FileStatus | FTPFileSystem. getFileStatus(Path file) | 
| FileStatus[] | FTPFileSystem. listStatus(Path file) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected FileStatus | FutureDataInputStreamBuilderImpl. getStatus()Get any status set in  FutureDataInputStreamBuilderImpl.withFileStatus(FileStatus). | 
| Modifier and Type | Method and Description | 
|---|---|
| FutureDataInputStreamBuilder | FutureDataInputStreamBuilderImpl. withFileStatus(FileStatus st) | 
| Modifier and Type | Method and Description | 
|---|---|
| FileStatus | NativeS3FileSystem. getFileStatus(Path f)Deprecated.  | 
| FileStatus[] | NativeS3FileSystem. listStatus(Path f)Deprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| FileStatus | ViewFs. getFileLinkStatus(Path f) | 
| FileStatus | ViewFileSystem. getFileStatus(Path f)Return a file status object that represents the path. | 
| FileStatus | ViewFs. getFileStatus(Path f)The specification of this method matches that of
  FileContext.getFileStatus(Path)except that an UnresolvedLinkException may be thrown if a symlink is 
 encountered in the path. | 
| FileStatus[] | ViewFileSystem. listStatus(Path f)List the statuses of the files/directories in the given path if the path is
 a directory. | 
| FileStatus[] | ViewFs. listStatus(Path f)The specification of this method matches that of
  FileContext.Util.listStatus(Path)except that Path f must be 
 for this file system. | 
| Modifier and Type | Method and Description | 
|---|---|
| Collection<FileStatus> | ViewFileSystem. getTrashRoots(boolean allUsers)Get all the trash roots for current user or all users. | 
| org.apache.hadoop.fs.RemoteIterator<FileStatus> | ViewFs. listStatusIterator(Path f) | 
| Modifier and Type | Method and Description | 
|---|---|
| BlockLocation[] | ViewFileSystem. getFileBlockLocations(FileStatus fs,
                     long start,
                     long len) | 
| Modifier and Type | Method and Description | 
|---|---|
| FileStatus | TreePath. getFileStatus() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected List<Long> | FixedBlockResolver. blockLengths(FileStatus s) | 
| protected abstract List<Long> | BlockResolver. blockLengths(FileStatus status) | 
| long | UGIResolver. getPermissionsProto(FileStatus remoteStatus,
                   AclStatus remoteAcl)Get the serialized, local permissions for the external
  FileStatusorAclStatus. | 
| int | FixedBlockResolver. getReplication(FileStatus s) | 
| int | FixedBlockMultiReplicaResolver. getReplication(FileStatus s) | 
| abstract int | BlockResolver. getReplication(FileStatus status) | 
| void | AuditLogger. logAuditEvent(boolean succeeded,
             String userName,
             InetAddress addr,
             String cmd,
             String src,
             String dst,
             FileStatus stat)Called to log an audit event. | 
| void | HdfsAuditLogger. logAuditEvent(boolean succeeded,
             String userName,
             InetAddress addr,
             String cmd,
             String src,
             String dst,
             FileStatus status) | 
| abstract void | HdfsAuditLogger. logAuditEvent(boolean succeeded,
             String userName,
             InetAddress addr,
             String cmd,
             String src,
             String dst,
             FileStatus stat,
             CallerContext callerContext,
             UserGroupInformation ugi,
             org.apache.hadoop.hdfs.security.token.delegation.DelegationTokenSecretManager dtSecretManager)Same as
  HdfsAuditLogger.logAuditEvent(boolean, String, InetAddress, String, String, String,
 FileStatus)with additional parameters related to logging delegation token
 tracking IDs. | 
| abstract void | DefaultAuditLogger. logAuditEvent(boolean succeeded,
             String userName,
             InetAddress addr,
             String cmd,
             String src,
             String dst,
             FileStatus status,
             CallerContext callerContext,
             UserGroupInformation ugi,
             org.apache.hadoop.hdfs.security.token.delegation.DelegationTokenSecretManager dtSecretManager) | 
| abstract void | HdfsAuditLogger. logAuditEvent(boolean succeeded,
             String userName,
             InetAddress addr,
             String cmd,
             String src,
             String dst,
             FileStatus stat,
             UserGroupInformation ugi,
             org.apache.hadoop.hdfs.security.token.delegation.DelegationTokenSecretManager dtSecretManager) | 
| abstract void | DefaultAuditLogger. logAuditEvent(boolean succeeded,
             String userName,
             InetAddress addr,
             String cmd,
             String src,
             String dst,
             FileStatus status,
             UserGroupInformation ugi,
             org.apache.hadoop.hdfs.security.token.delegation.DelegationTokenSecretManager dtSecretManager) | 
| long | FixedBlockResolver. preferredBlockSize(FileStatus s) | 
| long | BlockResolver. preferredBlockSize(FileStatus status) | 
| long | UGIResolver. resolve(FileStatus s) | 
| Iterable<org.apache.hadoop.hdfs.protocol.proto.HdfsProtos.BlockProto> | BlockResolver. resolve(FileStatus s) | 
| Constructor and Description | 
|---|
| TreePath(FileStatus stat,
        long parentId,
        org.apache.hadoop.hdfs.server.namenode.TreeWalk.TreeIterator i) | 
| 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 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
  FileSystem.openFile(Path)and blocks
 awaiting the operation completion. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected FileStatus[] | SequenceFileInputFormat. listStatus(JobConf job) | 
| protected FileStatus[] | FileInputFormat. listStatus(JobConf job)List input directories. | 
| 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. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected FileStatus[] | CombineFileInputFormat. listStatus(JobConf job)List input directories. | 
| Modifier and Type | Method and Description | 
|---|---|
| static FileStatus | FileInputFormat. shrinkStatus(FileStatus origStat)The HdfsBlockLocation includes a LocatedBlock which contains messages
 for issuing more detailed queries to datanodes about a block, but these
 messages are useless during job submission currently. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected List<FileStatus> | SequenceFileInputFormat. listStatus(JobContext job) | 
| protected List<FileStatus> | FileInputFormat. listStatus(JobContext job)List input directories. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected BlockLocation[] | CombineFileInputFormat. getFileBlockLocations(FileSystem fs,
                     FileStatus stat) | 
| static List<FileSplit> | NLineInputFormat. getSplitsForFile(FileStatus status,
                Configuration conf,
                int numLinesPerSplit) | 
| static FileStatus | FileInputFormat. shrinkStatus(FileStatus origStat)The HdfsBlockLocation includes a LocatedBlock which contains messages
 for issuing more detailed queries to datanodes about a block, but these
 messages are useless during job submission currently. | 
| 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. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected List<FileStatus> | HistoryFileManager. findTimestampedDirectories()Finds all history directories with a timestamp component by scanning the
 filesystem. | 
| protected static List<FileStatus> | HistoryFileManager. scanDirectory(Path path,
             FileContext fc,
             PathFilter pathFilter) | 
| protected List<FileStatus> | HistoryFileManager. scanDirectoryForHistoryFiles(Path path,
                            FileContext fc) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected boolean | HistoryFileManager. deleteDir(FileStatus serialDir) | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.fs.RemoteIterator<FileStatus> | LogAggregationFileController. getApplicationDirectoriesOfUser(String user)Gets all application directories of a user. | 
| org.apache.hadoop.fs.RemoteIterator<FileStatus> | LogAggregationFileController. getNodeFilesOfApplicationDirectory(FileStatus appDir)Gets all node files in an application directory. | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<String,List<org.apache.hadoop.yarn.logaggregation.ContainerLogFileInfo>> | LogAggregationFileController. getLogMetaFilesOfNode(org.apache.hadoop.yarn.logaggregation.ExtendedLogMetaRequest logRequest,
                     FileStatus currentNodeFile,
                     ApplicationId appId)Returns log file metadata for a node grouped by containers. | 
| org.apache.hadoop.fs.RemoteIterator<FileStatus> | LogAggregationFileController. getNodeFilesOfApplicationDirectory(FileStatus appDir)Gets all node files in an application directory. | 
Copyright © 2025 Apache Software Foundation. All rights reserved.