|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use Mapper | |
---|---|
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. |
Uses of Mapper in org.apache.hadoop.contrib.index.example |
---|
Classes in org.apache.hadoop.contrib.index.example that implement Mapper | |
---|---|
class |
IdentityLocalAnalysis
Identity local analysis maps inputs directly into outputs. |
class |
LineDocLocalAnalysis
Convert LineDocTextAndOp to DocumentAndOp as required by ILocalAnalysis. |
Uses of Mapper in org.apache.hadoop.contrib.index.mapred |
---|
Subinterfaces of Mapper in org.apache.hadoop.contrib.index.mapred | |
---|---|
interface |
ILocalAnalysis<K extends WritableComparable,V extends Writable>
Application specific local analysis. |
Classes in org.apache.hadoop.contrib.index.mapred that implement Mapper | |
---|---|
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. |
Uses of Mapper in org.apache.hadoop.contrib.utils.join |
---|
Classes in org.apache.hadoop.contrib.utils.join that implement Mapper | |
---|---|
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. |
Uses of Mapper in org.apache.hadoop.examples |
---|
Classes in org.apache.hadoop.examples that implement Mapper | |
---|---|
static class |
MultiFileWordCount.MapClass
This Mapper is similar to the one in MultiFileWordCount.MapClass . |
static class |
PiEstimator.PiMapper
Mapper class for Pi estimation. |
class |
SleepJob
Dummy class for testing MR framefork. |
Uses of Mapper in org.apache.hadoop.examples.dancing |
---|
Classes in org.apache.hadoop.examples.dancing that implement Mapper | |
---|---|
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. |
Uses of Mapper in org.apache.hadoop.examples.terasort |
---|
Classes in org.apache.hadoop.examples.terasort that implement Mapper | |
---|---|
static class |
TeraGen.SortGenMapper
The Mapper class that given a row number, will generate the appropriate output line. |
Uses of Mapper in org.apache.hadoop.mapred |
---|
Methods in org.apache.hadoop.mapred that return Mapper | |
---|---|
protected Mapper<K1,V1,K2,V2> |
MapRunner.getMapper()
|
Methods in org.apache.hadoop.mapred that return types with arguments of type Mapper | |
---|---|
Class<? extends Mapper> |
JobConf.getMapperClass()
Get the Mapper class for the job. |
Method parameters in org.apache.hadoop.mapred with type arguments of type Mapper | |
---|---|
void |
JobConf.setMapperClass(Class<? extends Mapper> theClass)
Set the Mapper class for the job. |
Uses of Mapper in org.apache.hadoop.mapred.lib |
---|
Classes in org.apache.hadoop.mapred.lib that implement Mapper | |
---|---|
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 |
Method parameters in org.apache.hadoop.mapred.lib with type arguments of type Mapper | ||
---|---|---|
static void |
MultipleInputs.addInputPath(JobConf conf,
Path path,
Class<? extends InputFormat> inputFormatClass,
Class<? extends Mapper> mapperClass)
Add a Path with a custom InputFormat and
Mapper to the list of inputs for the map-reduce job. |
|
static
|
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
|
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. |
Uses of Mapper in org.apache.hadoop.mapred.lib.aggregate |
---|
Classes in org.apache.hadoop.mapred.lib.aggregate that implement Mapper | |
---|---|
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. |
Uses of Mapper in org.apache.hadoop.streaming |
---|
Classes in org.apache.hadoop.streaming that implement Mapper | |
---|---|
class |
PipeMapper
A generic Mapper bridge. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |