Uses of Class
org.apache.hadoop.mapreduce.Mapper

Packages that use Mapper
org.apache.hadoop.mapreduce   
org.apache.hadoop.mapreduce.lib.aggregate   
org.apache.hadoop.mapreduce.lib.chain   
org.apache.hadoop.mapreduce.lib.fieldsel   
org.apache.hadoop.mapreduce.lib.input   
org.apache.hadoop.mapreduce.lib.map   
org.apache.hadoop.mapreduce.lib.reduce   
org.apache.hadoop.mapreduce.task   
 

Uses of Mapper in org.apache.hadoop.mapreduce
 

Methods in org.apache.hadoop.mapreduce that return types with arguments of type Mapper
 Class<? extends Mapper<?,?,?,?>> JobContext.getMapperClass()
          Get the Mapper class for the job.
 

Method parameters in org.apache.hadoop.mapreduce with type arguments of type Mapper
 void Job.setMapperClass(Class<? extends Mapper> cls)
          Set the Mapper for the job.
 

Uses of Mapper in org.apache.hadoop.mapreduce.lib.aggregate
 

Subclasses of Mapper in org.apache.hadoop.mapreduce.lib.aggregate
 class ValueAggregatorMapper<K1 extends WritableComparable<?>,V1 extends Writable>
          This class implements the generic mapper of Aggregate.
 

Uses of Mapper in org.apache.hadoop.mapreduce.lib.chain
 

Subclasses of Mapper in org.apache.hadoop.mapreduce.lib.chain
 class ChainMapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
          The ChainMapper class allows to use multiple Mapper classes within a single Map task.
 

Method parameters in org.apache.hadoop.mapreduce.lib.chain with type arguments of type Mapper
protected static void Chain.addMapper(boolean isMap, Job job, Class<? extends Mapper> klass, Class<?> inputKeyClass, Class<?> inputValueClass, Class<?> outputKeyClass, Class<?> outputValueClass, org.apache.hadoop.conf.Configuration mapperConf)
          Adds a Mapper class to the chain job.
static void ChainMapper.addMapper(Job job, Class<? extends Mapper> klass, Class<?> inputKeyClass, Class<?> inputValueClass, Class<?> outputKeyClass, Class<?> outputValueClass, org.apache.hadoop.conf.Configuration mapperConf)
          Adds a Mapper class to the chain mapper.
static void ChainReducer.addMapper(Job job, Class<? extends Mapper> klass, Class<?> inputKeyClass, Class<?> inputValueClass, Class<?> outputKeyClass, Class<?> outputValueClass, org.apache.hadoop.conf.Configuration mapperConf)
          Adds a Mapper class to the chain reducer.
 

Uses of Mapper in org.apache.hadoop.mapreduce.lib.fieldsel
 

Subclasses of Mapper in org.apache.hadoop.mapreduce.lib.fieldsel
 class FieldSelectionMapper<K,V>
          This class implements a mapper class that can be used to perform field selections in a manner similar to unix cut.
 

Uses of Mapper in org.apache.hadoop.mapreduce.lib.input
 

Subclasses of Mapper in org.apache.hadoop.mapreduce.lib.input
 class DelegatingMapper<K1,V1,K2,V2>
          An Mapper that delegates behavior of paths to multiple other mappers.
 

Method parameters in org.apache.hadoop.mapreduce.lib.input with type arguments of type Mapper
static void MultipleInputs.addInputPath(Job job, org.apache.hadoop.fs.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.
 

Uses of Mapper in org.apache.hadoop.mapreduce.lib.map
 

Subclasses of Mapper in org.apache.hadoop.mapreduce.lib.map
 class InverseMapper<K,V>
          A Mapper that swaps keys and values.
 class MultithreadedMapper<K1,V1,K2,V2>
          Multithreaded implementation for @link org.apache.hadoop.mapreduce.Mapper.
 class RegexMapper<K>
          A Mapper that extracts text matching a regular expression.
 class TokenCounterMapper
          Tokenize the input values and emit each word with a count of 1.
 class WrappedMapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
          A Mapper which wraps a given one to allow custom WrappedMapper.Context implementations.
 

Methods in org.apache.hadoop.mapreduce.lib.map that return types with arguments of type Mapper
 Class<? extends Mapper<?,?,?,?>> WrappedMapper.Context.getMapperClass()
           
static
<K1,V1,K2,V2>
Class<Mapper<K1,V1,K2,V2>>
MultithreadedMapper.getMapperClass(JobContext job)
          Get the application's mapper class.
 

Method parameters in org.apache.hadoop.mapreduce.lib.map with type arguments of type Mapper
static
<K1,V1,K2,V2>
void
MultithreadedMapper.setMapperClass(Job job, Class<? extends Mapper<K1,V1,K2,V2>> cls)
          Set the application's mapper class.
 

Uses of Mapper in org.apache.hadoop.mapreduce.lib.reduce
 

Methods in org.apache.hadoop.mapreduce.lib.reduce that return types with arguments of type Mapper
 Class<? extends Mapper<?,?,?,?>> WrappedReducer.Context.getMapperClass()
           
 

Uses of Mapper in org.apache.hadoop.mapreduce.task
 

Methods in org.apache.hadoop.mapreduce.task that return types with arguments of type Mapper
 Class<? extends Mapper<?,?,?,?>> JobContextImpl.getMapperClass()
          Get the Mapper class for the job.
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.