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 edu.uci.ics.fuzzyjoin.hadoop.IntTripleComparatorFirst.java

public class IntTripleComparatorFirst implements RawComparator<IntTripleWritable> {

    public int compare(byte[] b1, int s1, int l1, byte[] b2, int s2, int l2) {
        return WritableComparator.compareBytes(b1, s1, 4, b2, s2, 4);
    }

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

public class IntTripleComparatorFirstSecond implements RawComparator<IntTripleWritable> {

    public int compare(byte[] b1, int s1, int l1, byte[] b2, int s2, int l2) {
        int c = WritableComparator.compareBytes(b1, s1, 4, b2, s2, 4);
        if (c != 0) {
            return c;

From source file it.crs4.seal.common.GroupByLocationComparator.java

/**
 * Group based only on the sequence location.
 */
public class GroupByLocationComparator implements RawComparator<SequenceId> {
    @Override
    public int compare(byte[] b1, int s1, int l1, byte[] b2, int s2, int l2) {

From source file it.crs4.seal.demux.TwoOneThreeSortComparator.java

/**
 * Sort sequence ids so that read 2 comes first (the index read),
 * then read 1 and read 3.
 */
public class TwoOneThreeSortComparator implements RawComparator<SequenceId> {
    private static final Log LOG = LogFactory.getLog(TwoOneThreeSortComparator.class);

From source file org.apache.avro.hadoop.io.AvroKeyComparator.java

/**
 * The {@link org.apache.hadoop.io.RawComparator} used by jobs configured with
 * {@link org.apache.avro.mapreduce.AvroJob}.
 *
 * <p>Compares AvroKeys output from the map phase for sorting.</p>
 */

From source file org.apache.avro.mapred.AvroKeyComparator.java

/** The {@link RawComparator} used by jobs configured with {@link AvroJob}. */
public class AvroKeyComparator<T> extends Configured implements RawComparator<AvroWrapper<T>> {

    private Schema schema;

    @Override

From source file org.apache.avro.mapred.tether.TetherKeyComparator.java

/** The {@link RawComparator} used by jobs configured with {@link TetherJob}. */
class TetherKeyComparator extends Configured implements RawComparator<TetherData> {

    private Schema schema;

    @Override

From source file org.apache.crunch.lib.sort.ReverseAvroComparator.java

public class ReverseAvroComparator<T> extends Configured implements RawComparator<AvroKey<T>> {

    private Schema schema;

    @Override
    public void setConf(Configuration conf) {

From source file org.apache.crunch.lib.sort.ReverseWritableComparator.java

public class ReverseWritableComparator<T> extends Configured implements RawComparator<T> {

    private RawComparator<T> comparator;

    @SuppressWarnings("unchecked")
    @Override

From source file org.apache.gobblin.compaction.mapreduce.orc.OrcKeyComparator.java

/**
 * Compare {@link OrcKey} in shuffle of MapReduce.
 * Delegate byte decoding to underlying {@link OrcStruct#readFields(DataInput)} method to simplify comparison.
 */
public class OrcKeyComparator extends Configured implements RawComparator<OrcKey> {
    private TypeDescription schema;