Package | Description |
---|---|
org.apache.hadoop.mapreduce.protocol |
Modifier and Type | Class and Description |
---|---|
class |
HadoopIllegalArgumentException
Indicates that a method has been passed illegal or invalid argument.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Configurable
Something that may be configured with a
Configuration . |
class |
Configuration
Provides access to configuration parameters.
|
class |
Configured
Base class for things that may be configured with a
Configuration . |
Modifier and Type | Class and Description |
---|---|
class |
DistributedCache
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
AvroFSInput
Adapts an
FSDataInputStream to Avro's SeekableInput interface. |
class |
BlockLocation
Represents the network location of a block, information about the hosts
that contain block replicas, and other block metadata (E.g.
|
class |
ChecksumException
Thrown for checksum errors.
|
class |
ChecksumFileSystem
Abstract Checksumed FileSystem.
|
class |
FileAlreadyExistsException
Used when target file already exists for any operation and
is not configured to be overwritten.
|
class |
FileChecksum
An abstract class representing file checksums for files.
|
class |
FileStatus
Interface that represents the client side information for a file.
|
class |
FileSystem
An abstract base class for a fairly generic filesystem.
|
class |
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. |
interface |
FsConstants
FileSystem related constants.
|
class |
FSDataInputStream
Utility that wraps a
FSInputStream in a DataInputStream
and buffers input through a BufferedInputStream . |
class |
FSDataOutputStream
Utility that wraps a
OutputStream in a DataOutputStream ,
buffers output through a BufferedOutputStream and creates a checksum
file. |
class |
FSError
Thrown for unexpected filesystem errors, presumed to reflect disk errors
in the native filesystem.
|
class |
FsStatus
This class is used to represent the capacity, free and used space on a
FileSystem . |
class |
InvalidPathException
Path string is invalid either because it has invalid characters or due to
other file system specific reasons.
|
class |
LocalFileSystem
Implement the FileSystem API for the checksumed local filesystem.
|
class |
ParentNotDirectoryException
Indicates that the parent of specified Path is not a directory
as expected.
|
class |
Path
Names a file or directory in a
FileSystem . |
interface |
PathFilter |
class |
RawLocalFileSystem
Implement the FileSystem API for the raw local filesystem.
|
class |
Trash
Provides a trash facility which supports pluggable Trash policies.
|
class |
UnresolvedLinkException
Thrown when a symbolic link is encountered in a path.
|
class |
UnsupportedFileSystemException
File system for a given file system name/scheme is not supported
|
Modifier and Type | Class and Description |
---|---|
class |
FTPException
A class to wrap a
Throwable into a Runtime Exception. |
class |
FTPFileSystem
A
FileSystem backed by an FTP client provided by Apache Commons Net. |
Modifier and Type | Class and Description |
---|---|
class |
AccessControlException
Deprecated.
Use
AccessControlException
instead. |
class |
FsPermission
A class for file/directory permissions.
|
Modifier and Type | Class and Description |
---|---|
class |
S3Exception
Thrown if there is a problem communicating with Amazon S3.
|
class |
S3FileSystem
A block-based
FileSystem backed by
Amazon S3. |
class |
S3FileSystemException
Thrown when there is a fatal exception while using
S3FileSystem . |
class |
VersionMismatchException
Thrown when Hadoop cannot read the version of the data stored
in
S3FileSystem . |
Modifier and Type | Class and Description |
---|---|
class |
NativeS3FileSystem
A
FileSystem for reading and writing files stored on
Amazon S3. |
Modifier and Type | Class and Description |
---|---|
class |
HAServiceProtocolClientSideTranslatorPB
This class is the client side translator to translate the requests made on
HAServiceProtocol interfaces to the RPC server implementing
HAServiceProtocolPB . |
class |
HAServiceProtocolServerSideTranslatorPB
This class is used on the server side.
|
class |
ZKFCProtocolServerSideTranslatorPB |
Modifier and Type | Class and Description |
---|---|
class |
ClientDatanodeProtocolTranslatorPB
This class is the client side translator to translate the requests made on
ClientDatanodeProtocol interfaces to the RPC server implementing
ClientDatanodeProtocolPB . |
interface |
ClientNamenodeProtocolPB |
class |
ClientNamenodeProtocolServerSideTranslatorPB
This class is used on the server side.
|
class |
ClientNamenodeProtocolTranslatorPB
This class forwards NN's ClientProtocol calls as RPC calls to the NN server
while translating from the parameter types used in ClientProtocol to the
new PB types.
|
class |
DatanodeProtocolClientSideTranslatorPB
This class is the client side translator to translate the requests made on
DatanodeProtocol interfaces to the RPC server implementing
DatanodeProtocolPB . |
class |
InterDatanodeProtocolTranslatorPB
This class is the client side translator to translate the requests made on
InterDatanodeProtocol interfaces to the RPC server implementing
InterDatanodeProtocolPB . |
class |
JournalProtocolTranslatorPB
This class is the client side translator to translate the requests made on
JournalProtocol interfaces to the RPC server implementing
JournalProtocolPB . |
class |
NamenodeProtocolTranslatorPB
This class is the client side translator to translate the requests made on
NamenodeProtocol interfaces to the RPC server implementing
NamenodeProtocolPB . |
Modifier and Type | Class and Description |
---|---|
class |
QJournalProtocolTranslatorPB
This class is the client side translator to translate the requests made on
JournalProtocol interfaces to the RPC server implementing
JournalProtocolPB . |
Modifier and Type | Interface and Description |
---|---|
interface |
DataNodeMXBean
This is the JMX management interface for data node information
|
Modifier and Type | Interface and Description |
---|---|
interface |
NameNodeMXBean
This is the JMX management interface for namenode information
|
Modifier and Type | Class and Description |
---|---|
class |
ByteBufferOutputStream
OutputStream that writes into a
ByteBuffer . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMapWritable
Abstract base class for MapWritable and SortedMapWritable
Unlike org.apache.nutch.crawl.MapWritable, this class allows creation of
MapWritable<Writable, MapWritable> so the CLASS_TO_ID and ID_TO_CLASS
maps travel with the class instead of being static.
|
class |
ArrayFile
A dense file-based mapping from integers to values.
|
class |
ArrayPrimitiveWritable
This is a wrapper class.
|
class |
ArrayWritable
A Writable for arrays containing instances of a class.
|
class |
BinaryComparable
Interface supported by
WritableComparable
types supporting ordering/permutation by a representative set of bytes. |
class |
BloomMapFile
This class extends
MapFile and provides very much the same
functionality. |
class |
BooleanWritable
A WritableComparable for booleans.
|
class |
BytesWritable
A byte sequence that is usable as a key or value.
|
class |
ByteWritable
A WritableComparable for a single byte.
|
interface |
Closeable
Deprecated.
use java.io.Closeable
|
class |
CompressedWritable
A base-class for Writables which store themselves compressed and lazily
inflate on field access.
|
class |
DefaultStringifier<T>
DefaultStringifier is the default implementation of the
Stringifier
interface which stringifies the objects using base64 encoding of the
serialized version of the objects. |
class |
DoubleWritable
Writable for Double values.
|
class |
EnumSetWritable<E extends Enum<E>>
A Writable wrapper for EnumSet.
|
class |
FloatWritable
A WritableComparable for floats.
|
class |
GenericWritable
A wrapper for Writable instances.
|
class |
IntWritable
A WritableComparable for ints.
|
class |
LongWritable
A WritableComparable for longs.
|
class |
MapFile
A file-based map from keys to values.
|
class |
MapWritable
A Writable Map.
|
class |
MD5Hash
A Writable for MD5 hash values.
|
class |
MultipleIOException
Encapsulate a list of
IOException into an IOException |
class |
NullWritable
Singleton Writable with no data.
|
class |
ObjectWritable
A polymorphic Writable that writes an instance with it's class name.
|
interface |
RawComparator<T>
A
Comparator that operates directly on byte representations of
objects. |
class |
SequenceFile
SequenceFile s are flat files consisting of binary key/value
pairs. |
class |
SetFile
A file-based set of keys.
|
class |
ShortWritable
A WritableComparable for shorts.
|
class |
SortedMapWritable
A Writable SortedMap.
|
interface |
Stringifier<T>
Stringifier interface offers two methods to convert an object
to a string representation and restore the object given its
string representation.
|
class |
Text
This class stores text using standard UTF8 encoding.
|
class |
TwoDArrayWritable
A Writable for 2D arrays containing a matrix of instances of a class.
|
class |
UTF8
Deprecated.
replaced by Text
|
class |
VersionedWritable
A base class for Writables that provides version checking.
|
class |
VersionMismatchException
Thrown by
VersionedWritable.readFields(DataInput) when the
version of an object being read does not match the current implementation
version as returned by VersionedWritable.getVersion() . |
class |
VIntWritable
A WritableComparable for integer values stored in variable-length format.
|
class |
VLongWritable
A WritableComparable for longs in a variable-length format.
|
interface |
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
interface |
WritableComparable<T>
A
Writable which is also Comparable . |
class |
WritableComparator
A Comparator for
WritableComparable s. |
class |
WritableFactories
Factories for non-public writables.
|
interface |
WritableFactory
A factory for a class of Writable.
|
class |
WritableUtils |
Modifier and Type | Class and Description |
---|---|
class |
MetaBlockAlreadyExists
Exception - Meta Block with the same name already exists.
|
class |
MetaBlockDoesNotExist
Exception - No such Meta Block with the given name.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ProtocolMetaInterface
This interface is implemented by the client side translators and can be used
to obtain information about underlying protocol e.g.
|
Modifier and Type | Class and Description |
---|---|
class |
EventCounter
A log4J Appender that simply counts logging events in three levels:
fatal, error and warn.
|
Modifier and Type | Class and Description |
---|---|
class |
ClusterStatus
Status information on the current state of the Map-Reduce cluster.
|
class |
Counters
A set of named counters.
|
static class |
Counters.Counter
A counter record, comprising its name and value.
|
static class |
Counters.Group
Group of counters, comprising of counters from a particular
counter Enum class. |
class |
FileAlreadyExistsException
Used when target file already exists for any operation and
is not configured to be overwritten.
|
class |
FileInputFormat<K,V>
A base class for file-based
InputFormat . |
class |
FileOutputCommitter
An
OutputCommitter that commits files specified
in job output directory i.e. |
class |
FileOutputFormat<K,V>
A base class for
OutputFormat . |
class |
FileSplit
A section of an input file.
|
class |
ID
A general identifier, which internally stores the id
as an integer.
|
interface |
InputFormat<K,V>
InputFormat describes the input-specification for a
Map-Reduce job. |
interface |
InputSplit
InputSplit represents the data to be processed by an
individual Mapper . |
class |
InvalidFileTypeException
Used when file type differs from the desired file type.
|
class |
InvalidInputException
This class wraps a list of problems with the input, so that the user
can get a list of problems together instead of finding and fixing them one
by one.
|
class |
InvalidJobConfException
This exception is thrown when jobconf misses some mendatory attributes
or value of some attributes is invalid.
|
class |
JobClient
JobClient is the primary interface for the user-job to interact
with the cluster. |
class |
JobConf
A map/reduce job configuration.
|
interface |
JobConfigurable
That what may be configured.
|
interface |
JobContext |
class |
JobID
JobID represents the immutable and unique identifier for
the job.
|
class |
JobPriority
Used to describe the priority of the running job.
|
class |
JobQueueInfo
Class that contains the information regarding the Job Queues which are
maintained by the Hadoop Map/Reduce framework.
|
class |
JobStatus
Describes the current status of a job.
|
class |
KeyValueLineRecordReader
This class treats a line in the input as a key/value pair separated by a
separator character.
|
class |
KeyValueTextInputFormat
An
InputFormat for plain text files. |
class |
MapFileOutputFormat
An
OutputFormat that writes MapFile s. |
interface |
Mapper<K1,V1,K2,V2>
Maps input key/value pairs to a set of intermediate key/value pairs.
|
class |
MapReduceBase
|
interface |
MapRunnable<K1,V1,K2,V2>
Expert: Generic interface for
Mapper s. |
class |
MapRunner<K1,V1,K2,V2>
Default
MapRunnable implementation. |
class |
MultiFileInputFormat<K,V>
An abstract
InputFormat that returns MultiFileSplit 's
in MultiFileInputFormat.getSplits(JobConf, int) method. |
class |
MultiFileSplit
A sub-collection of input files.
|
interface |
OutputCollector<K,V>
|
class |
OutputCommitter
OutputCommitter describes the commit of task output for a
Map-Reduce job. |
interface |
OutputFormat<K,V>
OutputFormat describes the output-specification for a
Map-Reduce job. |
class |
OutputLogFilter
This class filters log files from directory given
It doesnt accept paths having _logs.
|
interface |
Partitioner<K2,V2>
Partitions the key space.
|
interface |
RecordReader<K,V>
RecordReader reads <key, value> pairs from an
InputSplit . |
interface |
RecordWriter<K,V>
RecordWriter writes the output <key, value> pairs
to an output file. |
interface |
Reducer<K2,V2,K3,V3>
Reduces a set of intermediate values which share a key to a smaller set of
values.
|
interface |
Reporter
A facility for Map-Reduce applications to report progress and update
counters, status information etc.
|
interface |
RunningJob
RunningJob is the user-interface to query for details on a
running Map-Reduce job. |
class |
SequenceFileAsBinaryInputFormat
InputFormat reading keys, values from SequenceFiles in binary (raw)
format.
|
class |
SequenceFileAsBinaryOutputFormat
An
OutputFormat that writes keys, values to
SequenceFile s in binary(raw) format |
class |
SequenceFileAsTextInputFormat
This class is similar to SequenceFileInputFormat,
except it generates SequenceFileAsTextRecordReader
which converts the input keys and values to their
String forms by calling toString() method.
|
class |
SequenceFileAsTextRecordReader
This class converts the input keys and values to their String forms by calling toString()
method.
|
class |
SequenceFileInputFilter<K,V>
A class that allows a map/red job to work on a sample of sequence files.
|
class |
SequenceFileInputFormat<K,V>
An
InputFormat for SequenceFile s. |
class |
SequenceFileOutputFormat<K,V>
An
OutputFormat that writes SequenceFile s. |
class |
SequenceFileRecordReader<K,V>
An
RecordReader for SequenceFile s. |
class |
SkipBadRecords
Utility class for skip bad records functionality.
|
interface |
TaskAttemptContext |
class |
TaskAttemptID
TaskAttemptID represents the immutable and unique identifier for
a task attempt.
|
class |
TaskCompletionEvent
This is used to track task completion events on
job tracker.
|
static class |
TaskCompletionEvent.Status |
class |
TaskID
TaskID represents the immutable and unique identifier for
a Map or Reduce Task.
|
class |
TaskReport
A report on the state of a task.
|
interface |
TaskUmbilicalProtocol
Protocol that task child process uses to contact its parent process.
|
class |
TextInputFormat
An
InputFormat for plain text files. |
class |
TextOutputFormat<K,V>
An
OutputFormat that writes plain text files. |
class |
Utils
A utility class.
|
Modifier and Type | Class and Description |
---|---|
class |
Job |
class |
JobControl |
Modifier and Type | Class and Description |
---|---|
class |
ArrayListBackedIterator<X extends Writable>
This class provides an implementation of ResetableIterator.
|
interface |
ComposableInputFormat<K extends WritableComparable,V extends Writable>
Refinement of InputFormat requiring implementors to provide
ComposableRecordReader instead of RecordReader.
|
interface |
ComposableRecordReader<K extends WritableComparable,V extends Writable>
Additional operations required of a RecordReader to participate in a join.
|
class |
CompositeInputFormat<K extends WritableComparable>
An InputFormat capable of performing joins over a set of data sources sorted
and partitioned the same way.
|
class |
CompositeInputSplit
This InputSplit contains a set of child InputSplits.
|
class |
CompositeRecordReader<K extends WritableComparable,V extends Writable,X extends Writable>
A RecordReader that can effect joins of RecordReaders sharing a common key
type and partitioning.
|
class |
InnerJoinRecordReader<K extends WritableComparable>
Full inner join.
|
class |
JoinRecordReader<K extends WritableComparable>
Base class for Composite joins returning Tuples of arbitrary Writables.
|
class |
MultiFilterRecordReader<K extends WritableComparable,V extends Writable>
Base class for Composite join returning values derived from multiple
sources, but generally not tuples.
|
class |
OuterJoinRecordReader<K extends WritableComparable>
Full outer join.
|
class |
OverrideRecordReader<K extends WritableComparable,V extends Writable>
Prefer the "rightmost" data source for this key.
|
interface |
ResetableIterator<T extends Writable>
This defines an interface to a stateful Iterator that can replay elements
added to it directly.
|
class |
StreamBackedIterator<X extends Writable>
This class provides an implementation of ResetableIterator.
|
class |
TupleWritable
Writable type storing multiple
Writable s. |
class |
WrappedRecordReader<K extends WritableComparable,U extends Writable>
Proxy class for a RecordReader participating in the join framework.
|
Modifier and Type | Class and Description |
---|---|
class |
BinaryPartitioner<V>
Partition
BinaryComparable keys using a configurable part of
the bytes array returned by BinaryComparable.getBytes() . |
class |
ChainMapper
The ChainMapper class allows to use multiple Mapper classes within a single
Map task.
|
class |
ChainReducer
The ChainReducer class allows to chain multiple Mapper classes after a
Reducer within the Reducer task.
|
class |
CombineFileInputFormat<K,V>
An abstract
InputFormat that returns CombineFileSplit 's
in InputFormat.getSplits(JobConf, int) method. |
class |
CombineFileRecordReader<K,V>
A generic RecordReader that can hand out different recordReaders
for each chunk in a
CombineFileSplit . |
class |
CombineFileRecordReaderWrapper<K,V>
A wrapper class for a record reader that handles a single file split.
|
class |
CombineFileSplit |
class |
CombineSequenceFileInputFormat<K,V>
Input format that is a
CombineFileInputFormat -equivalent for
SequenceFileInputFormat . |
class |
CombineTextInputFormat
Input format that is a
CombineFileInputFormat -equivalent for
TextInputFormat . |
class |
FieldSelectionMapReduce<K,V>
This class implements a mapper/reducer class that can be used to perform
field selections in a manner similar to unix cut.
|
class |
FilterOutputFormat<K,V>
FilterOutputFormat is a convenience class that wraps OutputFormat.
|
class |
HashPartitioner<K2,V2>
Partition keys by their
Object.hashCode() . |
class |
IdentityMapper<K,V>
Implements the identity function, mapping inputs directly to outputs.
|
class |
IdentityReducer<K,V>
Performs no reduction, writing all input values directly to the output.
|
class |
InputSampler<K,V> |
class |
InverseMapper<K,V>
A
Mapper that swaps keys and values. |
class |
KeyFieldBasedComparator<K,V>
This comparator implementation provides a subset of the features provided
by the Unix/GNU Sort.
|
class |
KeyFieldBasedPartitioner<K2,V2>
Defines a way to partition keys based on certain key fields (also see
KeyFieldBasedComparator . |
class |
LazyOutputFormat<K,V>
A Convenience class that creates output lazily.
|
class |
LongSumReducer<K>
A
Reducer that sums long values. |
class |
MultipleInputs
This class supports MapReduce jobs that have multiple input paths with
a different
InputFormat and Mapper for each path |
class |
MultipleOutputFormat<K,V>
This abstract class extends the FileOutputFormat, allowing to write the
output data to different output files.
|
class |
MultipleOutputs
The MultipleOutputs class simplifies writting to additional outputs other
than the job default output via the
OutputCollector passed to
the map() and reduce() methods of the
Mapper and Reducer implementations. |
class |
MultipleSequenceFileOutputFormat<K,V>
This class extends the MultipleOutputFormat, allowing to write the output data
to different output files in sequence file output format.
|
class |
MultipleTextOutputFormat<K,V>
This class extends the MultipleOutputFormat, allowing to write the output
data to different output files in Text output format.
|
class |
MultithreadedMapRunner<K1,V1,K2,V2>
Multithreaded implementation for @link org.apache.hadoop.mapred.MapRunnable.
|
class |
NLineInputFormat
NLineInputFormat which splits N lines of input as one split.
|
class |
NullOutputFormat<K,V>
Consume all outputs and put them in /dev/null.
|
class |
RegexMapper<K>
A
Mapper that extracts text matching a regular expression. |
class |
TokenCountMapper<K>
A
Mapper that maps text values into |
class |
TotalOrderPartitioner<K extends WritableComparable<?>,V>
Partitioner effecting a total order by reading split points from
an externally generated source.
|
Modifier and Type | Class and Description |
---|---|
class |
DoubleValueSum
This class implements a value aggregator that sums up a sequence of double
values.
|
class |
LongValueMax
This class implements a value aggregator that maintain the maximum of
a sequence of long values.
|
class |
LongValueMin
This class implements a value aggregator that maintain the minimum of
a sequence of long values.
|
class |
LongValueSum
This class implements a value aggregator that sums up
a sequence of long values.
|
class |
StringValueMax
This class implements a value aggregator that maintain the biggest of
a sequence of strings.
|
class |
StringValueMin
This class implements a value aggregator that maintain the smallest of
a sequence of strings.
|
class |
UniqValueCount
This class implements a value aggregator that dedupes a sequence of objects.
|
class |
UserDefinedValueAggregatorDescriptor
This class implements a wrapper for a user defined value aggregator
descriptor.
|
interface |
ValueAggregator<E>
This interface defines the minimal protocol for value aggregators.
|
class |
ValueAggregatorBaseDescriptor
This class implements the common functionalities of
the subclasses of ValueAggregatorDescriptor class.
|
class |
ValueAggregatorCombiner<K1 extends WritableComparable,V1 extends Writable>
This class implements the generic combiner of Aggregate.
|
interface |
ValueAggregatorDescriptor
This interface defines the contract a value aggregator descriptor must
support.
|
class |
ValueAggregatorJob
This is the main class for creating a map/reduce job using Aggregate
framework.
|
class |
ValueAggregatorJobBase<K1 extends WritableComparable,V1 extends Writable>
This abstract class implements some common functionalities of the
the generic mapper, reducer and combiner classes of Aggregate.
|
class |
ValueAggregatorMapper<K1 extends WritableComparable,V1 extends Writable>
This class implements the generic mapper of Aggregate.
|
class |
ValueAggregatorReducer<K1 extends WritableComparable,V1 extends Writable>
This class implements the generic reducer of Aggregate.
|
class |
ValueHistogram
This class implements a value aggregator that computes the
histogram of a sequence of strings.
|
Modifier and Type | Class and Description |
---|---|
class |
DBConfiguration |
class |
DBInputFormat<T extends DBWritable> |
class |
DBOutputFormat<K extends DBWritable,V> |
interface |
DBWritable |
Modifier and Type | Class and Description |
---|---|
class |
Submitter
The main entry point and job submitter.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Counter
A named counter that tracks the progress of a map/reduce job.
|
interface |
CounterGroup
A group of
Counter s that logically belong together. |
class |
Counters
Counters holds per job/task counters, defined either by the
Map-Reduce framework or applications. |
class |
ID
A general identifier, which internally stores the id
as an integer.
|
class |
InputFormat<K,V>
InputFormat describes the input-specification for a
Map-Reduce job. |
class |
InputSplit
InputSplit represents the data to be processed by an
individual Mapper . |
class |
JobID
JobID represents the immutable and unique identifier for
the job.
|
class |
Mapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
Maps input key/value pairs to a set of intermediate key/value pairs.
|
class |
OutputCommitter
OutputCommitter describes the commit of task output for a
Map-Reduce job. |
class |
OutputFormat<K,V>
OutputFormat describes the output-specification for a
Map-Reduce job. |
class |
Partitioner<KEY,VALUE>
Partitions the key space.
|
class |
RecordReader<KEYIN,VALUEIN>
The record reader breaks the data into key/value pairs for input to the
Mapper . |
class |
RecordWriter<K,V>
RecordWriter writes the output <key, value> pairs
to an output file. |
class |
Reducer<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
Reduces a set of intermediate values which share a key to a smaller set of
values.
|
class |
TaskAttemptID
TaskAttemptID represents the immutable and unique identifier for
a task attempt.
|
class |
TaskID
TaskID represents the immutable and unique identifier for
a Map or Reduce Task.
|
class |
TaskType
Enum for map, reduce, job-setup, job-cleanup, task-cleanup task types.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCounters<C extends Counter,G extends CounterGroupBase<C>>
An abstract class to provide common implementation for the Counters
container in both mapred and mapreduce packages.
|
Modifier and Type | Class and Description |
---|---|
class |
DoubleValueSum
This class implements a value aggregator that sums up a sequence of double
values.
|
class |
LongValueMax
This class implements a value aggregator that maintain the maximum of
a sequence of long values.
|
class |
LongValueMin
This class implements a value aggregator that maintain the minimum of
a sequence of long values.
|
class |
LongValueSum
This class implements a value aggregator that sums up
a sequence of long values.
|
class |
StringValueMax
This class implements a value aggregator that maintain the biggest of
a sequence of strings.
|
class |
StringValueMin
This class implements a value aggregator that maintain the smallest of
a sequence of strings.
|
class |
UniqValueCount
This class implements a value aggregator that dedupes a sequence of objects.
|
class |
UserDefinedValueAggregatorDescriptor
This class implements a wrapper for a user defined value
aggregator descriptor.
|
interface |
ValueAggregator<E>
This interface defines the minimal protocol for value aggregators.
|
class |
ValueAggregatorBaseDescriptor
This class implements the common functionalities of
the subclasses of ValueAggregatorDescriptor class.
|
class |
ValueAggregatorCombiner<K1 extends WritableComparable<?>,V1 extends Writable>
This class implements the generic combiner of Aggregate.
|
interface |
ValueAggregatorDescriptor
This interface defines the contract a value aggregator descriptor must
support.
|
class |
ValueAggregatorJob
This is the main class for creating a map/reduce job using Aggregate
framework.
|
class |
ValueAggregatorJobBase<K1 extends WritableComparable<?>,V1 extends Writable>
This abstract class implements some common functionalities of the
the generic mapper, reducer and combiner classes of Aggregate.
|
class |
ValueAggregatorMapper<K1 extends WritableComparable<?>,V1 extends Writable>
This class implements the generic mapper of Aggregate.
|
class |
ValueAggregatorReducer<K1 extends WritableComparable<?>,V1 extends Writable>
This class implements the generic reducer of Aggregate.
|
class |
ValueHistogram
This class implements a value aggregator that computes the
histogram of a sequence of strings.
|
Modifier and Type | Class and Description |
---|---|
class |
ChainMapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
The ChainMapper class allows to use multiple Mapper classes within a single
Map task.
|
class |
ChainReducer<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
The ChainReducer class allows to chain multiple Mapper classes after a
Reducer within the Reducer task.
|
Modifier and Type | Class and Description |
---|---|
class |
DBConfiguration
A container for configuration property names for jobs with DB input/output.
|
class |
DBInputFormat<T extends DBWritable>
A InputFormat that reads input data from an SQL table.
|
class |
DBOutputFormat<K extends DBWritable,V>
A OutputFormat that sends the reduce output to a SQL table.
|
interface |
DBWritable
Objects that are read from/written to a database should implement
DBWritable . |
Modifier and Type | Class and Description |
---|---|
class |
FieldSelectionHelper
This class implements a mapper/reducer class that can be used to perform
field selections in a manner similar to unix cut.
|
class |
FieldSelectionMapper<K,V>
This class implements a mapper class that can be used to perform
field selections in a manner similar to unix cut.
|
class |
FieldSelectionReducer<K,V>
This class implements a reducer class that can be used to perform field
selections in a manner similar to unix cut.
|
Modifier and Type | Class and Description |
---|---|
class |
CombineFileInputFormat<K,V>
An abstract
InputFormat that returns CombineFileSplit 's in
InputFormat.getSplits(JobContext) method. |
class |
CombineFileRecordReader<K,V>
A generic RecordReader that can hand out different recordReaders
for each chunk in a
CombineFileSplit . |
class |
CombineFileRecordReaderWrapper<K,V>
A wrapper class for a record reader that handles a single file split.
|
class |
CombineFileSplit
A sub-collection of input files.
|
class |
CombineSequenceFileInputFormat<K,V>
Input format that is a
CombineFileInputFormat -equivalent for
SequenceFileInputFormat . |
class |
CombineTextInputFormat
Input format that is a
CombineFileInputFormat -equivalent for
TextInputFormat . |
class |
FileInputFormat<K,V>
A base class for file-based
InputFormat s. |
class |
FileSplit
A section of an input file.
|
class |
InvalidInputException
This class wraps a list of problems with the input, so that the user
can get a list of problems together instead of finding and fixing them one
by one.
|
class |
KeyValueLineRecordReader
This class treats a line in the input as a key/value pair separated by a
separator character.
|
class |
KeyValueTextInputFormat
An
InputFormat for plain text files. |
class |
MultipleInputs
This class supports MapReduce jobs that have multiple input paths with
a different
InputFormat and Mapper for each path |
class |
NLineInputFormat
NLineInputFormat which splits N lines of input as one split.
|
class |
SequenceFileAsBinaryInputFormat
InputFormat reading keys, values from SequenceFiles in binary (raw)
format.
|
class |
SequenceFileAsTextInputFormat
This class is similar to SequenceFileInputFormat, except it generates
SequenceFileAsTextRecordReader which converts the input keys and values
to their String forms by calling toString() method.
|
class |
SequenceFileAsTextRecordReader
This class converts the input keys and values to their String forms by
calling toString() method.
|
class |
SequenceFileInputFilter<K,V>
A class that allows a map/red job to work on a sample of sequence files.
|
class |
SequenceFileInputFormat<K,V>
An
InputFormat for SequenceFile s. |
class |
SequenceFileRecordReader<K,V>
An
RecordReader for SequenceFile s. |
class |
TextInputFormat
An
InputFormat for plain text files. |
Modifier and Type | Class and Description |
---|---|
class |
ArrayListBackedIterator<X extends Writable>
This class provides an implementation of ResetableIterator.
|
class |
ComposableInputFormat<K extends WritableComparable<?>,V extends Writable>
Refinement of InputFormat requiring implementors to provide
ComposableRecordReader instead of RecordReader.
|
class |
ComposableRecordReader<K extends WritableComparable<?>,V extends Writable>
Additional operations required of a RecordReader to participate in a join.
|
class |
CompositeInputFormat<K extends WritableComparable>
An InputFormat capable of performing joins over a set of data sources sorted
and partitioned the same way.
|
class |
CompositeInputSplit
This InputSplit contains a set of child InputSplits.
|
class |
CompositeRecordReader<K extends WritableComparable<?>,V extends Writable,X extends Writable>
A RecordReader that can effect joins of RecordReaders sharing a common key
type and partitioning.
|
class |
InnerJoinRecordReader<K extends WritableComparable<?>>
Full inner join.
|
class |
JoinRecordReader<K extends WritableComparable<?>>
Base class for Composite joins returning Tuples of arbitrary Writables.
|
class |
MultiFilterRecordReader<K extends WritableComparable<?>,V extends Writable>
Base class for Composite join returning values derived from multiple
sources, but generally not tuples.
|
class |
OuterJoinRecordReader<K extends WritableComparable<?>>
Full outer join.
|
class |
OverrideRecordReader<K extends WritableComparable<?>,V extends Writable>
Prefer the "rightmost" data source for this key.
|
interface |
ResetableIterator<T extends Writable>
This defines an interface to a stateful Iterator that can replay elements
added to it directly.
|
class |
StreamBackedIterator<X extends Writable>
This class provides an implementation of ResetableIterator.
|
class |
TupleWritable
Writable type storing multiple
Writable s. |
class |
WrappedRecordReader<K extends WritableComparable<?>,U extends Writable>
Proxy class for a RecordReader participating in the join framework.
|
Modifier and Type | Class and Description |
---|---|
class |
InverseMapper<K,V>
A
Mapper that swaps keys and values. |
class |
MultithreadedMapper<K1,V1,K2,V2>
Multithreaded implementation for @link org.apache.hadoop.mapreduce.Mapper.
|
class |
RegexMapper<K>
A
Mapper that extracts text matching a regular expression. |
class |
TokenCounterMapper
Tokenize the input values and emit each word with a count of 1.
|
Modifier and Type | Class and Description |
---|---|
class |
FileOutputCommitter
An
OutputCommitter that commits files specified
in job output directory i.e. |
class |
FileOutputFormat<K,V>
A base class for
OutputFormat s that read from FileSystem s. |
class |
FilterOutputFormat<K,V>
FilterOutputFormat is a convenience class that wraps OutputFormat.
|
class |
LazyOutputFormat<K,V>
A Convenience class that creates output lazily.
|
class |
MapFileOutputFormat
An
OutputFormat that writes
MapFile s. |
class |
MultipleOutputs<KEYOUT,VALUEOUT>
The MultipleOutputs class simplifies writing output data
to multiple outputs
|
class |
NullOutputFormat<K,V>
Consume all outputs and put them in /dev/null.
|
class |
SequenceFileAsBinaryOutputFormat
An
OutputFormat that writes keys,
values to SequenceFile s in binary(raw) format |
class |
SequenceFileOutputFormat<K,V>
An
OutputFormat that writes SequenceFile s. |
class |
TextOutputFormat<K,V>
An
OutputFormat that writes plain text files. |
Modifier and Type | Class and Description |
---|---|
class |
HashPartitioner<K,V>
Partition keys by their
Object.hashCode() . |
class |
InputSampler<K,V>
Utility for collecting samples and writing a partition file for
TotalOrderPartitioner . |
class |
KeyFieldBasedComparator<K,V>
This comparator implementation provides a subset of the features provided
by the Unix/GNU Sort.
|
class |
KeyFieldBasedPartitioner<K2,V2>
Defines a way to partition keys based on certain key fields (also see
KeyFieldBasedComparator . |
class |
TotalOrderPartitioner<K extends WritableComparable<?>,V>
Partitioner effecting a total order by reading split points from
an externally generated source.
|
Modifier and Type | Class and Description |
---|---|
class |
IntSumReducer<Key> |
class |
LongSumReducer<KEY> |
Modifier and Type | Interface and Description |
---|---|
interface |
ClientProtocol
Protocol that a JobClient and the central JobTracker use to communicate.
|
Modifier and Type | Class and Description |
---|---|
class |
ShuffleHeader
Shuffle Header information that is sent by the TaskTracker and
deciphered by the Fetcher thread of Reduce task
|
Modifier and Type | Class and Description |
---|---|
class |
CLI
Interprets the map reduce cli options
|
Modifier and Type | Class and Description |
---|---|
class |
MBeans
This util class provides a method to register an MBean using
our standard naming convention as described in the doc
for {link
MBeans.register(String, String, Object) |
Modifier and Type | Class and Description |
---|---|
class |
ConnectTimeoutException
Thrown by
NetUtils.connect(java.net.Socket, java.net.SocketAddress, int)
if it times out while connecting to the remote host. |
Modifier and Type | Class and Description |
---|---|
class |
BinaryRecordInput
Deprecated.
Replaced by Avro.
|
class |
BinaryRecordOutput
Deprecated.
Replaced by Avro.
|
class |
Buffer
Deprecated.
Replaced by Avro.
|
class |
CsvRecordInput
Deprecated.
Replaced by Avro.
|
class |
CsvRecordOutput
Deprecated.
Replaced by Avro.
|
interface |
Index
Deprecated.
Replaced by Avro.
|
class |
Record
Deprecated.
Replaced by Avro.
|
class |
RecordComparator
Deprecated.
Replaced by Avro.
|
interface |
RecordInput
Deprecated.
Replaced by Avro.
|
interface |
RecordOutput
Deprecated.
Replaced by Avro.
|
class |
Utils
Deprecated.
Replaced by Avro.
|
class |
XmlRecordInput
Deprecated.
Replaced by Avro.
|
class |
XmlRecordOutput
Deprecated.
Replaced by Avro.
|
Modifier and Type | Class and Description |
---|---|
class |
CodeBuffer
Deprecated.
Replaced by Avro.
|
class |
Consts
Deprecated.
Replaced by Avro.
|
class |
JBoolean
Deprecated.
Replaced by Avro.
|
class |
JBuffer
Deprecated.
Replaced by Avro.
|
class |
JByte
Deprecated.
Replaced by Avro.
|
class |
JDouble
Deprecated.
Replaced by Avro.
|
class |
JField<T>
Deprecated.
Replaced by Avro.
|
class |
JFile
Deprecated.
Replaced by Avro.
|
class |
JFloat
Deprecated.
Replaced by Avro.
|
class |
JInt
Deprecated.
Replaced by Avro.
|
class |
JLong
Deprecated.
Replaced by Avro.
|
class |
JMap
Deprecated.
Replaced by Avro.
|
class |
JRecord
Deprecated.
Replaced by Avro.
|
class |
JString
Deprecated.
Replaced by Avro.
|
class |
JType
Deprecated.
Replaced by Avro.
|
class |
JVector
Deprecated.
Replaced by Avro.
|
Modifier and Type | Class and Description |
---|---|
class |
RccTask
Deprecated.
Replaced by Avro.
|
Modifier and Type | Class and Description |
---|---|
class |
ParseException
Deprecated.
Replaced by Avro.
|
class |
Rcc
Deprecated.
Replaced by Avro.
|
interface |
RccConstants
Deprecated.
Replaced by Avro.
|
class |
RccTokenManager
Deprecated.
Replaced by Avro.
|
class |
SimpleCharStream
Deprecated.
Replaced by Avro.
|
class |
Token
Deprecated.
Replaced by Avro.
|
class |
TokenMgrError
Deprecated.
Replaced by Avro.
|
Modifier and Type | Class and Description |
---|---|
class |
FieldTypeInfo
Deprecated.
Replaced by Avro.
|
class |
MapTypeID
Deprecated.
Replaced by Avro.
|
class |
RecordTypeInfo
Deprecated.
Replaced by Avro.
|
class |
StructTypeID
Deprecated.
Replaced by Avro.
|
class |
TypeID
Deprecated.
Replaced by Avro.
|
class |
Utils
Deprecated.
Replaced by Avro.
|
class |
VectorTypeID
Deprecated.
Replaced by Avro.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ServiceStateChangeListener
Interface to notify state changes of a service.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Progressable
A facility for reporting progress.
|
class |
PureJavaCrc32
A pure-java implementation of the CRC32 checksum that uses
the same polynomial as the built-in native CRC32.
|
class |
PureJavaCrc32C
A pure-java implementation of the CRC32 checksum that uses
the CRC32-C polynomial, the same polynomial used by iSCSI
and implemented on many Intel chipsets supporting SSE4.2.
|
class |
StringInterner
Provides equivalent behavior to String.intern() to optimize performance,
whereby does not consume memory in the permanent generation.
|
interface |
Tool
A tool interface that supports handling of generic command-line options.
|
class |
ToolRunner
A utility to help run
Tool s. |
Modifier and Type | Class and Description |
---|---|
class |
BloomFilter
Implements a Bloom filter, as defined by Bloom in 1970.
|
class |
CountingBloomFilter
Implements a counting Bloom filter, as defined by Fan et al.
|
class |
DynamicBloomFilter
Implements a dynamic Bloom filter, as defined in the INFOCOM 2006 paper.
|
class |
HashFunction
Implements a hash object that returns a certain number of hashed values.
|
interface |
RemoveScheme
Defines the different remove scheme for retouched Bloom filters.
|
class |
RetouchedBloomFilter
Implements a retouched Bloom filter, as defined in the CoNEXT 2006 paper.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ApplicationClientProtocol
The protocol between clients and the
ResourceManager
to submit/abort jobs and to get information on applications, cluster metrics,
nodes, queues and ACLs. |
interface |
ApplicationMasterProtocol
The protocol between a live instance of
ApplicationMaster
and the ResourceManager . |
interface |
ContainerManagementProtocol
The protocol between an
ApplicationMaster and a
NodeManager to start/stop containers and to get status
of running containers. |
Modifier and Type | Method and Description |
---|---|
AllocateResponse |
ApplicationMasterProtocol.allocate(AllocateRequest request)
The main interface between an
ApplicationMaster and the
ResourceManager . |
FinishApplicationMasterResponse |
ApplicationMasterProtocol.finishApplicationMaster(FinishApplicationMasterRequest request)
The interface used by an
ApplicationMaster to notify the
ResourceManager about its completion (success or failed). |
KillApplicationResponse |
ApplicationClientProtocol.forceKillApplication(KillApplicationRequest request)
The interface used by clients to request the
ResourceManager to abort submitted application. |
GetApplicationReportResponse |
ApplicationClientProtocol.getApplicationReport(GetApplicationReportRequest request)
The interface used by clients to get a report of an Application from
the
ResourceManager . |
GetApplicationsResponse |
ApplicationClientProtocol.getApplications(GetApplicationsRequest request)
The interface used by clients to get a report of Applications
matching the filters defined by
GetApplicationsRequest
in the cluster from the ResourceManager . |
GetClusterMetricsResponse |
ApplicationClientProtocol.getClusterMetrics(GetClusterMetricsRequest request)
The interface used by clients to get metrics about the cluster from
the
ResourceManager . |
GetClusterNodesResponse |
ApplicationClientProtocol.getClusterNodes(GetClusterNodesRequest request)
The interface used by clients to get a report of all nodes
in the cluster from the
ResourceManager . |
GetContainerStatusesResponse |
ContainerManagementProtocol.getContainerStatuses(GetContainerStatusesRequest request)
The API used by the
ApplicationMaster to request for current
statuses of Container s from the NodeManager . |
GetDelegationTokenResponse |
ApplicationClientProtocol.getDelegationToken(GetDelegationTokenRequest request)
The interface used by clients to get delegation token, enabling the
containers to be able to talk to the service using those tokens.
|
GetNewApplicationResponse |
ApplicationClientProtocol.getNewApplication(GetNewApplicationRequest request)
The interface used by clients to obtain a new
ApplicationId for
submitting new applications. |
GetQueueInfoResponse |
ApplicationClientProtocol.getQueueInfo(GetQueueInfoRequest request)
The interface used by clients to get information about queues
from the
ResourceManager . |
GetQueueUserAclsInfoResponse |
ApplicationClientProtocol.getQueueUserAcls(GetQueueUserAclsInfoRequest request)
The interface used by clients to get information about queue
acls for current user from the
ResourceManager . |
RegisterApplicationMasterResponse |
ApplicationMasterProtocol.registerApplicationMaster(RegisterApplicationMasterRequest request)
The interface used by a new
ApplicationMaster to register with
the ResourceManager . |
StartContainersResponse |
ContainerManagementProtocol.startContainers(StartContainersRequest request)
The
ApplicationMaster provides a list of
StartContainerRequest s to a NodeManager to
start Container s allocated to it using this interface. |
StopContainersResponse |
ContainerManagementProtocol.stopContainers(StopContainersRequest request)
The
ApplicationMaster requests a NodeManager to
stop a list of Container s allocated to it using this
interface. |
SubmitApplicationResponse |
ApplicationClientProtocol.submitApplication(SubmitApplicationRequest request)
The interface used by clients to submit a new application to the
ResourceManager. |
Modifier and Type | Class and Description |
---|---|
class |
AllocateRequest
The core request sent by the
ApplicationMaster to the
ResourceManager to obtain resources in the cluster. |
class |
AllocateResponse
The response sent by the
ResourceManager the
ApplicationMaster during resource negotiation. |
class |
FinishApplicationMasterRequest
The finalization request sent by the
ApplicationMaster to
inform the ResourceManager about its completion. |
class |
FinishApplicationMasterResponse
The response sent by the
ResourceManager to a
ApplicationMaster on it's completion. |
class |
GetApplicationReportRequest
The request sent by a client to the
ResourceManager to
get an ApplicationReport for an application. |
class |
GetApplicationReportResponse
The response sent by the
ResourceManager to a client
requesting an application report. |
class |
GetApplicationsRequest
The request from clients to get a report of Applications
in the cluster from the
ResourceManager . |
class |
GetApplicationsResponse
The response sent by the
ResourceManager to a client
requesting an ApplicationReport for applications. |
class |
GetClusterMetricsRequest
The request sent by clients to get cluster metrics from the
ResourceManager . |
class |
GetClusterMetricsResponse
The response sent by the
ResourceManager to a client
requesting cluster metrics. |
class |
GetClusterNodesRequest
The request from clients to get a report of all nodes
in the cluster from the
ResourceManager . |
class |
GetClusterNodesResponse
The response sent by the
ResourceManager to a client
requesting a NodeReport for all nodes. |
class |
GetContainerStatusesRequest
The request sent by the
ApplicationMaster to the
NodeManager to get ContainerStatus of requested
containers. |
class |
GetContainerStatusesResponse
The response sent by the
NodeManager to the
ApplicationMaster when asked to obtain the
ContainerStatus of requested containers. |
class |
GetDelegationTokenRequest
The request issued by the client to get a delegation token from
the
ResourceManager . |
class |
GetDelegationTokenResponse
Response to a
GetDelegationTokenRequest request
from the client. |
class |
GetNewApplicationRequest
The request sent by clients to get a new
ApplicationId for
submitting an application. |
class |
GetNewApplicationResponse
The response sent by the
ResourceManager to the client for
a request to get a new ApplicationId for submitting applications. |
class |
GetQueueInfoRequest
The request sent by clients to get queue information
from the
ResourceManager . |
class |
GetQueueInfoResponse
The response sent by the
ResourceManager to a client
requesting information about queues in the system. |
class |
GetQueueUserAclsInfoRequest
The request sent by clients to the
ResourceManager to
get queue acls for the current user. |
class |
GetQueueUserAclsInfoResponse
The response sent by the
ResourceManager to clients
seeking queue acls for the user. |
class |
KillApplicationRequest
The request sent by the client to the
ResourceManager
to abort a submitted application. |
class |
KillApplicationResponse
The response sent by the
ResourceManager to the client
aborting a submitted application. |
class |
RegisterApplicationMasterRequest
The request sent by the
ApplicationMaster to
ResourceManager on registration. |
class |
RegisterApplicationMasterResponse
The response sent by the
ResourceManager to a new
ApplicationMaster on registration. |
class |
StartContainerRequest
The request sent by the
ApplicationMaster to the
NodeManager to start a container. |
class |
StartContainersRequest
The request which contains a list of
StartContainerRequest sent by
the ApplicationMaster to the NodeManager to
start containers. |
class |
StartContainersResponse
The response sent by the
NodeManager to the
ApplicationMaster when asked to start an allocated
container. |
class |
StopContainersRequest
The request sent by the
ApplicationMaster to the
NodeManager to stop containers. |
class |
StopContainersResponse
The response sent by the
NodeManager to the
ApplicationMaster when asked to stop allocated
containers. |
class |
SubmitApplicationRequest
The request sent by a client to submit an application to the
ResourceManager . |
class |
SubmitApplicationResponse
The response sent by the
ResourceManager to a client on
application submission. |
Modifier and Type | Method and Description |
---|---|
abstract List<Container> |
AllocateResponse.getAllocatedContainers()
Get the list of newly allocated
Container by the
ResourceManager . |
abstract Map<String,ByteBuffer> |
StartContainersResponse.getAllServicesMetaData()
Get the meta-data from all auxiliary services running on the
NodeManager . |
abstract AMCommand |
AllocateResponse.getAMCommand()
If the
ResourceManager needs the
ApplicationMaster to take some action then it will send an
AMCommand to the ApplicationMaster . |
abstract Map<ApplicationAccessType,String> |
RegisterApplicationMasterResponse.getApplicationACLs()
Get the
ApplicationACL s for the application. |
abstract ApplicationId |
GetNewApplicationResponse.getApplicationId()
Get the new
ApplicationId allocated by the
ResourceManager . |
abstract ApplicationId |
GetApplicationReportRequest.getApplicationId()
Get the
ApplicationId of the application. |
abstract ApplicationId |
KillApplicationRequest.getApplicationId()
Get the
ApplicationId of the application to be aborted. |
abstract List<ApplicationReport> |
GetApplicationsResponse.getApplicationList()
Get
ApplicationReport for applications. |
abstract ApplicationReport |
GetApplicationReportResponse.getApplicationReport()
Get the
ApplicationReport for the application. |
abstract EnumSet<YarnApplicationState> |
GetApplicationsRequest.getApplicationStates()
Get the application states to filter applications on
|
abstract ApplicationSubmissionContext |
SubmitApplicationRequest.getApplicationSubmissionContext()
Get the
ApplicationSubmissionContext for the application. |
abstract Set<String> |
GetApplicationsRequest.getApplicationTypes()
Get the application types to filter applications on
|
abstract List<ResourceRequest> |
AllocateRequest.getAskList()
Get the list of
ResourceRequest to update the
ResourceManager about the application's resource requirements. |
abstract Resource |
AllocateResponse.getAvailableResources()
Get the available headroom for resources in the cluster for the
application.
|
abstract ByteBuffer |
RegisterApplicationMasterResponse.getClientToAMTokenMasterKey()
Get ClientToAMToken master key.
|
abstract YarnClusterMetrics |
GetClusterMetricsResponse.getClusterMetrics()
Get the
YarnClusterMetrics for the cluster. |
abstract List<ContainerStatus> |
AllocateResponse.getCompletedContainersStatuses()
Get the list of completed containers' statuses.
|
abstract List<ContainerId> |
GetContainerStatusesRequest.getContainerIds()
Get the list of
ContainerId s of containers for which to obtain
the ContainerStatus . |
abstract List<ContainerId> |
StopContainersRequest.getContainerIds()
Get the
ContainerId s of the containers to be stopped. |
abstract ContainerLaunchContext |
StartContainerRequest.getContainerLaunchContext()
Get the
ContainerLaunchContext for the container to be started
by the NodeManager . |
abstract List<ContainerStatus> |
GetContainerStatusesResponse.getContainerStatuses()
Get the
ContainerStatus es of the requested containers. |
abstract Token |
StartContainerRequest.getContainerToken()
Get the container token to be used for authorization during starting
container.
|
abstract String |
FinishApplicationMasterRequest.getDiagnostics()
Get diagnostic information on application failure.
|
abstract Map<ContainerId,SerializedException> |
StopContainersResponse.getFailedRequests()
Get the containerId-to-exception map in which the exception indicates error
from per container for failed requests
|
abstract Map<ContainerId,SerializedException> |
StartContainersResponse.getFailedRequests()
Get the containerId-to-exception map in which the exception indicates error
from per container for failed requests
|
abstract Map<ContainerId,SerializedException> |
GetContainerStatusesResponse.getFailedRequests()
Get the containerId-to-exception map in which the exception indicates error
from per container for failed requests
|
abstract FinalApplicationStatus |
FinishApplicationMasterRequest.getFinalApplicationStatus()
Get final state of the
ApplicationMaster . |
abstract String |
RegisterApplicationMasterRequest.getHost()
Get the host on which the
ApplicationMaster is
running. |
abstract boolean |
GetQueueInfoRequest.getIncludeApplications()
Is information about active applications
|
abstract boolean |
GetQueueInfoRequest.getIncludeChildQueues()
Is information about child queues required?
|
abstract boolean |
FinishApplicationMasterResponse.getIsUnregistered()
Get the flag which indicates that the application has successfully
unregistered with the RM and the application can safely stop.
|
abstract Resource |
GetNewApplicationResponse.getMaximumResourceCapability()
Get the maximum capability for any
Resource allocated by the
ResourceManager in the cluster. |
abstract Resource |
RegisterApplicationMasterResponse.getMaximumResourceCapability()
Get the maximum capability for any
Resource allocated by the
ResourceManager in the cluster. |
abstract List<NMToken> |
AllocateResponse.getNMTokens()
Get the list of NMTokens required for communicating with NM.
|
abstract List<NodeReport> |
GetClusterNodesResponse.getNodeReports()
Get
NodeReport for all nodes in the cluster. |
abstract int |
AllocateResponse.getNumClusterNodes()
Get the number of hosts available on the cluster.
|
abstract float |
AllocateRequest.getProgress()
Get the current progress of application.
|
abstract QueueInfo |
GetQueueInfoResponse.getQueueInfo()
Get the
QueueInfo for the specified queue. |
abstract String |
GetQueueInfoRequest.getQueueName()
Get the queue name for which to get queue information.
|
abstract boolean |
GetQueueInfoRequest.getRecursive()
Is information on the entire child queue hierarchy required?
|
abstract List<ContainerId> |
AllocateRequest.getReleaseList()
Get the list of
ContainerId of containers being
released by the ApplicationMaster . |
abstract String |
GetDelegationTokenRequest.getRenewer() |
abstract ResourceBlacklistRequest |
AllocateRequest.getResourceBlacklistRequest()
Get the
ResourceBlacklistRequest being sent by the
ApplicationMaster . |
abstract int |
AllocateRequest.getResponseId()
Get the response id used to track duplicate responses.
|
abstract int |
AllocateResponse.getResponseId()
Get the last response id.
|
abstract Token |
GetDelegationTokenResponse.getRMDelegationToken()
The Delegation tokens have a identifier which maps to
AbstractDelegationTokenIdentifier . |
abstract int |
RegisterApplicationMasterRequest.getRpcPort()
Get the RPC port on which the
ApplicationMaster
is responding. |
abstract List<StartContainerRequest> |
StartContainersRequest.getStartContainerRequests()
Get a list of
StartContainerRequest to start containers. |
abstract List<ContainerId> |
StartContainersResponse.getSuccessfullyStartedContainers()
Get the list of
ContainerId s of the containers that are
started successfully. |
abstract List<ContainerId> |
StopContainersResponse.getSuccessfullyStoppedContainers()
Get the list of containerIds of successfully stopped containers.
|
abstract String |
FinishApplicationMasterRequest.getTrackingUrl()
Get the tracking URL for the
ApplicationMaster . |
abstract String |
RegisterApplicationMasterRequest.getTrackingUrl()
Get the tracking URL for the
ApplicationMaster . |
abstract List<NodeReport> |
AllocateResponse.getUpdatedNodes()
Get the list of updated
NodeReport s. |
abstract List<QueueUserACLInfo> |
GetQueueUserAclsInfoResponse.getUserAclsInfoList()
Get the
QueueUserACLInfo per queue for the user. |
static GetClusterNodesRequest |
GetClusterNodesRequest.newInstance() |
static GetClusterMetricsRequest |
GetClusterMetricsRequest.newInstance() |
static GetApplicationsRequest |
GetApplicationsRequest.newInstance() |
static GetNewApplicationRequest |
GetNewApplicationRequest.newInstance() |
static GetQueueUserAclsInfoRequest |
GetQueueUserAclsInfoRequest.newInstance() |
static GetApplicationReportRequest |
GetApplicationReportRequest.newInstance(ApplicationId applicationId) |
static KillApplicationRequest |
KillApplicationRequest.newInstance(ApplicationId applicationId) |
static SubmitApplicationRequest |
SubmitApplicationRequest.newInstance(ApplicationSubmissionContext context) |
static StartContainerRequest |
StartContainerRequest.newInstance(ContainerLaunchContext context,
Token container) |
static GetClusterNodesRequest |
GetClusterNodesRequest.newInstance(EnumSet<NodeState> states) |
static GetApplicationsRequest |
GetApplicationsRequest.newInstance(EnumSet<YarnApplicationState> applicationStates)
The request from clients to get a report of Applications matching the
giving application states in the cluster from the
ResourceManager . |
static FinishApplicationMasterRequest |
FinishApplicationMasterRequest.newInstance(FinalApplicationStatus finalAppStatus,
String diagnostics,
String url) |
static AllocateRequest |
AllocateRequest.newInstance(int responseID,
float appProgress,
List<ResourceRequest> resourceAsk,
List<ContainerId> containersToBeReleased,
ResourceBlacklistRequest resourceBlacklistRequest) |
static AllocateResponse |
AllocateResponse.newInstance(int responseId,
List<ContainerStatus> completedContainers,
List<Container> allocatedContainers,
List<NodeReport> updatedNodes,
Resource availResources,
AMCommand command,
int numClusterNodes,
PreemptionMessage preempt,
List<NMToken> nmTokens) |
static GetContainerStatusesRequest |
GetContainerStatusesRequest.newInstance(List<ContainerId> containerIds) |
static StopContainersRequest |
StopContainersRequest.newInstance(List<ContainerId> containerIds) |
static StartContainersRequest |
StartContainersRequest.newInstance(List<StartContainerRequest> requests) |
static GetApplicationsRequest |
GetApplicationsRequest.newInstance(Set<String> applicationTypes)
The request from clients to get a report of Applications matching the
giving application types in the cluster from the
ResourceManager . |
static GetApplicationsRequest |
GetApplicationsRequest.newInstance(Set<String> applicationTypes,
EnumSet<YarnApplicationState> applicationStates)
The request from clients to get a report of Applications matching the
giving and application types and application types in the cluster from the
ResourceManager . |
static GetDelegationTokenRequest |
GetDelegationTokenRequest.newInstance(String renewer) |
static GetQueueInfoRequest |
GetQueueInfoRequest.newInstance(String queueName,
boolean includeApplications,
boolean includeChildQueues,
boolean recursive) |
static RegisterApplicationMasterRequest |
RegisterApplicationMasterRequest.newInstance(String host,
int port,
String trackingUrl)
Create a new instance of
RegisterApplicationMasterRequest . |
abstract void |
GetApplicationReportRequest.setApplicationId(ApplicationId applicationId)
Set the
ApplicationId of the application |
abstract void |
KillApplicationRequest.setApplicationId(ApplicationId applicationId) |
abstract void |
SubmitApplicationRequest.setApplicationSubmissionContext(ApplicationSubmissionContext context)
Set the
ApplicationSubmissionContext for the application. |
abstract void |
AllocateRequest.setAskList(List<ResourceRequest> resourceRequests)
Set list of
ResourceRequest to update the
ResourceManager about the application's resource requirements. |
abstract void |
RegisterApplicationMasterResponse.setClientToAMTokenMasterKey(ByteBuffer key)
Set ClientToAMToken master key.
|
abstract void |
GetContainerStatusesRequest.setContainerIds(List<ContainerId> containerIds)
Set a list of
ContainerId s of containers for which to obtain
the ContainerStatus |
abstract void |
StopContainersRequest.setContainerIds(List<ContainerId> containerIds)
Set the
ContainerId s of the containers to be stopped. |
abstract void |
StartContainerRequest.setContainerLaunchContext(ContainerLaunchContext context)
Set the
ContainerLaunchContext for the container to be started
by the NodeManager |
abstract void |
StartContainerRequest.setContainerToken(Token container) |
abstract void |
FinishApplicationMasterRequest.setDiagnostics(String diagnostics)
Set diagnostic information on application failure.
|
abstract void |
FinishApplicationMasterRequest.setFinalApplicationStatus(FinalApplicationStatus finalState)
Set the final state of the
ApplicationMaster |
abstract void |
RegisterApplicationMasterRequest.setHost(String host)
Set the host on which the
ApplicationMaster is
running. |
abstract void |
GetQueueInfoRequest.setIncludeApplications(boolean includeApplications)
Should we get fetch information about active applications?
|
abstract void |
GetQueueInfoRequest.setIncludeChildQueues(boolean includeChildQueues)
Should we fetch information about child queues?
|
abstract void |
AllocateRequest.setProgress(float progress)
Set the current progress of application
|
abstract void |
GetQueueInfoRequest.setQueueName(String queueName)
Set the queue name for which to get queue information
|
abstract void |
GetQueueInfoRequest.setRecursive(boolean recursive)
Should we fetch information on the entire child queue hierarchy?
|
abstract void |
AllocateRequest.setReleaseList(List<ContainerId> releaseContainers)
Set the list of
ContainerId of containers being
released by the ApplicationMaster |
abstract void |
GetDelegationTokenRequest.setRenewer(String renewer) |
abstract void |
AllocateRequest.setResourceBlacklistRequest(ResourceBlacklistRequest resourceBlacklistRequest)
Set the
ResourceBlacklistRequest to inform the
ResourceManager about the blacklist additions and removals
per the ApplicationMaster . |
abstract void |
AllocateRequest.setResponseId(int id)
Set the response id used to track duplicate responses.
|
abstract void |
RegisterApplicationMasterRequest.setRpcPort(int port)
Set the RPC port on which the
ApplicationMaster is
responding. |
abstract void |
StartContainersRequest.setStartContainerRequests(List<StartContainerRequest> request)
Set a list of
StartContainerRequest to start containers. |
abstract void |
FinishApplicationMasterRequest.setTrackingUrl(String url)
Set the final tracking URLfor the
ApplicationMaster . |
abstract void |
RegisterApplicationMasterRequest.setTrackingUrl(String trackingUrl)
Set the tracking URLfor the
ApplicationMaster while
it is running. |
Modifier and Type | Class and Description |
---|---|
class |
ApplicationAccessType
Application access types.
|
class |
ApplicationAttemptId
ApplicationAttemptId denotes the particular attempt
of an ApplicationMaster for a given ApplicationId . |
class |
ApplicationId
ApplicationId represents the globally unique
identifier for an application. |
class |
ApplicationReport
ApplicationReport is a report of an application. |
class |
ApplicationResourceUsageReport
Contains various scheduling metrics to be reported by UI and CLI.
|
class |
ApplicationSubmissionContext
ApplicationSubmissionContext represents all of the
information needed by the ResourceManager to launch
the ApplicationMaster for an application. |
class |
Container
Container represents an allocated resource in the cluster. |
class |
ContainerId
ContainerId represents a globally unique identifier
for a Container in the cluster. |
class |
ContainerLaunchContext
ContainerLaunchContext represents all of the information
needed by the NodeManager to launch a container. |
class |
ContainerState
State of a
Container . |
class |
ContainerStatus
ContainerStatus represents the current status of a
Container . |
class |
FinalApplicationStatus
Enumeration of various final states of an
Application . |
class |
LocalResource
LocalResource represents a local resource required to
run a container. |
class |
LocalResourceType
LocalResourceType specifies the type
of a resource localized by the NodeManager . |
class |
LocalResourceVisibility
LocalResourceVisibility specifies the visibility
of a resource localized by the NodeManager . |
class |
NMToken
The NMToken is used for authenticating communication with
NodeManager |
class |
NodeId
NodeId is the unique identifier for a node. |
class |
NodeReport
NodeReport is a summary of runtime information of a
node in the cluster. |
class |
Priority
The priority assigned to a ResourceRequest or Application or Container
allocation
|
class |
QueueACL
QueueACL enumerates the various ACLs for queues. |
class |
QueueInfo
QueueInfo is a report of the runtime information of the queue.
|
class |
QueueState
State of a Queue.
|
class |
QueueUserACLInfo
QueueUserACLInfo provides information QueueACL for
the given user. |
class |
Resource
Resource models a set of computer resources in the
cluster. |
class |
ResourceBlacklistRequest
ResourceBlacklistRequest encapsulates the list of resource-names
which should be added or removed from the blacklist of resources
for the application. |
class |
ResourceRequest
ResourceRequest represents the request made by an
application to the ResourceManager to obtain various
Container allocations. |
static class |
ResourceRequest.ResourceRequestComparator |
class |
Token
Token is the security entity used by the framework
to verify authenticity of any resource. |
class |
URL
URL represents a serializable URL . |
class |
YarnApplicationState
Enumeration of various states of an
ApplicationMaster . |
class |
YarnClusterMetrics
YarnClusterMetrics represents cluster metrics. |
Modifier and Type | Method and Description |
---|---|
abstract ContainerLaunchContext |
ApplicationSubmissionContext.getAMContainerSpec()
Get the
ContainerLaunchContext to describe the
Container with which the ApplicationMaster is
launched. |
abstract Token |
ApplicationReport.getAMRMToken()
Get the AMRM token of the application.
|
abstract Map<ApplicationAccessType,String> |
ContainerLaunchContext.getApplicationACLs()
Get the
ApplicationACL s for the application. |
abstract ApplicationAttemptId |
ContainerId.getApplicationAttemptId()
Get the
ApplicationAttemptId of the application to which
the Container was assigned. |
abstract ApplicationId |
ApplicationReport.getApplicationId()
Get the
ApplicationId of the application. |
abstract ApplicationId |
ApplicationSubmissionContext.getApplicationId()
Get the
ApplicationId of the submitted application. |
abstract ApplicationId |
ApplicationAttemptId.getApplicationId()
Get the
ApplicationId of the ApplicationAttempId . |
abstract String |
ApplicationSubmissionContext.getApplicationName()
Get the application name.
|
abstract ApplicationResourceUsageReport |
ApplicationReport.getApplicationResourceUsageReport()
Retrieve the structure containing the job resources for this application
|
abstract List<ApplicationReport> |
QueueInfo.getApplications()
Get the running applications of the queue.
|
abstract String |
ApplicationReport.getApplicationType()
Get the application's Type
|
abstract String |
ApplicationSubmissionContext.getApplicationType()
Get the application type
|
abstract int |
ApplicationAttemptId.getAttemptId()
Get the
attempt id of the Application . |
abstract List<String> |
ResourceBlacklistRequest.getBlacklistAdditions()
Get the list of resource-names which should be added to the
application blacklist.
|
abstract List<String> |
ResourceBlacklistRequest.getBlacklistRemovals()
Get the list of resource-names which should be removed from the
application blacklist.
|
abstract Resource |
ResourceRequest.getCapability()
Get the
Resource capability of the request. |
abstract Resource |
NodeReport.getCapability()
Get the total
Resource on the node. |
abstract float |
QueueInfo.getCapacity()
Get the configured capacity of the queue.
|
abstract List<QueueInfo> |
QueueInfo.getChildQueues()
Get the child queues of the queue.
|
abstract Token |
ApplicationReport.getClientToAMToken()
Get the client token for communicating with the
ApplicationMaster . |
abstract long |
ApplicationId.getClusterTimestamp()
Get the start time of the
ResourceManager which is
used to generate globally unique ApplicationId . |
abstract List<String> |
ContainerLaunchContext.getCommands()
Get the list of commands for launching the container.
|
abstract ContainerId |
ContainerStatus.getContainerId()
Get the
ContainerId of the container. |
abstract Token |
Container.getContainerToken()
Get the
ContainerToken for the container. |
abstract ApplicationAttemptId |
ApplicationReport.getCurrentApplicationAttemptId()
Get the
ApplicationAttemptId of the current
attempt of the application |
abstract float |
QueueInfo.getCurrentCapacity()
Get the current capacity of the queue.
|
abstract String |
ApplicationReport.getDiagnostics()
Get the diagnositic information of the application in case of
errors.
|
abstract String |
ContainerStatus.getDiagnostics()
Get diagnostic messages for failed containers.
|
abstract Map<String,String> |
ContainerLaunchContext.getEnvironment()
Get environment variables for the container.
|
abstract String |
URL.getFile()
Get the file of the URL.
|
abstract FinalApplicationStatus |
ApplicationReport.getFinalApplicationStatus()
Get the final finish status of the application.
|
abstract long |
ApplicationReport.getFinishTime()
Get the finish time of the application.
|
abstract String |
NodeReport.getHealthReport()
Get the diagnostic health report of the node.
|
abstract String |
ApplicationReport.getHost()
Get the host on which the
ApplicationMaster
is running. |
abstract String |
NodeId.getHost()
Get the hostname of the node.
|
abstract String |
URL.getHost()
Get the host of the URL.
|
abstract String |
NodeReport.getHttpAddress()
Get the http address of the node.
|
abstract int |
ApplicationId.getId()
Get the short integer identifier of the
ApplicationId
which is unique for all applications started by a particular instance
of the ResourceManager . |
abstract int |
ContainerId.getId()
Get the identifier of the
ContainerId . |
abstract ContainerId |
Container.getId()
Get the globally unique identifier for the container.
|
abstract ByteBuffer |
Token.getIdentifier()
Get the token identifier.
|
abstract String |
Token.getKind()
Get the token kind.
|
abstract long |
NodeReport.getLastHealthReportTime()
Get the last timestamp at which the health report was received.
|
abstract Map<String,LocalResource> |
ContainerLaunchContext.getLocalResources()
Get
LocalResource required by the container. |
abstract int |
ApplicationSubmissionContext.getMaxAppAttempts() |
abstract float |
QueueInfo.getMaximumCapacity()
Get the maximum capacity of the queue.
|
abstract int |
Resource.getMemory()
Get memory of the resource.
|
abstract String |
ApplicationReport.getName()
Get the user-defined name of the application.
|
abstract Resource |
ApplicationResourceUsageReport.getNeededResources()
Get the needed
Resource |
abstract String |
Container.getNodeHttpAddress()
Get the http uri of the node on which the container is allocated.
|
abstract NodeId |
NodeReport.getNodeId()
Get the
NodeId of the node. |
abstract NodeId |
NMToken.getNodeId()
Get the
NodeId of the NodeManager for which the NMToken
is used to authenticate. |
abstract NodeId |
Container.getNodeId()
Get the identifier of the node on which the container is allocated.
|
abstract NodeState |
NodeReport.getNodeState()
Get the
NodeState of the node. |
abstract int |
ResourceRequest.getNumContainers()
Get the number of containers required with the given specifications.
|
abstract int |
YarnClusterMetrics.getNumNodeManagers()
Get the number of
NodeManager s in the cluster. |
abstract int |
ApplicationResourceUsageReport.getNumUsedContainers()
Get the number of used containers
|
abstract ByteBuffer |
Token.getPassword()
Get the token password
|
abstract String |
LocalResource.getPattern()
Get the pattern that should be used to extract entries from the
archive (only used when type is
PATTERN ). |
abstract int |
NodeId.getPort()
Get the port for communicating with the node.
|
abstract int |
URL.getPort()
Get the port of the URL.
|
abstract int |
Priority.getPriority()
Get the assigned priority
|
abstract Priority |
ResourceRequest.getPriority()
Get the
Priority of the request. |
abstract Priority |
ApplicationSubmissionContext.getPriority()
Get the
Priority of the application. |
abstract Priority |
Container.getPriority()
Get the
Priority at which the Container was
allocated. |
abstract float |
ApplicationReport.getProgress()
Get the application's progress ( range 0.0 to 1.0 )
|
abstract String |
ApplicationReport.getQueue()
Get the queue to which the application was submitted.
|
abstract String |
ApplicationSubmissionContext.getQueue()
Get the queue to which the application is being submitted.
|
abstract String |
QueueUserACLInfo.getQueueName()
Get the queue name of the queue.
|
abstract String |
QueueInfo.getQueueName()
Get the name of the queue.
|
abstract QueueState |
QueueInfo.getQueueState()
Get the
QueueState of the queue. |
abstract String |
NodeReport.getRackName()
Get the rack name for the node.
|
abstract boolean |
ResourceRequest.getRelaxLocality()
Get whether locality relaxation is enabled with this
ResourceRequest . |
abstract Resource |
ApplicationResourceUsageReport.getReservedResources()
Get the reserved
Resource |
abstract Resource |
ApplicationSubmissionContext.getResource()
Get the resource required by the
ApplicationMaster for this
application. |
abstract URL |
LocalResource.getResource()
Get the location of the resource to be localized.
|
abstract Resource |
Container.getResource()
Get the
Resource allocated to the container. |
abstract String |
ResourceRequest.getResourceName()
Get the resource (e.g.
|
abstract int |
ApplicationReport.getRpcPort()
Get the RPC port of the
ApplicationMaster . |
abstract String |
URL.getScheme()
Get the scheme of the URL.
|
abstract String |
Token.getService()
Get the service to which the token is allocated.
|
abstract Map<String,ByteBuffer> |
ContainerLaunchContext.getServiceData()
Get application-specific binary service data.
|
abstract long |
LocalResource.getSize()
Get the size of the resource to be localized.
|
abstract long |
ApplicationReport.getStartTime()
Get the start time of the application.
|
abstract ContainerState |
ContainerStatus.getState()
Get the
ContainerState of the container. |
abstract long |
LocalResource.getTimestamp()
Get the original timestamp of the resource to be localized, used
for verification.
|
abstract Token |
NMToken.getToken()
Get the
Token used for authenticating with NodeManager |
abstract ByteBuffer |
ContainerLaunchContext.getTokens()
Get all the tokens needed by this container.
|
abstract String |
ApplicationReport.getTrackingUrl()
Get the tracking url for the application.
|
abstract LocalResourceType |
LocalResource.getType()
Get the
LocalResourceType of the resource to be localized. |
abstract boolean |
ApplicationSubmissionContext.getUnmanagedAM()
Get if the RM should manage the execution of the AM.
|
abstract Resource |
NodeReport.getUsed()
Get used
Resource on the node. |
abstract Resource |
ApplicationResourceUsageReport.getUsedResources()
Get the used
Resource |
abstract String |
ApplicationReport.getUser()
Get the user who submitted the application.
|
abstract List<QueueACL> |
QueueUserACLInfo.getUserAcls()
Get the list of
QueueACL for the given user. |
abstract String |
URL.getUserInfo()
Get the user info of the URL.
|
abstract LocalResourceVisibility |
LocalResource.getVisibility()
Get the
LocalResourceVisibility of the resource to be
localized. |
abstract YarnApplicationState |
ApplicationReport.getYarnApplicationState()
Get the
YarnApplicationState of the application. |
static boolean |
ResourceRequest.isAnyLocation(String hostName)
Check whether the given host/rack string represents an arbitrary
host name.
|
static ApplicationSubmissionContext |
ApplicationSubmissionContext.newInstance(ApplicationId applicationId,
String applicationName,
String queue,
Priority priority,
ContainerLaunchContext amContainer,
boolean isUnmanagedAM,
boolean cancelTokensWhenComplete,
int maxAppAttempts,
Resource resource) |
static ApplicationSubmissionContext |
ApplicationSubmissionContext.newInstance(ApplicationId applicationId,
String applicationName,
String queue,
Priority priority,
ContainerLaunchContext amContainer,
boolean isUnmanagedAM,
boolean cancelTokensWhenComplete,
int maxAppAttempts,
Resource resource,
String applicationType) |
static Priority |
Priority.newInstance(int p) |
static Resource |
Resource.newInstance(int memory,
int vCores) |
static ResourceBlacklistRequest |
ResourceBlacklistRequest.newInstance(List<String> additions,
List<String> removals) |
static ContainerLaunchContext |
ContainerLaunchContext.newInstance(Map<String,LocalResource> localResources,
Map<String,String> environment,
List<String> commands,
Map<String,ByteBuffer> serviceData,
ByteBuffer tokens,
Map<ApplicationAccessType,String> acls) |
static ResourceRequest |
ResourceRequest.newInstance(Priority priority,
String hostName,
Resource capability,
int numContainers) |
static ResourceRequest |
ResourceRequest.newInstance(Priority priority,
String hostName,
Resource capability,
int numContainers,
boolean relaxLocality) |
static URL |
URL.newInstance(String scheme,
String host,
int port,
String file) |
static LocalResource |
LocalResource.newInstance(URL url,
LocalResourceType type,
LocalResourceVisibility visibility,
long size,
long timestamp) |
static LocalResource |
LocalResource.newInstance(URL url,
LocalResourceType type,
LocalResourceVisibility visibility,
long size,
long timestamp,
String pattern) |
abstract void |
ApplicationSubmissionContext.setAMContainerSpec(ContainerLaunchContext amContainer)
Set the
ContainerLaunchContext to describe the
Container with which the ApplicationMaster is
launched. |
abstract void |
ApplicationReport.setAMRMToken(Token amRmToken) |
abstract void |
ContainerLaunchContext.setApplicationACLs(Map<ApplicationAccessType,String> acls)
Set the
ApplicationACL s for the application. |
abstract void |
ApplicationSubmissionContext.setApplicationId(ApplicationId applicationId)
Set the
ApplicationId of the submitted application. |
abstract void |
ApplicationSubmissionContext.setApplicationName(String applicationName)
Set the application name.
|
abstract void |
ApplicationSubmissionContext.setApplicationType(String applicationType)
Set the application type
|
abstract void |
ResourceBlacklistRequest.setBlacklistAdditions(List<String> resourceNames)
Set list of resource-names which should be added to the application blacklist.
|
abstract void |
ResourceBlacklistRequest.setBlacklistRemovals(List<String> resourceNames)
Set list of resource-names which should be removed from the
application blacklist.
|
abstract void |
ResourceRequest.setCapability(Resource capability)
Set the
Resource capability of the request |
abstract void |
ContainerLaunchContext.setCommands(List<String> commands)
Add the list of commands for launching the container.
|
abstract void |
ContainerLaunchContext.setEnvironment(Map<String,String> environment)
Add environment variables for the container.
|
abstract void |
URL.setFile(String file)
Set the file of the URL.
|
abstract void |
URL.setHost(String host)
Set the host of the URL.
|
abstract void |
ContainerLaunchContext.setLocalResources(Map<String,LocalResource> localResources)
Set
LocalResource required by the container. |
abstract void |
ApplicationSubmissionContext.setMaxAppAttempts(int maxAppAttempts)
Set the number of max attempts of the application to be submitted.
|
abstract void |
Resource.setMemory(int memory)
Set memory of the resource.
|
abstract void |
NMToken.setNodeId(NodeId nodeId) |
abstract void |
ResourceRequest.setNumContainers(int numContainers)
Set the number of containers required with the given specifications
|
abstract void |
LocalResource.setPattern(String pattern)
Set the pattern that should be used to extract entries from the
archive (only used when type is
PATTERN ). |
abstract void |
URL.setPort(int port)
Set the port of the URL
|
abstract void |
Priority.setPriority(int priority)
Set the assigned priority
|
abstract void |
ResourceRequest.setPriority(Priority priority)
Set the
Priority of the request |
abstract void |
ApplicationSubmissionContext.setQueue(String queue)
Set the queue to which the application is being submitted
|
abstract void |
ResourceRequest.setRelaxLocality(boolean relaxLocality)
For a request at a network hierarchy level, set whether locality can be relaxed
to that level and beyond.
|
abstract void |
ApplicationSubmissionContext.setResource(Resource resource)
Set the resource required by the
ApplicationMaster for this
application. |
abstract void |
LocalResource.setResource(URL resource)
Set location of the resource to be localized.
|
abstract void |
ResourceRequest.setResourceName(String resourceName)
Set the resource name (e.g.
|
abstract void |
URL.setScheme(String scheme)
Set the scheme of the URL
|
abstract void |
ContainerLaunchContext.setServiceData(Map<String,ByteBuffer> serviceData)
Set application-specific binary service data.
|
abstract void |
LocalResource.setSize(long size)
Set the size of the resource to be localized.
|
abstract void |
LocalResource.setTimestamp(long timestamp)
Set the timestamp of the resource to be localized, used
for verification.
|
abstract void |
NMToken.setToken(Token token) |
abstract void |
ContainerLaunchContext.setTokens(ByteBuffer tokens)
Set security tokens needed by this container.
|
abstract void |
LocalResource.setType(LocalResourceType type)
Set the
LocalResourceType of the resource to be localized. |
abstract void |
ApplicationSubmissionContext.setUnmanagedAM(boolean value) |
abstract void |
URL.setUserInfo(String userInfo)
Set the user info of the URL.
|
abstract void |
LocalResource.setVisibility(LocalResourceVisibility visibility)
Set the
LocalResourceVisibility of the resource to be
localized. |
Modifier and Type | Class and Description |
---|---|
class |
AMRMClient<T extends AMRMClient.ContainerRequest> |
class |
NMClient |
class |
YarnClient |
class |
YarnClientApplication |
Modifier and Type | Class and Description |
---|---|
class |
AMRMClientAsync<T extends AMRMClient.ContainerRequest>
AMRMClientAsync handles communication with the ResourceManager
and provides asynchronous updates on events such as container allocations and
completions. |
class |
NMClientAsync
NMClientAsync handles communication with all the NodeManagers
and provides asynchronous updates on getting responses from them. |
Modifier and Type | Class and Description |
---|---|
class |
YarnException
YarnException indicates exceptions from yarn servers.
|
Modifier and Type | Class and Description |
---|---|
class |
ContainerManagerSecurityInfo |
class |
ContainerTokenSelector |
class |
SchedulerSecurityInfo |
Modifier and Type | Class and Description |
---|---|
class |
AdminSecurityInfo |
Modifier and Type | Class and Description |
---|---|
class |
ClientRMSecurityInfo |
class |
RMDelegationTokenSelector |
Modifier and Type | Interface and Description |
---|---|
interface |
ResourceManagerAdministrationProtocol |
Modifier and Type | Method and Description |
---|---|
RefreshAdminAclsResponse |
ResourceManagerAdministrationProtocol.refreshAdminAcls(RefreshAdminAclsRequest request) |
RefreshNodesResponse |
ResourceManagerAdministrationProtocol.refreshNodes(RefreshNodesRequest request) |
RefreshQueuesResponse |
ResourceManagerAdministrationProtocol.refreshQueues(RefreshQueuesRequest request) |
RefreshServiceAclsResponse |
ResourceManagerAdministrationProtocol.refreshServiceAcls(RefreshServiceAclsRequest request) |
RefreshSuperUserGroupsConfigurationResponse |
ResourceManagerAdministrationProtocol.refreshSuperUserGroupsConfiguration(RefreshSuperUserGroupsConfigurationRequest request) |
RefreshUserToGroupsMappingsResponse |
ResourceManagerAdministrationProtocol.refreshUserToGroupsMappings(RefreshUserToGroupsMappingsRequest request) |
Modifier and Type | Class and Description |
---|---|
class |
RefreshAdminAclsRequest |
class |
RefreshAdminAclsResponse |
class |
RefreshNodesRequest |
class |
RefreshNodesResponse |
class |
RefreshQueuesRequest |
class |
RefreshQueuesResponse |
class |
RefreshServiceAclsRequest |
class |
RefreshServiceAclsResponse |
class |
RefreshSuperUserGroupsConfigurationRequest |
class |
RefreshSuperUserGroupsConfigurationResponse |
class |
RefreshUserToGroupsMappingsRequest |
class |
RefreshUserToGroupsMappingsResponse |
Modifier and Type | Method and Description |
---|---|
static RefreshQueuesRequest |
RefreshQueuesRequest.newInstance() |
static RefreshNodesRequest |
RefreshNodesRequest.newInstance() |
static RefreshAdminAclsRequest |
RefreshAdminAclsRequest.newInstance() |
static RefreshSuperUserGroupsConfigurationRequest |
RefreshSuperUserGroupsConfigurationRequest.newInstance() |
static RefreshUserToGroupsMappingsRequest |
RefreshUserToGroupsMappingsRequest.newInstance() |
static RefreshServiceAclsRequest |
RefreshServiceAclsRequest.newInstance() |
Modifier and Type | Class and Description |
---|---|
class |
NodeHealthStatus
NodeHealthStatus is a summary of the health status of the
node. |
Modifier and Type | Method and Description |
---|---|
abstract String |
NodeHealthStatus.getHealthReport()
Get the diagnostic health report of the node.
|
abstract boolean |
NodeHealthStatus.getIsNodeHealthy()
Is the node healthy?
|
abstract long |
NodeHealthStatus.getLastHealthReportTime()
Get the last timestamp at which the health report was received.
|
Modifier and Type | Class and Description |
---|---|
class |
NodeReport
Node usage report.
|
class |
SchedulerNodeReport
Node usage report.
|
Modifier and Type | Method and Description |
---|---|
Allocation |
YarnScheduler.allocate(ApplicationAttemptId appAttemptId,
List<ResourceRequest> ask,
List<ContainerId> release,
List<String> blacklistAdditions,
List<String> blacklistRemovals)
The main api between the ApplicationMaster and the Scheduler.
|
Resource |
YarnScheduler.getMaximumResourceCapability()
Get maximum allocatable
Resource . |
Resource |
YarnScheduler.getMinimumResourceCapability()
Get minimum allocatable
Resource . |
SchedulerNodeReport |
YarnScheduler.getNodeReport(NodeId nodeId)
Get node resource usage report.
|
int |
YarnScheduler.getNumClusterNodes()
Get the number of nodes available in the cluster.
|
QueueInfo |
YarnScheduler.getQueueInfo(String queueName,
boolean includeChildQueues,
boolean recursive)
Get queue information
|
List<QueueUserACLInfo> |
YarnScheduler.getQueueUserAclInfo()
Get acls for queues for current user.
|
SchedulerAppReport |
YarnScheduler.getSchedulerAppInfo(ApplicationAttemptId appAttemptId)
Get the Scheduler app for a given app attempt Id.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CSQueue
CSQueue represents a node in the tree of
hierarchical queues in the CapacityScheduler . |
Modifier and Type | Method and Description |
---|---|
Resource |
FiCaSchedulerApp.getCurrentReservation()
Get total current reservations.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Clock
A simple clock interface that gives you time.
|
class |
SystemClock
Implementation of
Clock that gives the current time from the system
clock in milliseconds. |
Copyright © 2013 Apache Software Foundation. All rights reserved.