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 com.jhkt.playgroundArena.hadoop.tasks.common.partitioner.GenericPartitioner.java

/**
 * @author Ji Hoon Kim
 */
public final class GenericPartitioner extends Partitioner<GenericPartitionerClass, Writable> {

    @Override

From source file com.juniarto.secondsorter.NaturalKeyPartitioner.java

/**
 *
 * @author hduser
 */
public class NaturalKeyPartitioner extends Partitioner<TextDsi, IntWritable> {
    public int getPartition(org.apache.hadoop.io.TextDsi key, IntWritable val, int numPartitions) {

From source file com.kylinolap.job.hadoop.invertedindex.InvertedIndexPartitioner.java

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

From source file com.linkedin.cubert.plan.physical.ByIndexPartitioner.java

/**
 * Partitioner for BLOCKGEN BY INDEX. This partitioner expects a BLOCK_ID within the key
 * when shuffling. The partitioner extracts the reducerId of the BLOCK_ID (which are the
 * upper 32 bits) and use it to route it to the reducer.
 * <p>
 * This partitioner ensures that the skew of the partition keys in blockgen by index will

From source file com.linkedin.cubert.plan.physical.CubertPartitioner.java

/**
 * Partitions the data during the shuffle stage.
 * 
 * @author Maneesh Varshney
 * 
 */

From source file com.rockstor.compact.garbagecollect.GarbageChunkPartition.java

public class GarbageChunkPartition extends Partitioner<ImmutableBytesWritable, ImmutableBytesWritable> {

    @Override
    public int getPartition(ImmutableBytesWritable key, ImmutableBytesWritable value, int numPartitions) {
        byte[] keyBytes = key.get();
        long high = Bytes.toLong(keyBytes, 0, Bytes.SIZEOF_LONG);

From source file com.scaleoutsoftware.soss.hserver.NamedMapPartitioner.java

/**
 * This partitioner sends the key to the Hadoop partition which is stored on the same host
 * that that the key would be stored at by the named map. This helps to avoid
 * excessive data movement when using {@link GridOutputFormat}.
 */
public class NamedMapPartitioner<K, V> extends Partitioner<K, V> {

From source file com.sirius.hadoop.job.onlinetime.StatusKeyPartitioner.java

/**
 * Created by pippo on 14-9-19.
 */
public class StatusKeyPartitioner extends Partitioner<StatusKey, NullWritable> {

    private static final Log LOG = LogFactory.getLog(StatusKeyPartitioner.class);

From source file com.spotify.hdfs2cass.cassandra.utils.CassandraPartitioner.java

/**
 * Uses the cassandra topology to send a key to a particular set of reducers
 */
public class CassandraPartitioner extends Partitioner<AvroKey<ByteBuffer>, AvroValue<Mutation>>
        implements Configurable, Serializable {

From source file com.sreejith.loganalyzer.mapreduce.LogPartitioner.java

public class LogPartitioner extends Partitioner<IntWritable, IntWritable> {

    private static Logger logger = LoggerFactory.getLogger(LogPartitioner.class);

    @Override
    public int getPartition(IntWritable key, IntWritable value, int numReduceTasks) {