程序包 | 说明 |
---|---|
org.apache.hadoop.examples |
Hadoop example code.
|
org.apache.hadoop.examples.terasort |
This package consists of 3 map/reduce applications for Hadoop to
compete in the annual terabyte sort
competition.
|
org.apache.hadoop.mapred |
A software framework for easily writing applications which process vast
amounts of data (multi-terabyte data-sets) parallelly on large clusters
(thousands of nodes) built of commodity hardware in a reliable, fault-tolerant
manner.
|
org.apache.hadoop.mapred.lib |
Library of generally useful mappers, reducers, and partitioners.
|
org.apache.hadoop.mapred.lib.db |
org.apache.hadoop.mapred.lib.db Package
This package contains a library to read records from a database as an
input to a mapreduce job, and write the output records to the database.
|
org.apache.hadoop.mapreduce.lib.db | |
org.apache.hadoop.mapreduce.lib.input | |
org.apache.hadoop.mapreduce.lib.reduce | |
org.apache.hadoop.tools | |
org.apache.hadoop.typedbytes |
Typed bytes are sequences of bytes in which the first byte is a type code.
|
限定符和类型 | 方法和说明 |
---|---|
void |
PiEstimator.PiMapper.map(LongWritable offset,
LongWritable size,
OutputCollector<BooleanWritable,LongWritable> out,
Reporter reporter)
Map method.
|
void |
SecondarySort.MapClass.map(LongWritable inKey,
Text inValue,
Mapper.Context context) |
限定符和类型 | 方法和说明 |
---|---|
void |
PiEstimator.PiMapper.map(LongWritable offset,
LongWritable size,
OutputCollector<BooleanWritable,LongWritable> out,
Reporter reporter)
Map method.
|
void |
MultiFileWordCount.MapClass.map(MultiFileWordCount.WordOffset key,
Text value,
OutputCollector<Text,LongWritable> output,
Reporter reporter) |
void |
PiEstimator.PiReducer.reduce(BooleanWritable isInside,
Iterator<LongWritable> values,
OutputCollector<WritableComparable<?>,Writable> output,
Reporter reporter)
Accumulate number of points inside/outside results from the mappers.
|
限定符和类型 | 方法和说明 |
---|---|
void |
TeraGen.SortGenMapper.map(LongWritable row,
NullWritable ignored,
OutputCollector<Text,Text> output,
Reporter reporter) |
限定符和类型 | 方法和说明 |
---|---|
LongWritable |
LineRecordReader.createKey() |
限定符和类型 | 方法和说明 |
---|---|
RecordReader<LongWritable,Text> |
TextInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
限定符和类型 | 方法和说明 |
---|---|
boolean |
LineRecordReader.next(LongWritable key,
Text value)
Read a line.
|
限定符和类型 | 方法和说明 |
---|---|
RecordReader<LongWritable,Text> |
NLineInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
限定符和类型 | 方法和说明 |
---|---|
void |
TokenCountMapper.map(K key,
Text value,
OutputCollector<Text,LongWritable> output,
Reporter reporter) |
void |
RegexMapper.map(K key,
Text value,
OutputCollector<Text,LongWritable> output,
Reporter reporter) |
void |
LongSumReducer.reduce(K key,
Iterator<LongWritable> values,
OutputCollector<K,LongWritable> output,
Reporter reporter) |
void |
LongSumReducer.reduce(K key,
Iterator<LongWritable> values,
OutputCollector<K,LongWritable> output,
Reporter reporter) |
限定符和类型 | 方法和说明 |
---|---|
LongWritable |
DBInputFormat.DBRecordReader.createKey()
Create an object of the appropriate type to be used as a key.
|
限定符和类型 | 方法和说明 |
---|---|
RecordReader<LongWritable,T> |
DBInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter)
Get the
RecordReader for the given InputSplit . |
限定符和类型 | 方法和说明 |
---|---|
boolean |
DBInputFormat.DBRecordReader.next(LongWritable key,
T value)
Reads the next key/value pair from the input for processing.
|
限定符和类型 | 方法和说明 |
---|---|
LongWritable |
DBRecordReader.getCurrentKey()
Get the current key
|
限定符和类型 | 方法和说明 |
---|---|
protected RecordReader<LongWritable,T> |
OracleDataDrivenDBInputFormat.createDBRecordReader(DBInputFormat.DBInputSplit split,
Configuration conf) |
protected RecordReader<LongWritable,T> |
DBInputFormat.createDBRecordReader(DBInputFormat.DBInputSplit split,
Configuration conf) |
protected RecordReader<LongWritable,T> |
DataDrivenDBInputFormat.createDBRecordReader(DBInputFormat.DBInputSplit split,
Configuration conf) |
RecordReader<LongWritable,T> |
DBInputFormat.createRecordReader(InputSplit split,
TaskAttemptContext context)
Create a record reader for a given split.
|
限定符和类型 | 方法和说明 |
---|---|
boolean |
DBRecordReader.next(LongWritable key,
T value)
已过时。
|
限定符和类型 | 方法和说明 |
---|---|
LongWritable |
LineRecordReader.getCurrentKey() |
限定符和类型 | 方法和说明 |
---|---|
RecordReader<LongWritable,Text> |
TextInputFormat.createRecordReader(InputSplit split,
TaskAttemptContext context) |
RecordReader<LongWritable,Text> |
NLineInputFormat.createRecordReader(InputSplit genericSplit,
TaskAttemptContext context) |
限定符和类型 | 方法和说明 |
---|---|
void |
LongSumReducer.reduce(KEY key,
Iterable<LongWritable> values,
Reducer.Context context) |
限定符和类型 | 方法和说明 |
---|---|
void |
Logalyzer.LogRegexMapper.map(K key,
Text value,
OutputCollector<Text,LongWritable> output,
Reporter reporter) |
限定符和类型 | 方法和说明 |
---|---|
LongWritable |
TypedBytesWritableInput.readLong() |
LongWritable |
TypedBytesWritableInput.readLong(LongWritable lw) |
限定符和类型 | 方法和说明 |
---|---|
LongWritable |
TypedBytesWritableInput.readLong(LongWritable lw) |
void |
TypedBytesWritableOutput.writeLong(LongWritable lw) |
Copyright © 2009 The Apache Software Foundation