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 org.freeeed.mr.KeyComparator.java

/**
 *
 * @author mark
 */
public class KeyComparator extends WritableComparator {
    private static final Logger logger = LoggerFactory.getLogger(KeyComparator.class);

From source file org.htuple.TupleComparator.java

/**
 * A {@link java.util.Comparator} for {@link org.htuple.Tuple} instances, which can compare a subset of the elements in
 * the tuple, which is useful for sorting and grouping when secondary-sort behavior is desired.
 * <p/>
 * TODO - Optimize space+time by overriding the {@link #compare(byte[], int, int, byte[], int, int)}.
 */

From source file org.huahinframework.core.lib.partition.SimpleGroupingComparator.java

/**
 * <code>SimpleGroupingComparator</code> grouping key is that you specify in the <code>Record#addGrouping</code>.
 */
public class SimpleGroupingComparator extends WritableComparator {
    /**
     * default constractor

From source file org.huahinframework.core.lib.partition.SimpleSortComparator.java

/**
 * <code>SimpleSortComparator</code> is sorted by keys that are specified in the <code>Record#addSort</code>.
 */
public class SimpleSortComparator extends WritableComparator {
    /**
     * default constractor

From source file org.rdfhdt.mrbuilder.io.TripleComparator.java

/**
 * @author chemi
 *
 */
@SuppressWarnings("rawtypes")
public abstract class TripleComparator<TW extends TripleWritable> extends WritableComparator {

From source file pad.NodeGroupingComparator.java

/**
 * Thanks to this class, the reducer bundles together records with the same
 * NodeID while it is streaming the mapper output records from local disk.
 */
public class NodeGroupingComparator extends WritableComparator {
    /** Initializes a new instance of the NodeGroupingComparator class. */

From source file SpecializedByState.GroupingStateComparator.java

/**
 *
 * @author vishakha
 */
public class GroupingStateComparator extends WritableComparator {

From source file top10flight.SortKeyComparator.java

/**
 *
 * @author priyank
 */
public class SortKeyComparator extends WritableComparator {

From source file top10_categories.SortKeyComparator.java

/**
 *
 * @author Rajat
 */
class SortKeyComparator extends WritableComparator {

From source file top25products.SortKeyComparator.java

public class SortKeyComparator extends WritableComparator {

    protected SortKeyComparator() {
        super(LongWritable.class, true);
    }