Package | Description |
---|---|
org.apache.hadoop.conf |
Configuration of system parameters.
|
org.apache.hadoop.filecache | |
org.apache.hadoop.fs |
Implementations of
AbstractFileSystem for 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
FileSystem for reading and writing files on
Azure Block Storage. |
org.apache.hadoop.fs.azurebfs |
A distributed implementation of
FileSystem for reading and writing files on
Azure Storage. |
org.apache.hadoop.fs.azurebfs.commit |
Support for manifest committer.
|
org.apache.hadoop.fs.ftp | |
org.apache.hadoop.fs.impl |
This package contains implementation classes for use inside
filesystems.
|
org.apache.hadoop.fs.obs |
Package for supporting
HuaweiCloud
Object Storage Service (OBS) as a backend filesystem in Hadoop.
|
org.apache.hadoop.fs.s3a |
S3A Filesystem.
|
org.apache.hadoop.fs.s3a.commit.magic |
This is the "Magic" committer and support.
|
org.apache.hadoop.fs.s3native |
A distributed implementation of
FileSystem for reading and writing files on
Amazon S3. |
org.apache.hadoop.fs.viewfs |
ViewFileSystem and ViewFileSystemOverloadScheme classes.
|
org.apache.hadoop.hdfs.client |
This package provides the administrative APIs for HDFS.
|
org.apache.hadoop.hdfs.protocol |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.hdfs.server.common | |
org.apache.hadoop.hdfs.server.common.blockaliasmap.impl | |
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.compress | |
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.join | |
org.apache.hadoop.mapreduce.lib.output | |
org.apache.hadoop.mapreduce.lib.output.committer.manifest |
Intermediate manifest committer.
|
org.apache.hadoop.mapreduce.lib.output.committer.manifest.files |
Persistence formats.
|
org.apache.hadoop.mapreduce.lib.partition | |
org.apache.hadoop.mapreduce.security | |
org.apache.hadoop.mapreduce.v2.hs | |
org.apache.hadoop.metrics2.sink |
Builtin metrics sinks
|
org.apache.hadoop.registry.client.api |
YARN Registry Client API.
|
org.apache.hadoop.security | |
org.apache.hadoop.tools |
Command-line tools for MapReduce.
|
org.apache.hadoop.util.functional |
Support for functional programming within the Hadoop APIs.
|
org.apache.hadoop.yarn.api.records |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.client.api | |
org.apache.hadoop.yarn.logaggregation |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.logaggregation.filecontroller |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.service.client |
Package org.apache.hadoop.yarn.service.client contains classes
for YARN Services Client API.
|
org.apache.hadoop.yarn.util |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
FileStatus
Interface that represents the client side information for a file.
|
Class and Description |
---|
Abortable
Abort data being written to a stream, so that close() does
not write the data.
|
AbstractFileSystem
This class provides an interface for implementors of a Hadoop file system
(analogous to the VFS of Unix).
|
BlockLocation
Represents the network location of a block, information about the hosts
that contain block replicas, and other block metadata (E.g.
|
BlockStoragePolicySpi
A storage policy specifies the placement of block replicas on specific
storage types.
|
BulkDelete
API for bulk deletion of objects/files,
but not directories.
|
BulkDeleteSource
Interface for bulk deletion.
|
ByteBufferPositionedReadable
Implementers of this interface provide a positioned read API that writes to a
ByteBuffer rather than a byte[] . |
ByteBufferReadable
Implementers of this interface provide a read API that writes to a
ByteBuffer, not a byte[].
|
CacheFlag
Specifies semantics for CacheDirective operations.
|
CanSetDropBehind |
CanSetReadahead |
CanUnbuffer
FSDataInputStreams implement this interface to indicate that they can clear
their buffers on request.
|
ChecksumFileSystem
Abstract Checksumed FileSystem.
|
ContentSummary
Store the summary of a content (a directory or a file).
|
CreateFlag
CreateFlag specifies the file create semantic.
|
FileAlreadyExistsException
Used when target file already exists for any operation and
is not configured to be overwritten.
|
FileChecksum
An abstract class representing file checksums for files.
|
FileContext
The FileContext class provides an interface for users of the Hadoop
file system.
|
FileStatus
Interface that represents the client side information for a file.
|
FileSystem
An abstract base class for a fairly generic filesystem.
|
FilterFileSystem
A
FilterFileSystem contains
some other file system, which it uses as
its basic file system, possibly transforming
the data along the way or providing additional
functionality. |
FSBuilder
The base interface which various FileSystem FileContext Builder
interfaces can extend, and which underlying implementations
will then implement.
|
FSDataInputStream
Utility that wraps a
FSInputStream in a DataInputStream
and buffers input through a BufferedInputStream . |
FSDataOutputStream
Utility that wraps a
OutputStream in a DataOutputStream . |
FSDataOutputStreamBuilder
Builder for
FSDataOutputStream and its subclasses. |
FsServerDefaults
Provides server default configuration values to clients.
|
FsStatus
This class is used to represent the capacity, free and used space on a
FileSystem . |
FutureDataInputStreamBuilder
Builder for input streams and subclasses whose return value is
actually a completable future: this allows for better asynchronous
operation.
|
GlobalStorageStatistics
Stores global storage statistics objects.
|
LocalFileSystem
Implement the FileSystem API for the checksumed local filesystem.
|
LocatedFileStatus
This class defines a FileStatus that includes a file's block locations.
|
ParentNotDirectoryException
Indicates that the parent of specified Path is not a directory
as expected.
|
PartHandle
Opaque, serializable reference to a part id for multipart uploads.
|
PartialListing
A partial listing of the children of a parent directory.
|
Path
Names a file or directory in a
FileSystem . |
PathFilter |
PathHandle
Opaque, serializable reference to an entity in the FileSystem.
|
PositionedReadable
Stream that permits positional reading.
|
QuotaUsage
Store the quota usage of a directory.
|
ReadOption
Options that can be used when reading from a FileSystem.
|
Seekable
Stream that permits seeking.
|
StorageStatistics
StorageStatistics contains statistics data for a FileSystem or FileContext
instance.
|
StorageType
Defines the types of supported storage media.
|
StreamCapabilities
Interface to query streams for supported capabilities.
|
Syncable
This is the interface for flush/sync operations.
|
TrashPolicy
This interface is used for implementing different Trash policies.
|
UnsupportedFileSystemException
File system for a given file system name/scheme is not supported
|
UploadHandle
Opaque, serializable reference to an uploadId for multipart uploads.
|
XAttrCodec
The value of
XAttr is byte[], this class is to
covert byte[] to some kind of string representation or convert back. |
XAttrSetFlag |
Class and Description |
---|
AbstractFileSystem
This class provides an interface for implementors of a Hadoop file system
(analogous to the VFS of Unix).
|
BulkDeleteSource
Interface for bulk deletion.
|
ContentSummary
Store the summary of a content (a directory or a file).
|
CreateFlag
CreateFlag specifies the file create semantic.
|
FileStatus
Interface that represents the client side information for a file.
|
FileSystem
An abstract base class for a fairly generic filesystem.
|
FSDataInputStream
Utility that wraps a
FSInputStream in a DataInputStream
and buffers input through a BufferedInputStream . |
FSDataOutputStream
Utility that wraps a
OutputStream in a DataOutputStream . |
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
AbstractFileSystem
This class provides an interface for implementors of a Hadoop file system
(analogous to the VFS of Unix).
|
BulkDeleteSource
Interface for bulk deletion.
|
CreateFlag
CreateFlag specifies the file create semantic.
|
FileAlreadyExistsException
Used when target file already exists for any operation and
is not configured to be overwritten.
|
FileStatus
Interface that represents the client side information for a file.
|
FileSystem
An abstract base class for a fairly generic filesystem.
|
FSDataInputStream
Utility that wraps a
FSInputStream in a DataInputStream
and buffers input through a BufferedInputStream . |
FSDataOutputStream
Utility that wraps a
OutputStream in a DataOutputStream . |
Path
Names a file or directory in a
FileSystem . |
XAttrSetFlag |
Class and Description |
---|
FileStatus
Interface that represents the client side information for a file.
|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
BulkDeleteSource
Interface for bulk deletion.
|
FileStatus
Interface that represents the client side information for a file.
|
FileSystem
An abstract base class for a fairly generic filesystem.
|
FSDataInputStream
Utility that wraps a
FSInputStream in a DataInputStream
and buffers input through a BufferedInputStream . |
FSDataOutputStream
Utility that wraps a
OutputStream in a DataOutputStream . |
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
CreateFlag
CreateFlag specifies the file create semantic.
|
FileContext
The FileContext class provides an interface for users of the Hadoop
file system.
|
FileStatus
Interface that represents the client side information for a file.
|
FileSystem
An abstract base class for a fairly generic filesystem.
|
FSBuilder
The base interface which various FileSystem FileContext Builder
interfaces can extend, and which underlying implementations
will then implement.
|
FutureDataInputStreamBuilder
Builder for input streams and subclasses whose return value is
actually a completable future: this allows for better asynchronous
operation.
|
MultipartUploader
MultipartUploader is an interface for copying files multipart and across
multiple nodes.
|
Path
Names a file or directory in a
FileSystem . |
PathHandle
Opaque, serializable reference to an entity in the FileSystem.
|
Class and Description |
---|
AbstractFileSystem
This class provides an interface for implementors of a Hadoop file system
(analogous to the VFS of Unix).
|
Class and Description |
---|
AbstractFileSystem
This class provides an interface for implementors of a Hadoop file system
(analogous to the VFS of Unix).
|
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
BulkDeleteSource
Interface for bulk deletion.
|
FileStatus
Interface that represents the client side information for a file.
|
FileSystem
An abstract base class for a fairly generic filesystem.
|
FSDataInputStream
Utility that wraps a
FSInputStream in a DataInputStream
and buffers input through a BufferedInputStream . |
FSDataOutputStream
Utility that wraps a
OutputStream in a DataOutputStream . |
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
AbstractFileSystem
This class provides an interface for implementors of a Hadoop file system
(analogous to the VFS of Unix).
|
BlockLocation
Represents the network location of a block, information about the hosts
that contain block replicas, and other block metadata (E.g.
|
BlockStoragePolicySpi
A storage policy specifies the placement of block replicas on specific
storage types.
|
BulkDeleteSource
Interface for bulk deletion.
|
ContentSummary
Store the summary of a content (a directory or a file).
|
CreateFlag
CreateFlag specifies the file create semantic.
|
FileAlreadyExistsException
Used when target file already exists for any operation and
is not configured to be overwritten.
|
FileChecksum
An abstract class representing file checksums for files.
|
FileStatus
Interface that represents the client side information for a file.
|
FileSystem
An abstract base class for a fairly generic filesystem.
|
FSDataInputStream
Utility that wraps a
FSInputStream in a DataInputStream
and buffers input through a BufferedInputStream . |
FSDataOutputStream
Utility that wraps a
OutputStream in a DataOutputStream . |
FsServerDefaults
Provides server default configuration values to clients.
|
FsStatus
This class is used to represent the capacity, free and used space on a
FileSystem . |
LocatedFileStatus
This class defines a FileStatus that includes a file's block locations.
|
ParentNotDirectoryException
Indicates that the parent of specified Path is not a directory
as expected.
|
Path
Names a file or directory in a
FileSystem . |
PathFilter |
QuotaUsage
Store the quota usage of a directory.
|
UnsupportedFileSystemException
File system for a given file system name/scheme is not supported
|
XAttrSetFlag |
Class and Description |
---|
Abortable
Abort data being written to a stream, so that close() does
not write the data.
|
BlockStoragePolicySpi
A storage policy specifies the placement of block replicas on specific
storage types.
|
ByteBufferPositionedReadable
Implementers of this interface provide a positioned read API that writes to a
ByteBuffer rather than a byte[] . |
ByteBufferReadable
Implementers of this interface provide a read API that writes to a
ByteBuffer, not a byte[].
|
CacheFlag
Specifies semantics for CacheDirective operations.
|
CanSetDropBehind |
CanSetReadahead |
CanUnbuffer
FSDataInputStreams implement this interface to indicate that they can clear
their buffers on request.
|
FSDataInputStream
Utility that wraps a
FSInputStream in a DataInputStream
and buffers input through a BufferedInputStream . |
FSDataOutputStream
Utility that wraps a
OutputStream in a DataOutputStream . |
Path
Names a file or directory in a
FileSystem . |
PositionedReadable
Stream that permits positional reading.
|
Seekable
Stream that permits seeking.
|
StorageType
Defines the types of supported storage media.
|
StreamCapabilities
Interface to query streams for supported capabilities.
|
Syncable
This is the interface for flush/sync operations.
|
Class and Description |
---|
ClusterStorageCapacityExceededException
Exception raised by HDFS indicating that storage capacity in the
cluster filesystem is exceeded.
|
Path
Names a file or directory in a
FileSystem . |
StorageType
Defines the types of supported storage media.
|
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
FileStatus
Interface that represents the client side information for a file.
|
FileSystem
An abstract base class for a fairly generic filesystem.
|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
CreateFlag
CreateFlag specifies the file create semantic.
|
FileContext
The FileContext class provides an interface for users of the Hadoop
file system.
|
FileSystem
An abstract base class for a fairly generic filesystem.
|
FSDataOutputStream
Utility that wraps a
OutputStream in a DataOutputStream . |
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Seekable
Stream that permits seeking.
|
Class and Description |
---|
FileStatus
Interface that represents the client side information for a file.
|
FileSystem
An abstract base class for a fairly generic filesystem.
|
FSDataInputStream
Utility that wraps a
FSInputStream in a DataInputStream
and buffers input through a BufferedInputStream . |
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
FileSystem
An abstract base class for a fairly generic filesystem.
|
Path
Names a file or directory in a
FileSystem . |
PathFilter |
Class and Description |
---|
FileSystem
An abstract base class for a fairly generic filesystem.
|
Class and Description |
---|
FileSystem
An abstract base class for a fairly generic filesystem.
|
Class and Description |
---|
FileSystem
An abstract base class for a fairly generic filesystem.
|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
BlockLocation
Represents the network location of a block, information about the hosts
that contain block replicas, and other block metadata (E.g.
|
FileStatus
Interface that represents the client side information for a file.
|
FileSystem
An abstract base class for a fairly generic filesystem.
|
Path
Names a file or directory in a
FileSystem . |
PathFilter |
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
StreamCapabilities
Interface to query streams for supported capabilities.
|
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
StreamCapabilities
Interface to query streams for supported capabilities.
|
Class and Description |
---|
FileSystem
An abstract base class for a fairly generic filesystem.
|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
FileContext
The FileContext class provides an interface for users of the Hadoop
file system.
|
FileStatus
Interface that represents the client side information for a file.
|
Path
Names a file or directory in a
FileSystem . |
PathFilter |
UnsupportedFileSystemException
File system for a given file system name/scheme is not supported
|
Class and Description |
---|
FileSystem
An abstract base class for a fairly generic filesystem.
|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
FileAlreadyExistsException
Used when target file already exists for any operation and
is not configured to be overwritten.
|
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
FSBuilder
The base interface which various FileSystem FileContext Builder
interfaces can extend, and which underlying implementations
will then implement.
|
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
FileStatus
Interface that represents the client side information for a file.
|
FileSystem
An abstract base class for a fairly generic filesystem.
|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Class and Description |
---|
Path
Names a file or directory in a
FileSystem . |
Copyright © 2024 Apache Software Foundation. All rights reserved.