程序包 | 说明 |
---|---|
org.apache.hadoop.contrib.index.example | |
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.join |
Given a set of sorted datasets keyed with the same class and yielding equal
partitions, it is possible to effect a join of those datasets prior to the map.
|
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.streaming |
Hadoop Streaming is a utility which allows users to create and run
Map-Reduce jobs with any executables (e.g.
|
限定符和类型 | 类和说明 |
---|---|
class |
LineDocRecordReader
A simple RecordReader for LineDoc for plain text files where each line is a
doc.
|
限定符和类型 | 方法和说明 |
---|---|
RecordReader<DocumentID,LineDocTextAndOp> |
LineDocInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
限定符和类型 | 类和说明 |
---|---|
static class |
MultiFileWordCount.MultiFileLineRecordReader
RecordReader is responsible from extracting records from the InputSplit.
|
限定符和类型 | 方法和说明 |
---|---|
RecordReader<IntWritable,IntWritable> |
SleepJob.SleepInputFormat.getRecordReader(InputSplit ignored,
JobConf conf,
Reporter reporter) |
RecordReader<MultiFileWordCount.WordOffset,Text> |
MultiFileWordCount.MyInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
限定符和类型 | 方法和说明 |
---|---|
RecordReader<Text,Text> |
TeraInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
限定符和类型 | 类和说明 |
---|---|
class |
KeyValueLineRecordReader
This class treats a line in the input as a key/value pair separated by a
separator character.
|
class |
LineRecordReader
Treats keys as offset in file and value as line.
|
static class |
SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Read records from a SequenceFile as binary (raw) bytes.
|
class |
SequenceFileAsTextRecordReader
This class converts the input keys and values to their String forms by calling toString()
method.
|
class |
SequenceFileRecordReader<K,V>
An
RecordReader for SequenceFile s. |
限定符和类型 | 方法和说明 |
---|---|
RecordReader<LongWritable,Text> |
TextInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
RecordReader<K,V> |
SequenceFileInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
RecordReader<K,V> |
SequenceFileInputFilter.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter)
Create a record reader for the given split
|
RecordReader<Text,Text> |
SequenceFileAsTextInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
RecordReader<BytesWritable,BytesWritable> |
SequenceFileAsBinaryInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
abstract RecordReader<K,V> |
MultiFileInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter)
已过时。
|
RecordReader<Text,Text> |
KeyValueTextInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
RecordReader<K,V> |
InputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter)
Get the
RecordReader for the given InputSplit . |
abstract RecordReader<K,V> |
FileInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
限定符和类型 | 方法和说明 |
---|---|
void |
MapRunner.run(RecordReader<K1,V1> input,
OutputCollector<K2,V2> output,
Reporter reporter) |
void |
MapRunnable.run(RecordReader<K1,V1> input,
OutputCollector<K2,V2> output,
Reporter reporter)
Start mapping input <key, value> pairs.
|
限定符和类型 | 接口和说明 |
---|---|
interface |
ComposableRecordReader<K extends WritableComparable,V extends Writable>
Additional operations required of a RecordReader to participate in a join.
|
限定符和类型 | 类和说明 |
---|---|
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.
|
class |
WrappedRecordReader<K extends WritableComparable,U extends Writable>
Proxy class for a RecordReader participating in the join framework.
|
限定符和类型 | 类和说明 |
---|---|
class |
CombineFileRecordReader<K,V>
A generic RecordReader that can hand out different recordReaders
for each chunk in a
CombineFileSplit . |
限定符和类型 | 字段和说明 |
---|---|
protected RecordReader<K,V> |
CombineFileRecordReader.curReader |
限定符和类型 | 字段和说明 |
---|---|
protected Class<RecordReader<K,V>> |
CombineFileRecordReader.rrClass |
protected Constructor<RecordReader<K,V>> |
CombineFileRecordReader.rrConstructor |
限定符和类型 | 方法和说明 |
---|---|
RecordReader<LongWritable,Text> |
NLineInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
RecordReader<K,V> |
DelegatingInputFormat.getRecordReader(InputSplit split,
JobConf conf,
Reporter reporter) |
abstract RecordReader<K,V> |
CombineFileInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter)
This is not implemented yet.
|
限定符和类型 | 方法和说明 |
---|---|
void |
MultithreadedMapRunner.run(RecordReader<K1,V1> input,
OutputCollector<K2,V2> output,
Reporter reporter) |
构造器和说明 |
---|
CombineFileRecordReader(JobConf job,
CombineFileSplit split,
Reporter reporter,
Class<RecordReader<K,V>> rrClass)
A generic RecordReader that can hand out different recordReaders
for each chunk in the CombineFileSplit.
|
限定符和类型 | 类和说明 |
---|---|
protected class |
DBInputFormat.DBRecordReader
A RecordReader that reads records from a SQL table.
|
限定符和类型 | 方法和说明 |
---|---|
RecordReader<LongWritable,T> |
DBInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter)
Get the
RecordReader for the given InputSplit . |
限定符和类型 | 类和说明 |
---|---|
class |
StreamBaseRecordReader
Shared functionality for hadoopStreaming formats.
|
class |
StreamXmlRecordReader
A way to interpret XML fragments as Mapper input records.
|
限定符和类型 | 方法和说明 |
---|---|
RecordReader<Text,Text> |
StreamInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
RecordReader |
AutoInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
限定符和类型 | 方法和说明 |
---|---|
void |
PipeMapRunner.run(RecordReader<K1,V1> input,
OutputCollector<K2,V2> output,
Reporter reporter) |
Copyright © 2009 The Apache Software Foundation