| 
 | ||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
| 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 Mapperclass 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 Mapperfor 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 | |
|---|---|
| static void | ChainMapper.addMapper(Job job,
                   Class<? extends Mapper> klass,
                   Class<?> inputKeyClass,
                   Class<?> inputValueClass,
                   Class<?> outputKeyClass,
                   Class<?> outputValueClass,
                   Configuration mapperConf)Adds a Mapperclass to the chain mapper. | 
| static void | ChainReducer.addMapper(Job job,
                   Class<? extends Mapper> klass,
                   Class<?> inputKeyClass,
                   Class<?> inputValueClass,
                   Class<?> outputKeyClass,
                   Class<?> outputValueClass,
                   Configuration mapperConf)Adds a Mapperclass 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 | 
|---|
| Method parameters in org.apache.hadoop.mapreduce.lib.input with type arguments of type Mapper | |
|---|---|
| static void | MultipleInputs.addInputPath(Job job,
                         Path path,
                         Class<? extends InputFormat> inputFormatClass,
                         Class<? extends Mapper> mapperClass)Add a Pathwith a customInputFormatandMapperto 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 Mapperthat swaps keys and values. | 
|  class | MultithreadedMapper<K1,V1,K2,V2>Multithreaded implementation for @link org.apache.hadoop.mapreduce.Mapper. | 
|  class | RegexMapper<K>A Mapperthat extracts text matching a regular expression. | 
|  class | TokenCounterMapperTokenize the input values and emit each word with a count of 1. | 
|  class | WrappedMapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT>A Mapperwhich wraps a given one to allow customWrappedMapper.Contextimplementations. | 
| Methods in org.apache.hadoop.mapreduce.lib.map that return types with arguments of type Mapper | ||
|---|---|---|
| static
 | 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
 | MultithreadedMapper.setMapperClass(Job job,
                             Class<? extends Mapper<K1,V1,K2,V2>> cls)Set the application's mapper class. | |
| 
 | ||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||