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.xiaomi.linden.hadoop.indexing.reduce.LindenCombiner.java

/**
 * This combiner combines multiple intermediate forms into one intermediate
 * form. More specifically, the input intermediate forms are a single-document
 * ram index and/or a single delete term. An output intermediate form contains
 * a multi-document ram index and/or multiple delete terms.
 */

From source file com.xiaomi.linden.hadoop.indexing.reduce.LindenReducer.java

public class LindenReducer extends Reducer<Shard, IntermediateForm, Shard, Text> {

    private static final Logger logger = Logger.getLogger(LindenReducer.class);
    static final Text DONE = new Text("done");

    private Configuration conf;

From source file com.yahoo.glimmer.indexing.generator.TermReduce.java

public class TermReduce extends Reducer<TermKey, TermValue, IntWritable, IndexRecordWriterValue> {
    private static final Log LOG = LogFactory.getLog(TermReduce.class);
    public static final String MAX_INVERTEDLIST_SIZE_PARAMETER = "maxInvertiedListSize";
    public static final String MAX_POSITIONLIST_SIZE_PARAMETER = "maxPositionListSize";

    private IntWritable writerKey;

From source file com.yahoo.glimmer.indexing.preprocessor.ResourcesReducer.java

/**
 * Reducer
 * 
 * For the given Subject resource key concatenates all <predicate> <object>
 * <context> . for that key It also appends PREDICATE, OBJECT and/or CONTEXT
 * keywords if that keyword occurs once or more as a value.

From source file com.yassergonzalez.pagerank.InLinksReducer.java

public class InLinksReducer extends Reducer<IntWritable, IntWritable, IntWritable, IntWritable> {

    @Override
    protected void reduce(IntWritable inKey, Iterable<IntWritable> inValues, Context context)
            throws IOException, InterruptedException {

From source file com.yassergonzalez.pagerank.InLinksTopNReducer.java

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

    // TODO: Create base classes TopN{Mapper,Reducer} to avoid duplicate
    // code in {PageRank,InLinks}TopN{Mapper,Reducer}.

    private PriorityQueue<Map.Entry<Integer, Integer>> topN;

From source file com.yassergonzalez.pagerank.PageRankIterationCombiner.java

public class PageRankIterationCombiner
        extends Reducer<ShortWritable, FloatArrayWritable, ShortWritable, FloatArrayWritable> {

    @Override
    protected void reduce(ShortWritable inKey, Iterable<FloatArrayWritable> inValues, Context context)
            throws IOException, InterruptedException {

From source file com.yassergonzalez.pagerank.PageRankIterationReducer.java

public class PageRankIterationReducer
        extends Reducer<ShortWritable, FloatArrayWritable, ShortWritable, FloatArrayWritable> {

    @Override
    protected void reduce(ShortWritable inKey, Iterable<FloatArrayWritable> inValues, Context context)
            throws IOException, InterruptedException {

From source file com.yassergonzalez.pagerank.PageRankMatrixReducer.java

public class PageRankMatrixReducer
        extends Reducer<ShortArrayWritable, ShortArrayWritable, ShortArrayWritable, MatrixBlockWritable> {

    @Override
    public void reduce(ShortArrayWritable inKey, Iterable<ShortArrayWritable> inValues, Context context)
            throws IOException, InterruptedException {

From source file com.yassergonzalez.pagerank.PageRankTopNReducer.java

public class PageRankTopNReducer extends Reducer<FloatWritable, IntWritable, FloatWritable, Text> {

    // TODO: Create base classes TopN{Mapper,Reducer} to avoid duplicate
    // code in {PageRank,InLinks}TopN{Mapper,Reducer}.

    private PriorityQueue<Map.Entry<Float, Integer>> topN;