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

Packages that use Reducer
org.apache.hadoop.mapred   
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.map   
org.apache.hadoop.mapreduce.lib.reduce   
org.apache.hadoop.mapreduce.task   
 

Uses of Reducer in org.apache.hadoop.mapred
 

Methods in org.apache.hadoop.mapred with parameters of type Reducer
protected static
<INKEY,INVALUE,OUTKEY,OUTVALUE>
Reducer.Context
Task.createReduceContext(Reducer<INKEY,INVALUE,OUTKEY,OUTVALUE> reducer, org.apache.hadoop.conf.Configuration job, TaskAttemptID taskId, RawKeyValueIterator rIter, Counter inputKeyCounter, Counter inputValueCounter, RecordWriter<OUTKEY,OUTVALUE> output, OutputCommitter committer, StatusReporter reporter, org.apache.hadoop.io.RawComparator<INKEY> comparator, Class<INKEY> keyClass, Class<INVALUE> valueClass)
           
 

Uses of Reducer in org.apache.hadoop.mapreduce
 

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

Method parameters in org.apache.hadoop.mapreduce with type arguments of type Reducer
 void Job.setCombinerClass(Class<? extends Reducer> cls)
          Set the combiner class for the job.
 void Job.setReducerClass(Class<? extends Reducer> cls)
          Set the Reducer for the job.
 

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

Subclasses of Reducer in org.apache.hadoop.mapreduce.lib.aggregate
 class ValueAggregatorCombiner<K1 extends WritableComparable<?>,V1 extends Writable>
          This class implements the generic combiner of Aggregate.
 class ValueAggregatorReducer<K1 extends WritableComparable<?>,V1 extends Writable>
          This class implements the generic reducer of Aggregate.
 

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

Subclasses of Reducer in org.apache.hadoop.mapreduce.lib.chain
 class ChainReducer<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
          The ChainReducer class allows to chain multiple Mapper classes after a Reducer within the Reducer task.
 

Method parameters in org.apache.hadoop.mapreduce.lib.chain with type arguments of type Reducer
static void ChainReducer.setReducer(Job job, Class<? extends Reducer> klass, Class<?> inputKeyClass, Class<?> inputValueClass, Class<?> outputKeyClass, Class<?> outputValueClass, org.apache.hadoop.conf.Configuration reducerConf)
          Sets the Reducer class to the chain job.
protected static void Chain.setReducer(Job job, Class<? extends Reducer> klass, Class<?> inputKeyClass, Class<?> inputValueClass, Class<?> outputKeyClass, Class<?> outputValueClass, org.apache.hadoop.conf.Configuration reducerConf)
          Sets the Reducer class to the chain job.
 

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

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

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

Methods in org.apache.hadoop.mapreduce.lib.map that return types with arguments of type Reducer
 Class<? extends Reducer<?,?,?,?>> WrappedMapper.Context.getCombinerClass()
           
 Class<? extends Reducer<?,?,?,?>> WrappedMapper.Context.getReducerClass()
           
 

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

Subclasses of Reducer in org.apache.hadoop.mapreduce.lib.reduce
 class IntSumReducer<Key>
           
 class LongSumReducer<KEY>
           
 class WrappedReducer<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
          A Reducer which wraps a given one to allow for custom WrappedReducer.Context implementations.
 

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

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

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



Copyright © 2014 Apache Software Foundation. All Rights Reserved.