程序包 | 说明 |
---|---|
org.apache.hadoop.classification | |
org.apache.hadoop.log.metrics | |
org.apache.hadoop.mapreduce.lib.db | |
org.apache.hadoop.mapreduce.lib.fieldsel | |
org.apache.hadoop.mapreduce.lib.input | |
org.apache.hadoop.mapreduce.lib.jobcontrol | |
org.apache.hadoop.mapreduce.lib.output | |
org.apache.hadoop.mapreduce.lib.partition | |
org.apache.hadoop.metrics.file |
Implementation of the metrics package that writes the metrics to a file.
|
org.apache.hadoop.metrics.ganglia |
Implementation of the metrics package that sends metric data to
Ganglia.
|
org.apache.hadoop.metrics.spi |
Note, this package is deprecated in favor of
org.apache.hadoop.metrics2 usage. |
org.apache.hadoop.net |
Network-related classes.
|
限定符和类型 | 类和说明 |
---|---|
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.
|
限定符和类型 | 类和说明 |
---|---|
class |
EventCounter
A log4J Appender that simply counts logging events in three levels:
fatal, error and warn.
|
限定符和类型 | 类和说明 |
---|---|
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.
|
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.
|
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.
|
class |
DBRecordReader<T extends DBWritable>
A RecordReader that reads records from a SQL table.
|
interface |
DBSplitter
DBSplitter will generate DBInputSplits to use with DataDrivenDBInputFormat.
|
interface |
DBWritable
Objects that are read from/written to a database should implement
DBWritable . |
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.
|
限定符和类型 | 类和说明 |
---|---|
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.
|
限定符和类型 | 类和说明 |
---|---|
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 |
CombineFileSplit
A sub-collection of input files.
|
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 |
ControlledJob
This class encapsulates a MapReduce job and its dependency.
|
class |
JobControl
This class encapsulates a set of MapReduce jobs and its dependency.
|
限定符和类型 | 类和说明 |
---|---|
class |
FilterOutputFormat<K,V>
FilterOutputFormat is a convenience class that wraps OutputFormat.
|
class |
LazyOutputFormat<K,V>
A Convenience class that creates output lazily.
|
class |
MultipleOutputs<KEYOUT,VALUEOUT>
The MultipleOutputs class simplifies writing output data
to multiple outputs
Case one: writing to additional outputs other than the job default output.
|
class |
SequenceFileAsBinaryOutputFormat
An
OutputFormat that writes keys,
values to SequenceFile s in binary(raw) format |
限定符和类型 | 类和说明 |
---|---|
class |
BinaryPartitioner<V>
Partition
BinaryComparable keys using a configurable part of
the bytes array returned by BinaryComparable.getBytes() . |
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.
|
限定符和类型 | 类和说明 |
---|---|
class |
FileContext
已过时。
use
FileSink instead. |
限定符和类型 | 类和说明 |
---|---|
class |
GangliaContext
已过时。
in favor of
org.apache.hadoop.metrics2 usage. |
限定符和类型 | 类和说明 |
---|---|
class |
AbstractMetricsContext
已过时。
in favor of
org.apache.hadoop.metrics2 usage. |
class |
CompositeContext
已过时。
in favor of
org.apache.hadoop.metrics2 usage. |
class |
MetricsRecordImpl
已过时。
in favor of
org.apache.hadoop.metrics2 usage. |
class |
MetricValue
已过时。
in favor of
org.apache.hadoop.metrics2 usage. |
class |
NoEmitMetricsContext
已过时。
in favor of
org.apache.hadoop.metrics2 usage. |
class |
NullContext
已过时。
in favor of
org.apache.hadoop.metrics2 usage. |
class |
NullContextWithUpdateThread
已过时。
in favor of
org.apache.hadoop.metrics2 usage. |
class |
OutputRecord
已过时。
in favor of
org.apache.hadoop.metrics2 usage. |
class |
Util
Static utility methods
|
限定符和类型 | 接口和说明 |
---|---|
interface |
DNSToSwitchMapping
An interface that should be implemented to allow pluggable
DNS-name/IP-address to RackID resolvers.
|
Copyright © 2009 The Apache Software Foundation