Example usage for org.apache.hadoop.mapreduce Partitioner subclass-usage

List of usage examples for org.apache.hadoop.mapreduce Partitioner subclass-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.mapreduce Partitioner subclass-usage.

Usage

From source file be.ugent.intec.halvade.uploader.mapreduce.BamIdPartitioner.java

/**
 *
 * @author dries
 */
public class BamIdPartitioner extends Partitioner<PairedIdWritable, FastqRecord> {

From source file boa.runtime.BoaPartitioner.java

/**
 * A {@link Partitioner} that takes several merged jobs and partitions
 * keys from each job to its own reducer.
 * 
 * @author rdyer
 */

From source file byte_import.MyNewTotalOrderPartitioner.java

public class MyNewTotalOrderPartitioner<VALUE> extends Partitioner<ImmutableBytesWritable, VALUE> {
    //private static Random g1= new Random();

    public static final int MAX_HBASE_ROWS = 45;
    public static final int MAX_HBASE_BUCKETS = 255;
    private static final byte[] SUBCLASS = Bytes.toBytes(new Long("8742859611446415633"));

From source file ca.uwaterloo.cs.bigdata2017w.assignment4.RangePartitioner.java

/**
 * Ranger partitioner. In the context of graph algorithms, ensures that consecutive node ids are
 * blocked together.
 *
 * @author Jimmy Lin
 * @author Michael Schatz

From source file clustering.mst.ChildPartitioner.java

/**
 * Partition the edges.
 * Partition by their end points so that the sub-graphs are
 * both connected and evenly distributed.
 *
 * @author edwardlol

From source file clustering.similarity.PrePartitioner.java

/**
 * Partition the index segments evenly across the cluster.
 *
 * @author edwardlol
 *         Created by edwardlol on 17-4-24.
 */

From source file co.cask.cdap.internal.app.runtime.batch.PartitionerWrapper.java

/**
 * Wraps user-defined implementation of {@link Partitioner} class which allows to perform extra configuration.
 */
public class PartitionerWrapper extends Partitioner implements Configurable {

    private static final String ATTR_CLASS = "c.partitioner.class";

From source file co.nubetech.hiho.dedup.HihoHashPartitioner.java

public class HihoHashPartitioner<K extends HihoTuple, V> extends Partitioner<K, V> {

    @Override
    public int getPartition(K key, V value, int numPartitions) {

        return (key.getHash().hashCode() & Integer.MAX_VALUE) % numPartitions;

From source file com.cloudera.spark.bulkload.TotalOrderPartitioner.java

  /**
   * Partitioner effecting a total order by reading split points from
   * an externally generated source.
   */
  @InterfaceAudience.Public
  @InterfaceStability.Stable

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

public class TupleHashPartitioner extends Partitioner<DatumWrapper<ITuple>, NullWritable> implements Configurable {

    private TupleMRConfig tupleMRConfig;
    private SerializationInfo serInfo;

    private Configuration conf;