Package | Description |
---|---|
org.apache.hadoop.security.token.delegation | |
org.apache.hadoop.ipc.metrics |
RPC related metrics.
|
org.apache.hadoop.metrics.jvm | |
org.apache.hadoop.metrics2.filter |
Builtin metrics filters (to be used in metrics config files)
|
org.apache.hadoop.io.retry |
A mechanism for selectively retrying methods that throw exceptions under certain circumstances.
|
org.apache.hadoop.metrics.util | |
org.apache.hadoop.metrics2.annotation |
Annotation interfaces for metrics instrumentation
|
org.apache.hadoop.metrics2.util |
General helpers for implementing source and sinks
|
org.apache.hadoop.metrics2 |
Metrics 2.0
|
org.apache.hadoop.metrics2.lib |
A collection of library classes for implementing metrics sources
|
org.apache.hadoop.mapreduce.counters |
This package contains the implementations of different types of
map-reduce counters.
|
org.apache.hadoop.metrics2.sink |
Builtin metrics sinks
|
org.apache.hadoop.security.token | |
org.apache.hadoop.ipc |
Tools to help define network clients and servers.
|
org.apache.hadoop.security.authorize | |
org.apache.hadoop.metrics2.impl |
A metrics system implementation
|
Modifier and Type | Class and Description |
---|---|
class |
InterfaceAudience
Annotation to inform users of a package, class or method's intended audience.
|
class |
InterfaceStability
Annotation to inform users of how much to rely on a particular package,
class or method not changing over time.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractFileSystem
This class provides an interface for implementors of a Hadoop file system
(analogous to the VFS of Unix).
|
interface |
CanSetDropBehind |
interface |
CanSetReadahead |
class |
ChecksumFs
Abstract Checksumed Fs.
|
class |
ContentSummary
Store the summary of a content (a directory or a file).
|
class |
CreateFlag
CreateFlag specifies the file create semantic.
|
class |
DF
Filesystem disk space usage statistics.
|
class |
DU
Filesystem disk space usage statistics.
|
class |
FileContext
The FileContext class provides an interface to the application writer for
using the Hadoop file system.
|
class |
FileSystemLinkResolver<T>
FileSystem-specific class used to operate on and resolve symlinks in a path.
|
class |
FileUtil
A collection of file-processing util methods
|
class |
FilterFs
A
FilterFs contains some other file system, which it uses as its
basic file system, possibly transforming the data along the way or providing
additional functionality. |
class |
FSLinkResolver<T>
Used primarily by
FileContext to operate on and resolve
symlinks in a path. |
class |
FsServerDefaults
Provides server default configuration values to clients.
|
class |
GlobFilter
A filter for POSIX glob pattern with brace expansions.
|
class |
GlobPattern
A class for POSIX glob pattern with brace expansions.
|
interface |
HasFileDescriptor
Having a FileDescriptor
|
class |
Hdfs |
class |
LocatedFileStatus
This class defines a FileStatus that includes a file's block locations.
|
class |
Options
This class contains options related to file system operations.
|
interface |
PositionedReadable
Stream that permits positional reading.
|
interface |
Seekable
Stream that permits seeking.
|
interface |
Syncable
This interface for flush/sync operation.
|
class |
TrashPolicy
This interface is used for implementing different Trash policies.
|
class |
TrashPolicyDefault
Provides a trash feature.
|
Modifier and Type | Method and Description |
---|---|
BlockLocation[] |
FileContext.getFileBlockLocations(Path f,
long start,
long len)
Return blockLocation of the given file for the given offset and len.
|
Modifier and Type | Class and Description |
---|---|
class |
FtpFs
The FtpFs implementation of AbstractFileSystem.
|
Modifier and Type | Class and Description |
---|---|
class |
LocalFs
The LocalFs implementation of ChecksumFs.
|
class |
RawLocalFs
The RawLocalFs implementation of AbstractFileSystem.
|
Modifier and Type | Class and Description |
---|---|
class |
Command
An abstract class for the execution of a file system command
|
class |
Count
Count the number of directories, files, bytes, quota, and remaining quota.
|
class |
FsCommand
Base class for all "hadoop fs" commands
|
Modifier and Type | Class and Description |
---|---|
class |
NotInMountpointException
NotInMountpointException extends the UnsupportedOperationException.
|
class |
ViewFileSystem
ViewFileSystem (extends the FileSystem interface) implements a client-side
mount table.
|
class |
ViewFs
ViewFs (extends the AbstractFileSystem interface) implements a client-side
mount table.
|
Modifier and Type | Class and Description |
---|---|
class |
ActiveStandbyElector
This class implements a simple library to perform leader election on top of
Apache Zookeeper.
|
class |
BadFencingConfigurationException
Indicates that the operator has specified an invalid configuration
for fencing methods.
|
class |
FailoverController
The FailOverController is responsible for electing an active service
on startup or when the current active is changing (eg due to failure),
monitoring the health of a service, and performing a fail-over when a
new active service is either manually selected by a user or elected.
|
class |
FailoverFailedException
Exception thrown to indicate service failover has failed.
|
interface |
HAServiceProtocol
Protocol interface that provides High Availability related primitives to
monitor and fail-over the service.
|
class |
HAServiceProtocolHelper
Helper for making
HAServiceProtocol RPC calls. |
class |
HAServiceTarget
Represents a target of the client side HA administration commands.
|
class |
HealthCheckFailedException
Exception thrown to indicate that health check of a service failed.
|
class |
NodeFencer
This class parses the configured list of fencing methods, and
is responsible for trying each one in turn while logging informative
output.
|
class |
ServiceFailedException
Exception thrown to indicate that an operation performed
to modify the state of a service or application failed.
|
interface |
ZKFCProtocol
Protocol exposed by the ZKFailoverController, allowing for graceful
failover.
|
class |
ZKFCRpcServer |
Modifier and Type | Interface and Description |
---|---|
interface |
HAServiceProtocolPB |
interface |
ZKFCProtocolPB |
Modifier and Type | Class and Description |
---|---|
class |
BlockMissingException
This exception is thrown when a read encounters a block that has no locations
associated with it.
|
class |
HftpFileSystem
An implementation of a protocol for accessing filesystems over HTTP.
|
class |
HsftpFileSystem
An implementation of a protocol for accessing filesystems over HTTPS.
|
Modifier and Type | Class and Description |
---|---|
class |
HdfsAdmin
The public API for performing administrative functions on HDFS.
|
class |
HdfsDataInputStream
The Hdfs implementation of
FSDataInputStream . |
class |
HdfsDataOutputStream
The Hdfs implementation of
FSDataOutputStream . |
class |
HdfsUtils
The public utility API for HDFS.
|
Modifier and Type | Class and Description |
---|---|
class |
AlreadyBeingCreatedException
The exception that happens when you ask to create a file that already
is being created, but is not closed yet.
|
class |
Block
A Block is a Hadoop FS primitive, identified by a
long.
|
class |
BlockListAsLongs
This class provides an interface for accessing list of blocks that
has been implemented as long[].
|
class |
BlockListAsLongs.BlockReportIterator
Iterates over blocks in the block report.
|
class |
BlockLocalPathInfo
A block and the full path information to the block data file and
the metadata file stored on the local file system.
|
interface |
ClientDatanodeProtocol
An client-datanode protocol for block recovery
|
interface |
ClientProtocol
ClientProtocol is used by user code via
DistributedFileSystem class to communicate
with the NameNode. |
class |
DatanodeID
This class represents the primary identifier for a Datanode.
|
class |
DatanodeInfo
This class extends the primary identifier of a Datanode with ephemeral
state, eg usage information, current administrative state, and the
network location that is communicated to clients.
|
class |
DirectoryListing
This class defines a partial listing of a directory to support
iterative directory listing.
|
class |
DSQuotaExceededException |
class |
ExtendedBlock
Identifies a Block uniquely across the block pools
|
class |
FSLimitException |
class |
HdfsFileStatus
Interface that represents the over the wire information for a file.
|
class |
HdfsLocatedFileStatus
Interface that represents the over the wire information
including block locations for a file.
|
class |
LocatedBlock
Associates a block with the Datanodes that contain its replicas
and other block metadata (E.g.
|
class |
LocatedBlocks
Collection of blocks with their locations and the file length.
|
class |
NSQuotaExceededException |
class |
QuotaExceededException
This exception is thrown when modification to HDFS results in violation
of a directory quota.
|
class |
RecoveryInProgressException
Exception indicating that a replica is already being recovery.
|
class |
SnapshotInfo
SnapshotInfo maintains information for a snapshot
|
class |
UnregisteredNodeException
This exception is thrown when a node that has not previously
registered is trying to access the name node.
|
class |
UnresolvedPathException
Thrown when a symbolic link is encountered in a path.
|
Modifier and Type | Class and Description |
---|---|
class |
BlockConstructionStage
Block Construction Stage
|
interface |
DataTransferProtocol
Transfer data to/from datanode using a streaming protocol.
|
class |
DataTransferProtoUtil
Static utilities for dealing with the protocol buffers used by the
Data Transfer Protocol.
|
class |
InvalidEncryptionKeyException
Encryption key verification failed.
|
class |
Op
Operation
|
class |
PacketHeader
Header data for each packet that goes through the read/write pipelines.
|
class |
PipelineAck
Pipeline Acknowledgment
|
class |
Receiver
Receiver
|
class |
ReplaceDatanodeOnFailure
The setting of replace-datanode-on-failure feature.
|
class |
Sender
Sender
|
Modifier and Type | Interface and Description |
---|---|
interface |
JournalNodeMXBean
This is the JMX management interface for JournalNode information
|
Modifier and Type | Class and Description |
---|---|
class |
InvalidBlockTokenException
Access token verification failed.
|
Modifier and Type | Class and Description |
---|---|
class |
DatanodeDescriptor
This class extends the DatanodeInfo class with ephemeral information (eg
health, capacity, what blocks are associated with the Datanode) that is
private to the Namenode, ie this class is not exposed to clients.
|
static class |
DatanodeDescriptor.BlockTargetPair
Block and targets pair
|
class |
DatanodeManager
Manage datanodes, include decommission and other activities.
|
class |
OutOfV1GenerationStampsException
This exception is thrown when the name node runs out of V1 generation
stamps.
|
Modifier and Type | Class and Description |
---|---|
class |
InconsistentFSStateException
The exception is thrown when file system state is inconsistent
and is not recoverable.
|
class |
IncorrectVersionException
The exception is thrown when external version does not match
current version of the application.
|
Modifier and Type | Class and Description |
---|---|
class |
BlockMetadataHeader
BlockMetadataHeader manages metadata for data blocks on Datanodes.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AuditLogger
Interface defining an audit logger.
|
class |
EditLogInputStream
A generic abstract class to support reading edits log data from
persistent storage.
|
class |
EditLogOutputStream
A generic abstract class to support journaling of edits logs into
a persistent storage.
|
class |
FSEditLog
FSEditLog maintains a log of the namespace modifications.
|
class |
FSEditLogLoader |
class |
FSImage
FSImage handles checkpointing and logging of the namespace edits.
|
class |
FSImageFormat
Contains inner classes for reading or writing the on-disk format for
FSImages.
|
class |
FSImageSerialization
Static utility functions for serializing various pieces of data in the correct
format for the FSImage file.
|
class |
HdfsAuditLogger
Extension of
AuditLogger . |
interface |
JournalManager
A JournalManager is responsible for managing a single place of storing
edit logs.
|
class |
LeaseExpiredException
The lease that was being used to create this file has expired.
|
class |
MetaRecoveryContext
Context data for an ongoing NameNode metadata recovery process.
|
class |
NotReplicatedYetException
The file has not finished being written to enough datanodes yet.
|
class |
SafeModeException
This exception is thrown when the name node is in safe mode.
|
class |
UnsupportedActionException
This exception is thrown when an operation is not supported.
|
Modifier and Type | Class and Description |
---|---|
class |
EditLogTailer
EditLogTailer represents a thread which periodically reads from edits
journals and applies the transactions contained within to a given
FSNamesystem.
|
Modifier and Type | Class and Description |
---|---|
class |
BlockCommand
A BlockCommand is an instruction to a datanode
regarding some blocks under its control.
|
class |
BlockRecoveryCommand
BlockRecoveryCommand is an instruction to a data-node to recover
the specified blocks.
|
static class |
BlockRecoveryCommand.RecoveringBlock
This is a block with locations from which it should be recovered
and the new generation stamp, which the block will have after
successful recovery.
|
class |
BlocksWithLocations
Maintains an array of blocks and their corresponding storage IDs.
|
static class |
BlocksWithLocations.BlockWithLocations
A class to keep track of a block and its locations
|
class |
CheckpointCommand
Checkpoint command.
|
class |
DatanodeCommand
Base class for data-node command.
|
class |
DatanodeRegistration
DatanodeRegistration class contains all information the name-node needs
to identify and verify a data-node when it contacts the name-node.
|
class |
DisallowedDatanodeException
This exception is thrown when a datanode tries to register or communicate
with the namenode when it does not appear on the list of included nodes,
or has been specifically excluded.
|
class |
FinalizeCommand
A BlockCommand is an instruction to a datanode to register with the namenode.
|
class |
HeartbeatResponse |
class |
KeyUpdateCommand |
class |
NamenodeCommand
Base class for name-node command.
|
class |
NamenodeRegistration
Information sent by a subordinate name-node to the active name-node
during the registration process.
|
class |
NamespaceInfo
NamespaceInfo is returned by the name-node in reply
to a data-node handshake.
|
class |
NNHAStatusHeartbeat |
class |
RegisterCommand
A BlockCommand is an instruction to a datanode to register with the namenode.
|
class |
ReplicaRecoveryInfo
Replica recovery information.
|
class |
ServerCommand
Base class for a server command.
|
Modifier and Type | Class and Description |
---|---|
class |
ExactSizeInputStream
An InputStream implementations which reads from some other InputStream
but expects an exact number of bytes.
|
Modifier and Type | Class and Description |
---|---|
class |
HttpServer
Create a Jetty embedded server to answer http requests.
|
Modifier and Type | Class and Description |
---|---|
class |
IOUtils
An utility class for I/O related functionality.
|
class |
ReadaheadPool
Manages a pool of threads which can issue readahead requests on file descriptors.
|
class |
WritableName
Utility to permit renaming of Writable implementation classes without
invalidiating files that contain their class name.
|
Modifier and Type | Class and Description |
---|---|
class |
BlockCompressorStream
A
CompressorStream which works
with 'block-based' based compression algorithms, as opposed to
'stream-based' compression algorithms. |
class |
BlockDecompressorStream
A
DecompressorStream which works
with 'block-based' based compression algorithms, as opposed to
'stream-based' compression algorithms. |
class |
BZip2Codec
This class provides output and input streams for bzip2 compression
and decompression.
|
class |
CodecPool
A global compressor/decompressor pool used to save and reuse
(possibly native) compression/decompression codecs.
|
interface |
CompressionCodec
This class encapsulates a streaming compression/decompression pair.
|
class |
CompressionCodecFactory
A factory that will find the correct codec for a given filename.
|
class |
CompressionInputStream
A compression input stream.
|
class |
CompressionOutputStream
A compression output stream.
|
interface |
Compressor
Specification of a stream-based 'compressor' which can be
plugged into a
CompressionOutputStream to compress data. |
class |
CompressorStream |
interface |
Decompressor
Specification of a stream-based 'de-compressor' which can be
plugged into a
CompressionInputStream to compress data. |
class |
DecompressorStream |
class |
DefaultCodec |
class |
GzipCodec
This class creates gzip compressors/decompressors.
|
protected static class |
GzipCodec.GzipOutputStream
A bridge that wraps around a DeflaterOutputStream to make it
a CompressionOutputStream.
|
class |
SplitCompressionInputStream
An InputStream covering a range of compressed data.
|
interface |
SplittableCompressionCodec
This interface is meant to be implemented by those compression codecs
which are capable to compress / de-compress a stream starting at any
arbitrary position.
|
Modifier and Type | Interface and Description |
---|---|
interface |
RawComparable
Interface for objects that can be compared through
RawComparator . |
class |
TFile
A TFile is a container of key-value pairs.
|
static class |
TFile.Reader
TFile Reader.
|
static class |
TFile.Writer
TFile Writer.
|
class |
Utils
Supporting Utility classes used by TFile, and shared by users of TFile.
|
Modifier and Type | Class and Description |
---|---|
interface |
AtMostOnce
Used to mark certain methods of an interface with at-most-once semantics.
|
class |
DefaultFailoverProxyProvider<T>
An implementation of
FailoverProxyProvider which does nothing in the
event of failover, and always returns the same proxy object. |
interface |
FailoverProxyProvider<T>
An implementer of this interface is capable of providing proxy objects for
use in IPC communication, and potentially modifying these objects or creating
entirely new ones in the event of certain types of failures.
|
interface |
Idempotent
Used to mark certain methods of an interface as being idempotent, and
therefore warrant being retried on failover.
|
interface |
RetryPolicy
Specifies a policy for retrying method failures.
|
static class |
RetryPolicy.RetryAction
|
Modifier and Type | Interface and Description |
---|---|
interface |
Deserializer<T>
Provides a facility for deserializing objects of type
InputStream . |
class |
DeserializerComparator<T>
A
RawComparator that uses a Deserializer to deserialize
the objects to be compared so that the standard Comparator can
be used to compare them. |
interface |
Serialization<T>
Encapsulates a
Serializer /Deserializer pair. |
class |
SerializationFactory
A factory for
Serialization s. |
interface |
Serializer<T>
Provides a facility for serializing objects of type
OutputStream . |
class |
WritableSerialization
A
Serialization for Writable s that delegates to
Writable.write(java.io.DataOutput) and
Writable.readFields(java.io.DataInput) . |
Modifier and Type | Interface and Description |
---|---|
interface |
AvroReflectSerializable
Tag interface for Avro 'reflect' serializable classes.
|
class |
AvroReflectSerialization
Serialization for Avro Reflect classes.
|
class |
AvroSerialization<T>
Base class for providing serialization to Avro types.
|
class |
AvroSpecificSerialization
Serialization for Avro Specific classes.
|
Modifier and Type | Class and Description |
---|---|
static class |
Client.ConnectionId
This class holds the address and the user ticket.
|
class |
ClientCache |
class |
ProtobufRpcEngine
RPC Engine for for protobuf based RPCs.
|
interface |
RpcEngine
An RPC implementation.
|
class |
StandbyException
Thrown by a remote server when it is up, but is not the active server in a
set of servers in which only a subset may be active.
|
class |
WritableRpcEngine
An RpcEngine implementation for Writable data.
|
Modifier and Type | Class and Description |
---|---|
class |
LogLevel
Change log level in runtime.
|
Modifier and Type | Class and Description |
---|---|
class |
JobCreator |
interface |
UserResolver
Maps users in the trace to a set of valid target users on the test cluster.
|
Modifier and Type | Class and Description |
---|---|
class |
Parser
Very simple shift-reduce parser for join expressions.
|
static class |
Parser.Node |
static class |
Parser.NodeToken |
static class |
Parser.NumToken |
static class |
Parser.StrToken |
static class |
Parser.Token
Tagged-union type for tokens from the join expression.
|
static class |
Parser.TType |
Modifier and Type | Class and Description |
---|---|
class |
Cluster
Provides a way to access information about the map/reduce cluster.
|
static class |
Cluster.JobTrackerStatus |
class |
ClusterMetrics
Status information on the current state of the Map-Reduce cluster.
|
class |
Job
The job submitter's view of the Job.
|
static class |
Job.JobState |
static class |
Job.TaskStatusFilter |
interface |
JobContext
A read-only view of the job that is provided to the tasks while they
are running.
|
class |
JobCounter |
class |
JobPriority
Used to describe the priority of the running job.
|
class |
JobStatus
Describes the current status of a job.
|
interface |
MapContext<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
The context that is given to the
Mapper . |
class |
MarkableIterator<VALUE>
MarkableIterator is a wrapper iterator class that
implements the MarkableIteratorInterface . |
interface |
MRJobConfig |
class |
QueueAclsInfo
Class to encapsulate Queue ACLs for a particular
user.
|
class |
QueueInfo
Class that contains the information regarding the Job Queues which are
maintained by the Hadoop Map/Reduce framework.
|
class |
QueueState
Enum representing queue state
|
interface |
ReduceContext<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
The context passed to the
Reducer . |
interface |
TaskAttemptContext
The context for task attempts.
|
class |
TaskCompletionEvent
This is used to track task completion events on
job tracker.
|
static class |
TaskCompletionEvent.Status |
class |
TaskCounter |
interface |
TaskInputOutputContext<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
A context object that allows input and output from the task.
|
class |
TaskReport
A report on the state of a task.
|
class |
TaskTrackerInfo
Information about TaskTracker.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CounterGroupBase<T extends Counter>
The common counter group interface.
|
Modifier and Type | Class and Description |
---|---|
class |
BigDecimalSplitter
Implement DBSplitter over BigDecimal values.
|
class |
BooleanSplitter
Implement DBSplitter over boolean values.
|
class |
DataDrivenDBInputFormat<T extends DBWritable>
A InputFormat that reads input data from an SQL table.
|
static class |
DataDrivenDBInputFormat.DataDrivenDBInputSplit
A InputSplit that spans a set of rows
|
class |
DataDrivenDBRecordReader<T extends DBWritable>
A RecordReader that reads records from a SQL table,
using data-driven WHERE clause splits.
|
class |
DateSplitter
Implement DBSplitter over date/time values.
|
static class |
DBInputFormat.DBInputSplit
A InputSplit that spans a set of rows
|
static class |
DBInputFormat.NullDBWritable
A Class that does nothing, implementing DBWritable
|
class |
DBOutputFormat.DBRecordWriter
A RecordWriter that writes the reduce output to a SQL table
|
class |
DBRecordReader<T extends DBWritable>
A RecordReader that reads records from a SQL table.
|
interface |
DBSplitter
DBSplitter will generate DBInputSplits to use with DataDrivenDBInputFormat.
|
class |
FloatSplitter
Implement DBSplitter over floating-point values.
|
class |
IntegerSplitter
Implement DBSplitter over integer values.
|
class |
MySQLDataDrivenDBRecordReader<T extends DBWritable>
A RecordReader that reads records from a MySQL table via DataDrivenDBRecordReader
|
class |
MySQLDBRecordReader<T extends DBWritable>
A RecordReader that reads records from a MySQL table.
|
class |
OracleDataDrivenDBInputFormat<T extends DBWritable>
A InputFormat that reads input data from an SQL table in an Oracle db.
|
class |
OracleDataDrivenDBRecordReader<T extends DBWritable>
A RecordReader that reads records from a Oracle table via DataDrivenDBRecordReader
|
class |
OracleDateSplitter
Implement DBSplitter over date/time values returned by an Oracle db.
|
class |
OracleDBRecordReader<T extends DBWritable>
A RecordReader that reads records from an Oracle SQL table.
|
class |
TextSplitter
Implement DBSplitter over text strings.
|
Modifier and Type | Class and Description |
---|---|
class |
FileInputFormatCounter |
class |
LineRecordReader
Treats keys as offset in file and value as line.
|
Modifier and Type | Class and Description |
---|---|
class |
ControlledJob
This class encapsulates a MapReduce job and its dependency.
|
class |
JobControl
This class encapsulates a set of MapReduce jobs and its dependency.
|
Modifier and Type | Class and Description |
---|---|
class |
Parser
Very simple shift-reduce parser for join expressions.
|
static class |
Parser.Node |
static class |
Parser.NodeToken |
static class |
Parser.NumToken |
static class |
Parser.StrToken |
static class |
Parser.Token
Tagged-union type for tokens from the join expression.
|
static class |
Parser.TType |
Modifier and Type | Class and Description |
---|---|
class |
WrappedMapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
A
Mapper which wraps a given one to allow custom
Mapper.Context implementations. |
class |
WrappedMapper.Context |
Modifier and Type | Class and Description |
---|---|
class |
FileOutputFormatCounter |
class |
PartialFileOutputCommitter
An
OutputCommitter that commits files specified
in job output directory i.e. |
interface |
PartialOutputCommitter
Interface for an
OutputCommitter
implementing partial commit of task output, as during preemption. |
Modifier and Type | Class and Description |
---|---|
class |
BinaryPartitioner<V>
Partition
BinaryComparable keys using a configurable part of
the bytes array returned by BinaryComparable.getBytes() . |
Modifier and Type | Class and Description |
---|---|
class |
WrappedReducer<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
A
Reducer which wraps a given one to allow for custom
Reducer.Context implementations. |
class |
WrappedReducer.Context |
Modifier and Type | Class and Description |
---|---|
class |
TokenCache
This class provides user facing APIs for transferring secrets from
the job client to the tasks.
|
Modifier and Type | Interface and Description |
---|---|
interface |
JTConfig
Place holder for JobTracker server-level configuration.
|
Modifier and Type | Interface and Description |
---|---|
interface |
TTConfig
Place holder for TaskTracker server-level configuration.
|
Modifier and Type | Class and Description |
---|---|
interface |
Checkpointable
Contract representing to the framework that the task can be safely preempted
and restarted between invocations of the user-defined function.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CancelDelegationTokenRequest
The request issued by the client to the
ResourceManager to cancel a
delegation token. |
interface |
CancelDelegationTokenResponse
The response from the
ResourceManager to a cancelDelegationToken
request. |
interface |
GetDelegationTokenRequest |
interface |
RenewDelegationTokenRequest
The request issued by the client to renew a delegation token from
the
ResourceManager . |
interface |
RenewDelegationTokenResponse
The response to a renewDelegationToken call to the
ResourceManager . |
Modifier and Type | Class and Description |
---|---|
class |
JHAdminConfig
Stores Job History configuration keys that can be set by administrators of
the Job History server.
|
Modifier and Type | Class and Description |
---|---|
class |
MRWebAppUtil |
Modifier and Type | Class and Description |
---|---|
class |
ContextFactory
Factory class for creating MetricsContext objects.
|
interface |
MetricsContext
The main interface to the metrics package.
|
class |
MetricsException
General-purpose, unchecked metrics exception.
|
interface |
MetricsRecord
A named and optionally tagged set of records to be sent to the metrics
system.
|
class |
MetricsServlet
A servlet to print out metrics data.
|
class |
MetricsUtil
Utility class to simplify creation and reporting of hadoop metrics.
|
interface |
Updater
Call-back interface.
|
Modifier and Type | Class and Description |
---|---|
class |
FileContext
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
GangliaContext
Context for sending metrics to Ganglia.
|
Modifier and Type | Class and Description |
---|---|
class |
JvmMetrics
Singleton class which reports Java Virtual Machine metrics to the metrics API.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractMetricsContext
The main class of the Service Provider Interface.
|
class |
CompositeContext |
class |
MetricsRecordImpl
An implementation of MetricsRecord.
|
class |
MetricValue
A Number that is either an absolute or an incremental amount.
|
class |
NoEmitMetricsContext
A MetricsContext that does not emit data, but, unlike NullContextWithUpdate,
does save it for retrieval with getAllRecords().
|
class |
NullContext
Null metrics context: a metrics context which does nothing.
|
class |
NullContextWithUpdateThread
A null context which has a thread calling
periodically when monitoring is started.
|
class |
OutputRecord
Represents a record of metric data to be sent to a metrics system.
|
class |
Util
Static utility methods
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractMetric
The immutable metric
|
interface |
MetricsCollector
The metrics collector interface
|
class |
MetricsException
A general metrics exception wrapper
|
class |
MetricsFilter
The metrics filter interface
|
interface |
MetricsInfo
Interface to provide immutable meta info for metrics
|
interface |
MetricsPlugin
The plugin interface for the metrics framework
|
interface |
MetricsRecord
An immutable snapshot of metrics with a timestamp
|
class |
MetricsRecordBuilder
The metrics record builder interface
|
interface |
MetricsSink
The metrics sink interface
|
interface |
MetricsSource
The metrics source interface
|
class |
MetricsSystem
The metrics system interface
|
interface |
MetricsSystemMXBean
The JMX interface to the metrics system
|
class |
MetricsTag
Immutable tag for metrics (for grouping on host/queue/username etc.)
|
interface |
MetricsVisitor
A visitor interface for metrics
|
Modifier and Type | Class and Description |
---|---|
interface |
Metric
Annotation interface for a single metric
|
interface |
Metrics
Annotation interface for a group of metrics
|
Modifier and Type | Class and Description |
---|---|
class |
GlobFilter
A glob pattern filter for metrics.
|
class |
RegexFilter
A regex pattern filter for metrics
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultMetricsSystem
The default metrics system singleton
|
class |
Interns
Helpers to create interned metrics info
|
class |
MetricsAnnotations
Metrics annotation helpers.
|
class |
MetricsRegistry
An optional metrics registry class for creating and maintaining a
collection of MetricsMutables, making writing metrics source easier.
|
class |
MutableCounter
The mutable counter (monotonically increasing) metric interface
|
class |
MutableCounterInt
A mutable int counter for implementing metrics sources
|
class |
MutableCounterLong
A mutable long counter
|
class |
MutableGauge
The mutable gauge metric interface
|
class |
MutableGaugeInt
A mutable int gauge
|
class |
MutableGaugeLong
A mutable long gauge
|
class |
MutableMetric
The mutable metric interface
|
class |
MutableMetricsFactory |
class |
MutableQuantiles
Watches a stream of long values, maintaining online estimates of specific
quantiles with provably low error bounds.
|
class |
MutableRate
A convenient mutable metric for throughput measurement
|
class |
MutableRates
Helper class to manage a group of mutable rate metrics
|
class |
MutableStat
A mutable metric with stats.
|
Modifier and Type | Class and Description |
---|---|
class |
FileSink
A metrics sink that writes to a file
|
Modifier and Type | Class and Description |
---|---|
class |
MetricsCache
A metrics cache for sinks that don't support sparse updates.
|
class |
Servers
Helpers to handle server addresses
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractDNSToSwitchMapping
This is a base class for DNS to Switch mappings.
|
class |
CachedDNSToSwitchMapping
A cached implementation of DNSToSwitchMapping that takes an
raw DNSToSwitchMapping and stores the resolved network location in
a cache.
|
interface |
DNSToSwitchMapping
An interface that must be implemented to allow pluggable
DNS-name/IP-address to RackID resolvers.
|
class |
ScriptBasedMapping
This class implements the
DNSToSwitchMapping interface using a
script configured via the
CommonConfigurationKeysPublic.NET_TOPOLOGY_SCRIPT_FILE_NAME_KEY option. |
class |
SocksSocketFactory
Specialized SocketFactory to create sockets with a SOCKS proxy
|
class |
StandardSocketFactory
Specialized SocketFactory to create sockets with a SOCKS proxy
|
class |
TableMapping
Simple
DNSToSwitchMapping implementation that reads a 2 column text
file. |
Modifier and Type | Class and Description |
---|---|
class |
AccessControlException
An exception class for access control related issues.
|
class |
Credentials
A class that provides the facilities of reading and writing
secret keys and Tokens.
|
interface |
GroupMappingServiceProvider
An interface for the implementation of a user-to-groups mapping service
used by
Groups . |
class |
Groups
A user-to-groups mapping service.
|
class |
HadoopKerberosName
This class implements parsing and handling of Kerberos principal names.
|
class |
JniBasedUnixGroupsMapping
A JNI-based implementation of
GroupMappingServiceProvider
that invokes libC calls to get the group
memberships of a given user. |
class |
JniBasedUnixGroupsNetgroupMapping
A JNI-based implementation of
GroupMappingServiceProvider
that invokes libC calls to get the group
memberships of a given user. |
interface |
KerberosInfo
Indicates Kerberos related information to be used
|
class |
LdapGroupsMapping
An implementation of
GroupMappingServiceProvider which
connects directly to an LDAP server for determining group membership. |
interface |
RefreshUserMappingsProtocol
Protocol use
|
class |
SaslInputStream
A SaslInputStream is composed of an InputStream and a SaslServer (or
SaslClient) so that read() methods return data that are read in from the
underlying InputStream but have been additionally processed by the SaslServer
(or SaslClient) object.
|
class |
SaslOutputStream
A SaslOutputStream is composed of an OutputStream and a SaslServer (or
SaslClient) so that write() methods first process the data before writing
them out to the underlying OutputStream.
|
class |
SaslPlainServer |
class |
SaslRpcClient
A utility class that encapsulates SASL logic for RPC client
|
class |
SaslRpcServer
A utility class for dealing with SASL on RPC server
|
static class |
SaslRpcServer.AuthMethod
Authentication method
|
static class |
SaslRpcServer.SaslDigestCallbackHandler
CallbackHandler for SASL DIGEST-MD5 mechanism
|
static class |
SaslRpcServer.SaslGssCallbackHandler
CallbackHandler for SASL GSSAPI Kerberos mechanism
|
class |
SecurityInfo |
class |
SecurityUtil |
class |
ShellBasedUnixGroupsMapping
A simple shell-based implementation of
GroupMappingServiceProvider
that exec's the groups shell command to fetch the group
memberships of a given user. |
class |
ShellBasedUnixGroupsNetgroupMapping
A simple shell-based implementation of
GroupMappingServiceProvider
that exec's the groups shell command to fetch the group
memberships of a given user. |
class |
UserGroupInformation
User and group information for Hadoop.
|
static class |
UserGroupInformation.AuthenticationMethod
existing types of authentications' methods
|
Modifier and Type | Method and Description |
---|---|
static UserGroupInformation |
UserGroupInformation.createProxyUser(String user,
UserGroupInformation realUser)
Create a proxy user using username of the effective user and the ugi of the
real user.
|
static UserGroupInformation |
UserGroupInformation.createRemoteUser(String user)
Create a user from a login name.
|
static UserGroupInformation |
UserGroupInformation.createUserForTesting(String user,
String[] userGroups)
Create a UGI for testing HDFS and MapReduce
|
<T> T |
UserGroupInformation.doAs(PrivilegedAction<T> action)
Run the given action as the user.
|
<T> T |
UserGroupInformation.doAs(PrivilegedExceptionAction<T> action)
Run the given action as the user, potentially throwing an exception.
|
static UserGroupInformation |
UserGroupInformation.getCurrentUser()
Return the current user, including any doAs in the current stack.
|
static UserGroupInformation |
UserGroupInformation.getLoginUser()
Get the currently logged in user.
|
UserGroupInformation |
UserGroupInformation.getRealUser()
get RealUser (vs.
|
static String |
SecurityUtil.getServerPrincipal(String principalConfig,
InetAddress addr)
Convert Kerberos principal name pattern to valid Kerberos principal names.
|
static String |
SecurityUtil.getServerPrincipal(String principalConfig,
String hostname)
Convert Kerberos principal name pattern to valid Kerberos principal
names.
|
static UserGroupInformation |
UserGroupInformation.getUGIFromTicketCache(String ticketCache,
String user)
Create a UserGroupInformation from a Kerberos ticket cache.
|
String |
UserGroupInformation.getUserName()
Get the user's full principal name.
|
static boolean |
UserGroupInformation.isLoginKeytabBased()
Did the login happen via keytab
|
static void |
SecurityUtil.login(Configuration conf,
String keytabFileKey,
String userNameKey)
Login as a principal specified in config.
|
static void |
SecurityUtil.login(Configuration conf,
String keytabFileKey,
String userNameKey,
String hostname)
Login as a principal specified in config.
|
static void |
UserGroupInformation.loginUserFromKeytab(String user,
String path)
Log a user in from a keytab file.
|
void |
UserGroupInformation.reloginFromKeytab()
Re-Login a user in from a keytab file.
|
void |
UserGroupInformation.reloginFromTicketCache()
Re-Login a user in from the ticket cache.
|
static void |
UserGroupInformation.setConfiguration(Configuration conf)
Set the static configuration for UGI.
|
Modifier and Type | Class and Description |
---|---|
class |
KerberosName
This class implements parsing and handling of Kerberos principal names.
|
Modifier and Type | Class and Description |
---|---|
class |
AccessControlList
Class representing a configured access control list.
|
class |
AuthorizationException
An exception class for authorization-related issues.
|
class |
PolicyProvider
|
interface |
RefreshAuthorizationPolicyProtocol
Protocol which is used to refresh the authorization policy in use currently.
|
class |
Service
An abstract definition of service as related to
Service Level Authorization for Hadoop.
|
class |
ServiceAuthorizationManager
An authorization manager which handles service-level authorization
for incoming service requests.
|
Modifier and Type | Interface and Description |
---|---|
interface |
RefreshAuthorizationPolicyProtocolPB |
interface |
RefreshUserMappingsProtocolPB |
Modifier and Type | Class and Description |
---|---|
class |
FileBasedKeyStoresFactory
KeyStoresFactory implementation that reads the certificates from
keystore files. |
interface |
KeyStoresFactory
Interface that gives access to
KeyManager and TrustManager
implementations. |
class |
ReloadingX509TrustManager
A
TrustManager implementation that reloads its configuration when
the truststore file on disk changes. |
class |
SSLFactory
Factory that creates SSLEngine and SSLSocketFactory instances using
Hadoop configuration information.
|
interface |
SSLHostnameVerifier
Copied from the not-yet-commons-ssl project at
http://juliusdavies.ca/commons-ssl/
This project is not yet in Apache, but it is Apache 2.0 licensed.
|
Modifier and Type | Class and Description |
---|---|
class |
SecretManager<T extends TokenIdentifier>
The server-side secret manager for each token type.
|
static class |
SecretManager.InvalidToken
The token was invalid and the message explains why.
|
class |
Token<T extends TokenIdentifier>
The client-side form of the token.
|
static class |
Token.TrivialRenewer
A trivial renewer for token kinds that aren't managed.
|
class |
TokenIdentifier
An identifier that identifies a token, may contain public information
about a token, including its kind (or type).
|
interface |
TokenInfo
Indicates Token related information to be used
|
class |
TokenRenewer
This is the interface for plugins that handle tokens.
|
interface |
TokenSelector<T extends TokenIdentifier>
Select token of type T from tokens for use with named service
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractDelegationTokenIdentifier |
class |
AbstractDelegationTokenSecretManager<TokenIdent extends AbstractDelegationTokenIdentifier> |
static class |
AbstractDelegationTokenSecretManager.DelegationTokenInformation
Class to encapsulate a token's renew date and password.
|
class |
AbstractDelegationTokenSelector<TokenIdent extends AbstractDelegationTokenIdentifier>
Look through tokens to find the first delegation token that matches the
service and return it.
|
class |
DelegationKey
Key used for generating and verifying delegation tokens
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractService
This is the base implementation class for services.
|
class |
CompositeService
Composition of services.
|
class |
LifecycleEvent
A serializable lifecycle event: the time a state
transition occurred, and what state was entered.
|
class |
LoggingStateChangeListener
This is a state change listener that logs events at INFO level
|
interface |
Service
Service LifeCycle.
|
class |
ServiceOperations
This class contains a set of methods to work with services, especially
to walk them through their lifecycle.
|
class |
ServiceStateException
Exception that is raised on state change operations.
|
class |
ServiceStateModel
Implements the service state model.
|
Modifier and Type | Interface and Description |
---|---|
interface |
GetUserMappingsProtocol
Protocol implemented by the Name Node and Job Tracker which maps users to
groups.
|
Modifier and Type | Interface and Description |
---|---|
interface |
GetUserMappingsProtocolPB |
Modifier and Type | Class and Description |
---|---|
class |
DataChecksum
This class provides inteface and utilities for processing checksums for
DFS data transfers.
|
class |
GenericOptionsParser
GenericOptionsParser is a utility to parse command line
arguments generic to the Hadoop framework. |
class |
ReflectionUtils
General reflection utils
|
class |
ThreadUtil |
Modifier and Type | Class and Description |
---|---|
class |
YarnUncaughtExceptionHandler
This class is intended to be installed by calling
Thread.setDefaultUncaughtExceptionHandler(UncaughtExceptionHandler)
In the main entry point. |
Modifier and Type | Interface and Description |
---|---|
interface |
ApplicationConstants
This is the API for the applications comprising of constants that YARN sets
up for the applications and the containers.
|
Modifier and Type | Method and Description |
---|---|
abstract PreemptionMessage |
AllocateResponse.getPreemptionMessage()
Get the description of containers owned by the AM, but requested back by
the cluster.
|
Modifier and Type | Class and Description |
---|---|
class |
PreemptionContainer
Specific container requested back by the
ResourceManager . |
class |
PreemptionContract
Description of resources requested back by the
ResourceManager . |
class |
PreemptionMessage
A
PreemptionMessage is part of the RM-AM protocol, and it is used by
the RM to specify resources that the RM wants to reclaim from this
ApplicationMaster (AM). |
class |
PreemptionResourceRequest
Description of resources requested back by the cluster.
|
class |
StrictPreemptionContract
Enumeration of particular allocations to be reclaimed.
|
Modifier and Type | Method and Description |
---|---|
abstract Set<PreemptionContainer> |
PreemptionContract.getContainers()
Assign the set of
PreemptionContainer specifying which containers
owned by the ApplicationMaster that may be reclaimed by the
ResourceManager . |
abstract Set<PreemptionContainer> |
StrictPreemptionContract.getContainers()
Get the set of
PreemptionContainer specifying containers owned by
the ApplicationMaster that may be reclaimed by the
ResourceManager . |
abstract PreemptionContract |
PreemptionMessage.getContract() |
abstract ContainerId |
PreemptionContainer.getId() |
abstract List<PreemptionResourceRequest> |
PreemptionContract.getResourceRequest()
If the AM releases resources matching these requests, then the
PreemptionContainer s enumerated in PreemptionContract.getContainers() should not be
evicted from the cluster. |
abstract ResourceRequest |
PreemptionResourceRequest.getResourceRequest() |
abstract StrictPreemptionContract |
PreemptionMessage.getStrictContract() |
abstract int |
Resource.getVirtualCores()
Get number of virtual cpu cores of the resource.
|
abstract void |
Resource.setVirtualCores(int vCores)
Set number of virtual cpu cores of the resource.
|
Modifier and Type | Class and Description |
---|---|
class |
RMProxy<T> |
Modifier and Type | Class and Description |
---|---|
class |
NMTokenCache
It manages NMTokens required for communicating with Node manager.
|
Modifier and Type | Method and Description |
---|---|
static Token |
NMTokenCache.getNMToken(String nodeAddr)
Returns NMToken, null if absent
|
static void |
NMTokenCache.setNMToken(String nodeAddr,
Token token)
Sets the NMToken for node address
|
Modifier and Type | Class and Description |
---|---|
class |
LogsCLI |
Modifier and Type | Class and Description |
---|---|
class |
YarnConfiguration |
Modifier and Type | Class and Description |
---|---|
class |
AbstractEvent<TYPE extends Enum<TYPE>>
Parent class of all the events.
|
class |
AsyncDispatcher
Dispatches
Event s in a separate thread. |
interface |
Dispatcher
Event Dispatcher interface.
|
interface |
Event<TYPE extends Enum<TYPE>>
Interface defining events api.
|
interface |
EventHandler<T extends Event>
Interface for handling events of type T
|
Modifier and Type | Class and Description |
---|---|
class |
AggregatedLogFormat |
static class |
AggregatedLogFormat.LogReader |
Modifier and Type | Class and Description |
---|---|
class |
AMRMTokenIdentifier
AMRMTokenIdentifier is the TokenIdentifier to be used by
ApplicationMasters to authenticate to the ResourceManager.
|
class |
AMRMTokenSelector |
class |
ContainerTokenIdentifier
TokenIdentifier for a container.
|
class |
NMTokenIdentifier |
Modifier and Type | Class and Description |
---|---|
class |
BaseClientToAMTokenSecretManager
A base
SecretManager for AMs to extend and validate Client-RM tokens
issued to clients by the RM using the underlying master-key shared by RM to
the AMs on their launch. |
class |
ClientToAMTokenIdentifier |
class |
ClientToAMTokenSecretManager
A simple
SecretManager for AMs to validate Client-RM tokens issued to
clients by the RM using the underlying master-key shared by RM to the AMs on
their launch. |
class |
RMDelegationTokenIdentifier
Delegation Token Identifier that identifies the delegation tokens from the
Resource Manager.
|
Modifier and Type | Class and Description |
---|---|
class |
ApplicationInitializationContext
Initialization context for
AuxiliaryService when starting an
application. |
class |
ApplicationTerminationContext
Initialization context for
AuxiliaryService when stopping an
application. |
class |
AuxiliaryService
A generic service that will be started by the NodeManager.
|
class |
ContainerContext
Base context class for
AuxiliaryService initializing and stopping a
container. |
class |
ContainerInitializationContext
Initialization context for
AuxiliaryService when starting a
container. |
class |
ContainerTerminationContext
Termination context for
AuxiliaryService when stopping a
container. |
Modifier and Type | Class and Description |
---|---|
class |
ResourceType |
class |
ResourceWeights |
Modifier and Type | Interface and Description |
---|---|
interface |
Queue |
interface |
ResourceScheduler
This interface is the one implemented by the schedulers.
|
class |
SchedulerAppReport
Represents an application attempt, and the resources that the attempt is
using.
|
Modifier and Type | Method and Description |
---|---|
QueueMetrics |
YarnScheduler.getRootQueueMetrics()
Get the root queue for the scheduler.
|
Modifier and Type | Class and Description |
---|---|
class |
CapacityScheduler |
class |
ParentQueue |
Modifier and Type | Class and Description |
---|---|
class |
FairSchedulerConfiguration |
class |
SchedulingPolicy |
Modifier and Type | Class and Description |
---|---|
class |
FifoScheduler |
Modifier and Type | Class and Description |
---|---|
class |
InvalidStateTransitonException |
interface |
MultipleArcTransition<OPERAND,EVENT,STATE extends Enum<STATE>>
Hook for Transition.
|
interface |
SingleArcTransition<OPERAND,EVENT>
Hook for Transition.
|
interface |
StateMachine<STATE extends Enum<STATE>,EVENTTYPE extends Enum<EVENTTYPE>,EVENT> |
class |
StateMachineFactory<OPERAND,STATE extends Enum<STATE>,EVENTTYPE extends Enum<EVENTTYPE>,EVENT>
State machine topology.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractLivelinessMonitor<O>
A simple liveliness monitor with which clients can register, trust the
component to monitor liveliness, get a call-back on expiry and then finally
unregister.
|
Modifier and Type | Class and Description |
---|---|
class |
WebAppUtils |
Copyright © 2013 Apache Software Foundation. All rights reserved.