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.mozilla.hadoop.mapreduce.lib.UniqueIdentityReducer.java

/**
 * Typical IdentityReduce will output once for every value.  This will output 
 * only once for a given key assuming it has at least 1 value.
 *
 * @param <K>
 * @param <V>

From source file com.mycompany.hadooptrain.WordCountReducer.java

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

    public void reduce(Text text, Iterable<IntWritable> values, Context context)
            throws IOException, InterruptedException {
        int sum = 0;
        for (IntWritable value : values) {

From source file com.mycompany.maprpractice.Reducer.WordCountReducer.java

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

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

From source file com.nearinfinity.blur.mapreduce.BlurReducer.java

public class BlurReducer extends Reducer<BytesWritable, BlurMutate, BytesWritable, BlurMutate> {

    static class LuceneFileComparator implements Comparator<String> {

        private Directory _directory;

From source file com.netflix.aegisthus.mapred.reduce.CassReducer.java

public class CassReducer extends Reducer<Text, Text, Text, Text> {
    public static final AegisthusSerializer as = new AegisthusSerializer();
    Set<Text> valuesSet = new HashSet<Text>();

    @SuppressWarnings("unchecked")
    protected Long getTimestamp(Map<String, Object> map, String columnName) {

From source file com.netflix.aegisthus.mapreduce.CassSSTableReducer.java

public class CassSSTableReducer extends Reducer<AegisthusKey, AtomWritable, BytesWritable, RowWritable> {
    private static final Logger LOG = LoggerFactory.getLogger(CassSSTableReducer.class);
    private long rowsToAddToCounter = 0;
    private AbstractType<?> columnComparator;
    private AbstractType<?> rowKeyComparator;
    private long maxRowSize = Long.MAX_VALUE;

From source file com.pagerankcalculator.calculation.PageRankCalculationReducer.java

/**
 *
 * @author mfikria
 */
public class PageRankCalculationReducer extends Reducer<Text, Text, Text, Text> {
    //    private MultipleOutputs<Text, Text> multipleOutputs;

From source file com.pagerankcalculator.graphparsing.GraphParsingReducer.java

/**
 *
 * @author mfikria
 */
public class GraphParsingReducer extends Reducer<Text, Text, Text, Text> {
    Integer initialPageRank = 1;

From source file com.pagerankcalculator.ordering.PageRankSortingReducer.java

/**
 *
 * @author mfikria
 */
public class PageRankSortingReducer extends Reducer<DoubleWritable, Text, Text, Text> {
    int counter = 0;

From source file com.panguso.lc.analysis.format.mapreduce.FormatAnalysisReducer.java

/**
 * 
 * 
 * @author piaohailin
 * @date 2013-4-9
 */