Example usage for org.apache.hadoop.io WritableComparator subclass-usage

List of usage examples for org.apache.hadoop.io WritableComparator subclass-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.io WritableComparator subclass-usage.

Usage

From source file com.zjy.mongo.io.BSONWritableComparator.java

public class BSONWritableComparator extends WritableComparator {

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

    public BSONWritableComparator() {
        super(BSONWritable.class, true);

From source file csc555.ebratt.depaul.edu.GroupByGroupingComparator.java

/**
 * GroupByGroupingComparator is a custom comparator used in a hadoop job to
 * ensure that GroupByCountPair objects are grouped using their groupBy fields.
 * 
 * @author Eric Bratt
 * @version 11/11/2015

From source file de.tudarmstadt.ukp.dkpro.bigdata.collocations.GramKeyGroupComparator.java

/** Group GramKeys based on their Gram, ignoring the secondary sort key, so that all keys with the same Gram are sent
 *  to the same call of the reduce method, sorted in natural order (for GramKeys).
 */
class GramKeyGroupComparator extends WritableComparator implements Serializable {

    GramKeyGroupComparator() {

From source file demo.CompositeKeyComparator.java

/**
 * Compares the composite key, {@link StockKey}.
 * We sort by symbol ascendingly and timestamp
 * descendingly.
 * @author Jee Vang
 *

From source file demo.NaturalKeyGroupingComparator.java

/**
 * Groups values based on symbol of {@link StockKey} (the natural key).
 * @author Jee Vang
 *
 */
public class NaturalKeyGroupingComparator extends WritableComparator {

From source file dev.TripleWritableComparator.java

public class TripleWritableComparator extends WritableComparator {

    protected TripleWritableComparator() {
        super(TripleWritable.class);
    }

From source file edu.rosehulman.GramKeyGroupComparator.java

/** Group GramKeys based on their Gram, ignoring the secondary sort key, so that all keys with the same Gram are sent
 *  to the same call of the reduce method, sorted in natural order (for GramKeys).
 */
class GramKeyGroupComparator extends WritableComparator implements Serializable {

    GramKeyGroupComparator() {

From source file edu.uci.ics.pregelix.runtime.touchpoint.VLongWritableComparator.java

/** A Comparator optimized for VLongWritable. */
public class VLongWritableComparator extends WritableComparator {

    public VLongWritableComparator() {
        super(VLongWritable.class);
    }

From source file hamr.core.general.group.GeneralGroupComparator.java

public class GeneralGroupComparator extends WritableComparator {
    @SuppressWarnings("rawtypes")
    private WritableComparable key1;
    @SuppressWarnings("rawtypes")
    private WritableComparable key2;
    private final DataInputBuffer buffer;

From source file io.apigee.lembos.mapreduce.LembosGroupComparator.java

/**
 * Extension of {@link WritableComparator} that allows a Node.js MapReduce job author to export a <strong>group</strong>
 * function to implement the group comparator functionality for their job.
 */
public class LembosGroupComparator extends WritableComparator implements Configurable, Closeable {