Example usage for org.apache.hadoop.mapreduce.lib.partition HashPartitioner subclass-usage

List of usage examples for org.apache.hadoop.mapreduce.lib.partition HashPartitioner subclass-usage

Introduction

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

Usage

From source file org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.OutermostHierarchicalPartitioner.java

public class OutermostHierarchicalPartitioner extends HashPartitioner<PigNullableWritable, Writable>
        implements Configurable {

    Byte kt;
    Tuple t;
    PigNullableWritable realKey;

From source file org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.RollupH2IRGPartitioner.java

/**
 * This class provides a partitioner when the RollupOptimizer is activated.
 * The map output key space is partitioned by the dimension which the pivot
 * position is assigned to.
 * For example, we have a tuple (year, month, day, payload) and the pivot is 
 * 2, so the map output space will be partitioned by month, which means that

From source file org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.RollupHIIPartitioner.java

/**
 * This class provides a partitioner when the RollupOptimizer is activated. The
 * map output key space is partitioned by the dimension which the pivot position
 * is assigned to. For example, we have a tuple (year, month, day, payload) and
 * the pivot is 2, so the map output space will be partitioned by month, which
 * means that there will be one reducer per month.

From source file org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SecondaryKeyPartitioner.java

public class SecondaryKeyPartitioner extends HashPartitioner<PigNullableWritable, Writable>
        implements Configurable {
    Byte kt;

    @Override
    public int getPartition(PigNullableWritable key, Writable value, int numPartitions) {