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.jhkt.playgroundArena.hadoop.tasks.jobs.reducer.AverageMultipleOutputReducer.java

/**
 * @author Ji Hoon Kim
 */
public final class AverageMultipleOutputReducer extends Reducer<Text, AverageWritable, Text, DoubleWritable> {

    private MultipleOutputs<Text, DoubleWritable> _mOutputs;

From source file com.jhkt.playgroundArena.hadoop.tasks.jobs.reducer.AverageReducer.java

/**
 * @author Ji Hoon Kim
 */
public final class AverageReducer extends Reducer<Text, AverageWritable, Text, DoubleWritable> {

    private DoubleWritable _dWriter = new DoubleWritable();

From source file com.jhkt.playgroundArena.hadoop.tasks.jobs.reducer.BloomFilterReducer.java

/**
 * @author Ji Hoon Kim
 */
public class BloomFilterReducer extends Reducer<Text, BloomFilter, Text, Text> {

    private BloomFilter _bFilter = new BloomFilter();

From source file com.jhkt.playgroundArena.hadoop.tasks.jobs.reducer.CountReducer.java

/**
 * @author Ji Hoon Kim
 */
public final class CountReducer extends Reducer<Text, IntWritable, Text, IntWritable> {

    protected void reduce(Text key, Iterable<IntWritable> values,

From source file com.justgiving.raven.kissmetrics.jsonenricher.KissmetricsJsonToEnrichedJsonReducer.java

/****
 * This reducer class takes all the json values from the the reducer and enriches it with the 
 * email and IDs where missing
 * 
 * If the ID and email address co-occur (the identify event) then the email is populated backward for all 
 * events.

From source file com.justgiving.raven.kissmetrics.schema.KissmetricsJsonToSchemaReducer.java

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

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

        int total = 0;
        int maxLen = 0;

From source file com.jyz.study.hadoop.mapreduce.datajoin.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.kasabi.labs.freebase.mr.Freebase2RDFReducer.java

public class Freebase2RDFReducer extends Reducer<Text, Text, Text, NullWritable> {

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

    private final NullWritable nullWritable = NullWritable.get();
    private Text k = new Text();

From source file com.knewton.mapreduce.example.StudentEventReducer.java

public class StudentEventReducer extends Reducer<LongWritable, StudentEventWritable, LongWritable, Text> {

    public static final String STUDENT_INTERACTIONS_COUNT = "STUDENT_INTERACTIONS";
    protected static char DELIMITER;

    /**

From source file com.linkedin.cubert.plan.physical.CubertCombiner.java

/**
 * Combines data at the mapper during the shuffle stage.
 * 
 * This object is instantiated if the job configuration has "shuffle" property, and
 * further, if the shuffle property as "aggregations" property.
 *