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.cg.mapreduce.myfpgrowth.ParallelCountingReducer.java

/**
 *  sums up the item count and output the item and the count This can also be
 * used as a local Combiner. A simple summing reducer
 */
@Deprecated
public class ParallelCountingReducer extends Reducer<Text, LongWritable, Text, LongWritable> {

From source file com.cg.mapreduce.myfpgrowth.ParallelFPGrowthReducer.java

/**
 * takes each group of transactions and runs Vanilla FPGrowth on it and outputs
 * the the Top K frequent Patterns for each group.
 * 
 */

From source file com.chinnu.churndetection.fuzzykmeans.FuzzyKMeansReducer.java

/**
 *
 * @author libin
 */
public class FuzzyKMeansReducer extends Reducer<IntWritable, Vector, IntWritable, Text> {

From source file com.chinnu.churndetection.kmeans.KMeansReducer.java

/**
 *
 * @author libin
 */
public class KMeansReducer extends Reducer<IntWritable, Vector, IntWritable, Text> {

From source file com.ci.backports.hadoop.hbase.ZPutSortReducer.java

/**
 * Emits sorted Puts.
 * Reads in all Puts from passed Iterator, sorts them, then emits
 * Puts in sorted order.  If lots of columns per row, it will use lots of
 * memory sorting.
 * @see HFileOutputFormat

From source file com.citic.zxyjs.zwlscx.mapreduce.join.api.DataJoinReducerBase.java

/**
 * This abstract class serves as the base class for the reducer class of a data
 * join job. The reduce function will first group the values according to their
 * input tags, and then compute the cross product of over the groups. For each
 * tuple in the cross product, it calls the following method, which is expected
 * to be implemented in a subclass. protected abstract TaggedMapOutput

From source file com.ckelsel.hadoop.MaxTemperature.AppReducer.java

public class AppReducer extends Reducer<Text, IntWritable, Text, IntWritable> {

}

From source file com.cloudera.castagna.logparser.mr.StatusCodesStatsCombiner.java

public class StatusCodesStatsCombiner extends Reducer<Text, Text, Text, Text> {

    private static final Logger log = LoggerFactory.getLogger(StatusCodesStatsCombiner.class);

    private Text outTextValue = new Text();

From source file com.cloudera.castagna.logparser.mr.StatusCodesStatsReducer.java

public class StatusCodesStatsReducer extends Reducer<Text, Text, Text, Text> {

    private static final Logger log = LoggerFactory.getLogger(StatusCodesStatsReducer.class);

    private Text outTextKey = new Text();
    private Text outTextValue = new Text();

From source file com.cloudera.crunch.impl.mr.run.CrunchReducer.java

public class CrunchReducer extends Reducer<Object, Object, Object, Object> {

    private static final Log LOG = LogFactory.getLog(CrunchReducer.class);

    private RTNode node;
    private CrunchTaskContext ctxt;