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

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

Introduction

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

Usage

From source file com.talis.labs.pagerank.mapreduce.DanglingPagesMapper.java

public class DanglingPagesMapper extends Mapper<LongWritable, Text, Text, DoubleWritable> {

    private Text KEY_NAME = new Text("dangling");

    @Override
    public void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {

From source file com.talis.labs.pagerank.mapreduce.InitializePageRanksMapper.java

public class InitializePageRanksMapper extends Mapper<LongWritable, Text, Text, Text> {

    private double pagerank;

    @Override
    protected void setup(Context context) throws IOException, InterruptedException {

From source file com.talis.labs.pagerank.mapreduce.SortPageRanksMapper.java

public class SortPageRanksMapper extends Mapper<LongWritable, Text, DoubleWritable, Text> {

    @Override
    public void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {
        StringTokenizer st = new StringTokenizer(value.toString());
        String page = st.nextToken();

From source file com.talis.labs.pagerank.mapreduce.UpdatePageRanksMapper.java

public class UpdatePageRanksMapper extends Mapper<LongWritable, Text, Text, Text> {

    @Override
    public void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {
        StringTokenizer st = new StringTokenizer(value.toString());
        String page = st.nextToken();

From source file com.talis.mapreduce.dicenc.FirstMapper.java

public class FirstMapper extends Mapper<LongWritable, Text, Text, IntWritable> {

    private static int percentage;

    private Random random = new Random(System.currentTimeMillis());
    private Text k = new Text();

From source file com.talis.mapreduce.dicenc.SecondMapper.java

public class SecondMapper extends Mapper<LongWritable, Text, Text, Text> {

    private String filename = null;

    @Override
    protected void setup(org.apache.hadoop.mapreduce.Mapper<LongWritable, Text, Text, Text>.Context context)

From source file com.talis.mapreduce.dicenc.ThirdMapper.java

public class ThirdMapper extends Mapper<LongWritable, Text, Text, Text> {

    @Override
    public void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {
        StringTokenizer st = new StringTokenizer(value.toString());

From source file com.talis.mapreduce.lib.input.TestMapper.java

public class TestMapper extends Mapper<LongWritable, Text, LongWritable, Text> {

    @Override
    public void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {
        context.write(key, value);
    }

From source file com.talis.mapreduce.wordcount.newapi.WordCountMapper.java

public class WordCountMapper extends Mapper<LongWritable, Text, Text, IntWritable> {

    private final static IntWritable one = new IntWritable(1);
    private Text word = new Text();

    @Override

From source file com.tdunning.plume.local.lazy.MSCRMapper.java

/**
 * Mapper that is used to execute MSCR in MapReds
 */
public class MSCRMapper extends Mapper<WritableComparable, WritableComparable, PlumeObject, PlumeObject> {

    MSCR mscr; // Current MSCR being executed