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.mrgeo.hdfs.partitioners.TileIdPartitioner.java

/**
 * The TileIdPartitioner works by reading split points from a file and producing partition numbers
 * based on these split points. This split file is usually resident in the distributed cache, from
 * where it can be read by map tasks for properly partitioning tiles amongst reducers.
 * <p/>
 * There is also a use case for reading it from the file system - hdfs or local for non-map/reduce

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

/**
 * @author Dave Syer
 * 
 */
public class AutowiringPartitioner<K, V> extends Partitioner<K, V> implements Configurable {

From source file pad.NodePartitioner.java

/**   Thanks to this class, the keys (\see NodesPair) are partitioned only considering the first component, i.e NodeID. */
public class NodePartitioner extends Partitioner<NodesPairWritable, IntWritable> {
    /**
    * Choose the Reducer identifier to which send the record using only the NodeID information.
    * @param pair         key of the record, \see NodesPair.
    * @param _            value of the record.

From source file Patterns.A3_Partitioning.Partition_Users_By_Country_Partitioner.java

/**
 *
 * @author Chintan
 */
public class Partition_Users_By_Country_Partitioner extends Partitioner<Text, Text> {

From source file proj.analysis.uscensus.USCensusFirstPartitioner.java

/**
 *
 * @author namanrs
 */
public class USCensusFirstPartitioner extends Partitioner<Text, MapperOPValue> {

From source file Qn3.TotalOrderPartitioner.java

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

From source file sampler.TotalOrderPartitioner.java

/**
 * Partitioner effecting a total order by reading split points from
 * an externally generated source.
 * 
 * This is an identical copy of o.a.h.mapreduce.lib.partition.TotalOrderPartitioner
 * from Hadoop trunk at r910774.

From source file simsql.runtime.RecordPartitioner.java

/**
 * This little class partitions records to the various reducers
 */
public class RecordPartitioner extends Partitioner<RecordKey, RecordWrapper> {

    public int getPartition(RecordKey key, RecordWrapper value, int numReducers) {

From source file sourcefiles.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 uk.ac.cam.eng.extraction.hadoop.merge.MergePartitioner.java

/**
 * 
 * @author Aurelien Waite
 * @date 28 May 2014
 */
class MergePartitioner extends Partitioner<RuleWritable, AlignmentAndFeatureMap> {