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 org.springframework.hadoop.mapreduce.AutowiringGroupingComparator.java

/**
 * @author Dave Syer
 * 
 */
public class AutowiringGroupingComparator<K> implements RawComparator<K>, Configurable {

From source file org.springframework.hadoop.mapreduce.AutowiringSortComparator.java

/**
 * @author Dave Syer
 * 
 */
public class AutowiringSortComparator<K> implements RawComparator<K>, Configurable {

From source file org.terrier.structures.postings.PostingIdComparator.java

/** A comparator object for Posting objects, where they are sorted by id.
 * @since 3.0 */
public class PostingIdComparator implements Comparator<Posting>, RawComparator<Posting>, Serializable {
    private static final long serialVersionUID = 1L;

    /** Compare Posting objects by id */

From source file simsql.runtime.RecordKeyGroupingComparator.java

/**
 * This is used to group records so that all records in the same 
 * group are given to the same reducer.  In our case, this means
 * that all records with the same hashcode
 */
public class RecordKeyGroupingComparator implements RawComparator<RecordKey> {

From source file simsql.runtime.RecordKeySortComparator.java

/**
 * This is lke the RecordKeyGroupingComparator, except that it also
 * takes into account the typeCode of the underlying record to
 * make sure that records of one type come before records of 
 * another type in the reducer
 */

From source file tap.core.BinaryKeyComparator.java

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

    private Schema schema;

    public int compare(byte[] b1, int s1, int l1, byte[] b2, int s2, int l2) {

From source file voldemort.store.readonly.mr.serialization.JsonDeserializerComparator.java

/**
 * A hadoop RawComparator that deserializes first. Usefull for sorting JSON
 * objects
 * 
 * @author jay
 *