Uses of Interface
org.apache.hadoop.mapred.Mapper

Packages that use Mapper
org.apache.hadoop.mapred   
org.apache.hadoop.mapred.lib   
org.apache.hadoop.mapred.lib.aggregate   
 

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 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 pairs.
 

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
<K1,V1,K2,V2>
void
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.
static
<K1,V1,K2,V2>
void
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.
 

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.
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.