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.apache.crunch.lib.sort.TupleWritableComparator.java

public class TupleWritableComparator extends WritableComparator implements Configurable {

    private static final String CRUNCH_ORDERING_PROPERTY = "crunch.ordering";

    private Configuration conf;
    private ColumnOrder[] columnOrders;

From source file org.apache.jena.hadoop.rdf.types.comparators.SimpleBinaryComparator.java

/**
 * A general purpose comparator that may be used with any types which can be
 * compared directly on their binary encodings
 */
public class SimpleBinaryComparator extends WritableComparator {

From source file org.apache.mahout.classifier.bayes.mapreduce.common.FeatureLabelComparator.java

public class FeatureLabelComparator extends WritableComparator {

    public FeatureLabelComparator() {
        super(StringTuple.class, true);
    }

From source file org.apache.mahout.utils.nlp.collocations.llr.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 {

    GramKeyGroupComparator() {

From source file org.apache.mahout.vectorizer.collocations.llr.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 org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBigDecimalRawComparator.java

public class PigBigDecimalRawComparator extends WritableComparator implements Configurable {
    private static final Log mLog = LogFactory.getLog(PigBigDecimalRawComparator.class);
    private boolean[] mAsc;
    private final BigDecimalWritable.Comparator mWrappedComp;

    public PigBigDecimalRawComparator() {

From source file org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBigIntegerRawComparator.java

public class PigBigIntegerRawComparator extends WritableComparator implements Configurable {
    private static final Log mLog = LogFactory.getLog(PigBigIntegerRawComparator.class);
    private boolean[] mAsc;
    private final BigIntegerWritable.Comparator mWrappedComp;

    public PigBigIntegerRawComparator() {

From source file org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBooleanRawComparator.java

public class PigBooleanRawComparator extends WritableComparator implements Configurable {

    private final Log mLog = LogFactory.getLog(getClass());
    private boolean[] mAsc;
    private BooleanWritable.Comparator mWrappedComp;

From source file org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBytesRawComparator.java

public class PigBytesRawComparator extends WritableComparator implements Configurable {

    private final Log mLog = LogFactory.getLog(getClass());
    private boolean[] mAsc;
    private WritableComparator mWrappedComp;

From source file org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigDateTimeRawComparator.java

public class PigDateTimeRawComparator extends WritableComparator implements Configurable {

    private final Log mLog = LogFactory.getLog(getClass());
    private boolean[] mAsc;
    private DateTimeWritable.Comparator mWrappedComp;