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.github.ygf.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.github.ygf.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.github.ygf.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.github.ygf.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.github.ygf.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;

From source file com.gsvic.csmr.CosineSimilarityReducer.java

public class CosineSimilarityReducer extends Reducer<Text, VectorArrayWritable, Text, DoubleWritable> {

    @Override
    public void reduce(Text key, Iterable<VectorArrayWritable> value, Context context)
            throws IOException, InterruptedException {

From source file com.gsvic.csmr.CSMRReducer.java

public class CSMRReducer extends Reducer<IntWritable, DocumentWritable, Text, VectorArrayWritable> {

    private ArrayList<DocumentWritable> al;
    private VectorWritable[] val;
    private VectorArrayWritable vaw;

From source file com.hhscyber.nl.tweets.dataout.DataOutReducer.java

/**
 *
 * @author eve
 */
public class DataOutReducer extends Reducer<Text, Text, Text, Text> {

From source file com.hhscyber.nl.tweets.processtweets.ProcessTweetsReducer.java

/**
 *
 * @author eve
 */
public class ProcessTweetsReducer extends Reducer<Text, IntWritable, Text, IntWritable> {

From source file com.hhscyber.nl.tweets.svm.train.TrainReducer.java

/**
 *
 * @author eve
 */
public class TrainReducer extends Reducer<Text, Text, Text, Text> {