Example usage for org.apache.hadoop.mapreduce Reducer subclass-usage

List of usage examples for org.apache.hadoop.mapreduce Reducer subclass-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.mapreduce Reducer subclass-usage.

Usage

From source file com.yosanai.tutorial.hadoop.hellohadoop.WordCountReducer.java

/**
 * @author Saravana P Shanmugam
 * 
 */
public class WordCountReducer extends Reducer<Text, IntWritable, Text, IntWritable> {
    protected void reduce(Text key, Iterable<IntWritable> values, Context context)

From source file com.yourcompany.hadoop.mapreduce.KoreanWordcountReducer.java

/**
 *   ?  ? Reducer
 *
 * @author Edward KIM
 * @version 0.1
 */

From source file com.yourcompany.hadoop.mapreduce.WordCount.KoreanWordcountReducer.java

/**
 *   ?  ? Reducer
 *
 * @author Edward KIM
 * @version 0.1
 */

From source file com.zinnia.nectar.regression.hadoop.primitive.mapreduce.DoubleSumReducer.java

public class DoubleSumReducer extends Reducer<Text, DoubleWritable, Text, DoubleWritable> {
    protected void reduce(Text key, Iterable<DoubleWritable> valueSet, Context context)
            throws IOException, InterruptedException {
        // TODO Auto-generated method stub
        Iterator<DoubleWritable> values = valueSet.iterator();
        double sum = 0;

From source file com.zinnia.nectar.util.hadoop.DoubleReducer.java

public class DoubleReducer extends Reducer<Text, DoubleWritable, Text, DoubleWritable> {

    protected void reduce(Text key, Iterable<DoubleWritable> values, Context context)
            throws IOException, InterruptedException {

        double sum = 0;

From source file com.zqh.hadoop.mr.Financial.HighLowDayReducer.java

/**
 * Hadoop MapReduce example showing high and low for a day across all stock symbols
 * 
 */
public class HighLowDayReducer extends Reducer<Text, DoubleWritable, Text, Text> {

From source file com.zqh.hadoop.mr.Financial.HighLowStockReducer.java

/**
 * Hadoop MapReduce example showing high and low for a stock symbol
 *
 */
public class HighLowStockReducer extends Reducer<Text, DoubleWritable, Text, Text> {

From source file com.zqh.hadoop.mr.Financial.HighLowWritableReducer.java

/**
 * Hadoop MapReduce example showing a custom Writable
 *
 */
public class HighLowWritableReducer extends Reducer<Text, StockWritable, Text, Text> {

From source file comm.IntSumReducer.java

/**
 * 
 * <p>
 * date author email notes<br />
 * ----------------------------------------------------------------<br />
 * 20141012  starqiu@mail.ustc.edu.cn <br />

From source file comm.PrintKeysReducer.java

/**
 *  ??Key
 * <p>
 * date           author            email                 notes<br />
 * ----------------------------------------------------------------<br />
 *20141014                 starqiu@mail.ustc.edu.cn       <br /></p>