程序包 | 说明 |
---|---|
org.apache.hadoop.contrib.index.example | |
org.apache.hadoop.contrib.index.mapred | |
org.apache.hadoop.contrib.utils.join | |
org.apache.hadoop.examples |
Hadoop example code.
|
org.apache.hadoop.examples.dancing |
This package is a distributed implementation of Knuth's dancing links
algorithm that can run under Hadoop.
|
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.aggregate |
Classes for performing various counting and aggregations.
|
org.apache.hadoop.streaming |
Hadoop Streaming is a utility which allows users to create and run
Map-Reduce jobs with any executables (e.g.
|
org.apache.hadoop.tools |
限定符和类型 | 类和说明 |
---|---|
class |
IdentityLocalAnalysis
Identity local analysis maps inputs directly into outputs.
|
class |
LineDocLocalAnalysis
Convert LineDocTextAndOp to DocumentAndOp as required by ILocalAnalysis.
|
限定符和类型 | 接口和说明 |
---|---|
interface |
ILocalAnalysis<K extends WritableComparable,V extends Writable>
Application specific local analysis.
|
限定符和类型 | 类和说明 |
---|---|
class |
IndexUpdateMapper<K extends WritableComparable,V extends Writable>
This class applies local analysis on a key-value pair and then convert the
result docid-operation pair to a shard-and-intermediate form pair.
|
限定符和类型 | 类和说明 |
---|---|
class |
DataJoinMapperBase
This abstract class serves as the base class for the mapper class of a data
join job.
|
class |
DataJoinReducerBase
This abstract class serves as the base class for the reducer class of a data
join job.
|
class |
JobBase
A common base implementing some statics collecting mechanisms that are
commonly used in a typical map/reduce job.
|
限定符和类型 | 类和说明 |
---|---|
static class |
MultiFileWordCount.MapClass
This Mapper is similar to the one in
WordCount.MapClass . |
static class |
PiEstimator.PiMapper
Mapper class for Pi estimation.
|
class |
SleepJob
Dummy class for testing MR framefork.
|
限定符和类型 | 类和说明 |
---|---|
static class |
DistributedPentomino.PentMap
Each map takes a line, which represents a prefix move and finds all of
the solutions that start with that prefix.
|
限定符和类型 | 类和说明 |
---|---|
static class |
TeraGen.SortGenMapper
The Mapper class that given a row number, will generate the appropriate
output line.
|
限定符和类型 | 方法和说明 |
---|---|
protected Mapper<K1,V1,K2,V2> |
MapRunner.getMapper() |
限定符和类型 | 方法和说明 |
---|---|
Class<? extends Mapper> |
JobConf.getMapperClass()
Get the
Mapper class for the job. |
限定符和类型 | 方法和说明 |
---|---|
void |
JobConf.setMapperClass(Class<? extends Mapper> theClass)
Set the
Mapper class for the job. |
限定符和类型 | 类和说明 |
---|---|
class |
ChainMapper
The ChainMapper class allows to use multiple Mapper classes within a single
Map task.
|
class |
DelegatingMapper<K1,V1,K2,V2>
An
Mapper that delegates behaviour of paths to multiple other
mappers. |
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 |
IdentityMapper<K,V>
Implements the identity function, mapping inputs directly to outputs.
|
class |
InverseMapper<K,V>
A
Mapper that swaps keys and values. |
class |
RegexMapper<K>
A
Mapper that extracts text matching a regular expression. |
class |
TokenCountMapper<K>
A
Mapper that maps text values into |
限定符和类型 | 方法和说明 |
---|---|
static void |
MultipleInputs.addInputPath(JobConf conf,
Path path,
Class<? extends InputFormat> inputFormatClass,
Class<? extends Mapper> mapperClass)
|
static <K1,V1,K2,V2> |
ChainReducer.addMapper(JobConf job,
Class<? extends Mapper<K1,V1,K2,V2>> klass,
Class<? extends K1> inputKeyClass,
Class<? extends V1> inputValueClass,
Class<? extends K2> outputKeyClass,
Class<? extends V2> outputValueClass,
boolean byValue,
JobConf mapperConf)
Adds a Mapper class to the chain job's JobConf.
|
static <K1,V1,K2,V2> |
ChainMapper.addMapper(JobConf job,
Class<? extends Mapper<K1,V1,K2,V2>> klass,
Class<? extends K1> inputKeyClass,
Class<? extends V1> inputValueClass,
Class<? extends K2> outputKeyClass,
Class<? extends V2> outputValueClass,
boolean byValue,
JobConf mapperConf)
Adds a Mapper class to the chain job's JobConf.
|
限定符和类型 | 类和说明 |
---|---|
class |
ValueAggregatorCombiner<K1 extends WritableComparable,V1 extends Writable>
This class implements the generic combiner of Aggregate.
|
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 |
PipeMapper
A generic Mapper bridge.
|
限定符和类型 | 类和说明 |
---|---|
static class |
Logalyzer.LogRegexMapper<K extends WritableComparable>
A
Mapper that extracts text matching a regular expression. |
Copyright © 2009 The Apache Software Foundation