| 
 | ||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
| Packages that use Reducer.Context | |
|---|---|
| org.apache.hadoop.examples | Hadoop example code. | 
| 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.mapreduce | |
| org.apache.hadoop.mapreduce.lib.fieldsel | |
| org.apache.hadoop.mapreduce.lib.reduce | |
| Uses of Reducer.Context in org.apache.hadoop.examples | 
|---|
| Methods in org.apache.hadoop.examples with parameters of type Reducer.Context | |
|---|---|
|  void | SecondarySort.Reduce.reduce(SecondarySort.IntPair key,
       Iterable<IntWritable> values,
       Reducer.Context context) | 
|  void | WordCount.IntSumReducer.reduce(Text key,
       Iterable<IntWritable> values,
       Reducer.Context context) | 
| Uses of Reducer.Context in org.apache.hadoop.mapred | 
|---|
| Methods in org.apache.hadoop.mapred that return Reducer.Context | ||
|---|---|---|
| protected static
 | Task.createReduceContext(Reducer<INKEY,INVALUE,OUTKEY,OUTVALUE> reducer,
                    Configuration job,
                    TaskAttemptID taskId,
                    RawKeyValueIterator rIter,
                    Counter inputKeyCounter,
                    Counter inputValueCounter,
                    RecordWriter<OUTKEY,OUTVALUE> output,
                    OutputCommitter committer,
                    StatusReporter reporter,
                    RawComparator<INKEY> comparator,
                    Class<INKEY> keyClass,
                    Class<INVALUE> valueClass) | |
| Uses of Reducer.Context in org.apache.hadoop.mapreduce | 
|---|
| Methods in org.apache.hadoop.mapreduce with parameters of type Reducer.Context | |
|---|---|
| protected  void | Reducer.cleanup(Reducer.Context context)Called once at the end of the task. | 
| protected  void | Reducer.reduce(KEYIN key,
       Iterable<VALUEIN> values,
       Reducer.Context context)This method is called once for each key. | 
|  void | Reducer.run(Reducer.Context context)Advanced application writers can use the Reducer.run(org.apache.hadoop.mapreduce.Reducer.Context)method to
 control how the reduce task works. | 
| protected  void | Reducer.setup(Reducer.Context context)Called once at the start of the task. | 
| Uses of Reducer.Context in org.apache.hadoop.mapreduce.lib.fieldsel | 
|---|
| Methods in org.apache.hadoop.mapreduce.lib.fieldsel with parameters of type Reducer.Context | |
|---|---|
|  void | FieldSelectionReducer.reduce(Text key,
       Iterable<Text> values,
       Reducer.Context context) | 
|  void | FieldSelectionReducer.setup(Reducer.Context context) | 
| Uses of Reducer.Context in org.apache.hadoop.mapreduce.lib.reduce | 
|---|
| Methods in org.apache.hadoop.mapreduce.lib.reduce with parameters of type Reducer.Context | |
|---|---|
|  void | IntSumReducer.reduce(Key key,
       Iterable<IntWritable> values,
       Reducer.Context context) | 
|  void | LongSumReducer.reduce(KEY key,
       Iterable<LongWritable> values,
       Reducer.Context context) | 
| 
 | ||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||