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 org.apache.accumulo.hadoop.mapreduce.partition.KeyRangePartitioner.java

/**
 * Hadoop partitioner that uses ranges based on row keys, and optionally sub-bins based on hashing.
 *
 * @since 2.0.0
 */
public class KeyRangePartitioner extends Partitioner<Key, Writable> implements Configurable {

From source file org.apache.accumulo.hadoop.mapreduce.partition.RangePartitioner.java

/**
 * Hadoop partitioner that uses ranges, and optionally sub-bins based on hashing.
 *
 * @since 2.0.0
 */
public class RangePartitioner extends Partitioner<Text, Writable> implements Configurable {

From source file org.apache.accumulo.server.master.RoundRobinPartitioner.java

public class RoundRobinPartitioner extends Partitioner<LogFileKey, LogFileValue> {

    int counter = 0;

    @Override
    public int getPartition(LogFileKey key, LogFileValue value, int numPartitions) {

From source file org.apache.blur.manager.BlurPartitioner.java

/**
 * The {@link BlurPartitioner} class is a Hadoop {@link Partitioner}
 * implementation for Blur. Simple hashing class used to guide the rows to the
 * correct shards during MapReduce jobs as well as during normal runtime
 * operations.
 */

From source file org.apache.blur.mapreduce.lib.update.IndexKeyPartitioner.java

public class IndexKeyPartitioner extends Partitioner<IndexKey, IndexValue> {

    private HashPartitioner<Text, Writable> _partitioner = new HashPartitioner<Text, Writable>();

    @Override
    public int getPartition(IndexKey key, IndexValue value, int numPartitions) {

From source file org.apache.crunch.impl.mr.run.UniformHashPartitioner.java

/**
 * Hash partitioner which applies a supplemental hashing function to the hash code of values to ensure better
 * distribution of keys over partitions.
 */
public class UniformHashPartitioner<KEY, VALUE> extends Partitioner<KEY, VALUE> {

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

/**
 * A partition-aware {@code Partitioner} instance that can work with either Avro or Writable-formatted
 * keys.
 */
public class TotalOrderPartitioner<K, V> extends Partitioner<K, V> implements Configurable {

From source file org.apache.jena.tdbloader4.FourthCustomPartitioner.java

public class FourthCustomPartitioner extends Partitioner<LongQuadWritable, NullWritable> {

    @Override
    public int getPartition(LongQuadWritable key, NullWritable value, int numPartitions) {
        String indexName = key.getIndexName();

From source file org.apache.jena.tdbloader4.partitioners.TotalOrderPartitioner.java

/**
 * Partitioner effecting a total order by reading split points from an externally generated source.
 */
public class TotalOrderPartitioner<K extends WritableComparable<?>, V> extends Partitioner<K, V>
        implements Configurable {

From source file org.apache.kylin.engine.mr.invertedindex.InvertedIndexPartitioner.java

/**
 * @author yangli9
 */
public class InvertedIndexPartitioner extends Partitioner<LongWritable, ImmutableBytesWritable>
        implements Configurable {