Example usage for org.apache.hadoop.io RawComparator interface-usage

List of usage examples for org.apache.hadoop.io RawComparator interface-usage

Introduction

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

Usage

From source file com.datasalt.pangool.tuplemr.mapred.SortComparator.java

/**
 * Tuple-based MapRed job binary comparator. It decodes the binary serialization
 * performed by {@link TupleSerialization}.
 * <p/>
 * Used to group tuples according to
 * {@link TupleMRConfigBuilder#setOrderBy(com.datasalt.pangool.tuplemr.OrderBy)}

From source file com.ebay.erl.mobius.core.model.Tuple.java

/**
 * Represents a record(row) in a dataset.
 * <p>
 * 
 * <p>
 * This product is licensed under the Apache License,  Version 2.0, 

From source file com.ibm.bi.dml.runtime.matrix.data.MatrixIndexes.java

/**
 * This represent the indexes to the blocks of the matrix.
 * Please note that these indexes are 1-based, whereas the data in the block are zero-based (as they are double arrays).
 */
public class MatrixIndexes
        implements WritableComparable<MatrixIndexes>, RawComparator<MatrixIndexes>, Externalizable {

From source file com.ibm.jaql.lang.core.JsonComparator.java

public interface JsonComparator extends RawComparator<JsonHolder>, RawLongHasher<JsonHolder> {
}

From source file com.mongodb.hadoop.util.BSONComparator.java

/**
 * @author Mike O'Brien, Sweet Song
 */
public class BSONComparator implements RawComparator<BSONObject> {

    private static final BSONComparator INSTANCE;

From source file com.splicemachine.access.client.SpliceKVComparator.java

/**
 *
 * KeyValueComparator used by the Client Side Merge of Store File Scanners and MemstoreKeyValueScanner.  This
 * class handles the special key values returned from the MemstoreFlushAwareScanner.
 *
 * Created by jleach on 4/12/16.

From source file com.spotify.hdfs2cass.cassandra.utils.CassandraKeyComparator.java

/**
 * A comparator for sorting keys in sstable order. This is used in the shuffle
 * to ensure that the reducer sees inputs in the correct order and can append
 * them to sstables without sorting again.
 */
public class CassandraKeyComparator implements RawComparator<AvroKey<ByteBuffer>>, Configurable {

From source file com.zjy.mongo.util.BSONComparator.java

/**
 * @author Mike O'Brien, Sweet Song
 */
public class BSONComparator implements RawComparator<BSONObject> {

    private static final BSONComparator INSTANCE;

From source file edu.cmu.cs.in.hadoop.HoopKeyComparer.java

/**
* Future class to work with the partitioner
*/
public class HoopKeyComparer extends HoopRoot implements RawComparator<Text> {
    /**
     *

From source file edu.uci.ics.fuzzyjoin.hadoop.IntPairComparatorFirst.java

public class IntPairComparatorFirst implements RawComparator<IntPairWritable> {

    public static int compareInt(int i1, int i2) {
        return i1 < i2 ? -1 : i1 == i2 ? 0 : 1;
    }