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 license.NamesDetailsMapper.java

public class NamesDetailsMapper extends Mapper<Text, LicenseNameWritable, LicenseKey, JoinNameAndLicense> {

    private JoinNameAndLicense outValue = new JoinNameAndLicense();
    private LicenseKey keyOut = new LicenseKey();

    @Override

From source file map.MapClass.java

public class MapClass extends Mapper<Key, Value, Text, LongWritable> {

    public LongWritable countWritable;
    public final static LongWritable oneWritable = new LongWritable(1);
    public MapIO io;

From source file mappers.BlockMultiplicationGroupingMapper.java

public class BlockMultiplicationGroupingMapper<T> extends Mapper<Text, T, Text, T> {

    public Text outKey = new Text();

    public void map(Text key, T value, Context context) throws IOException, InterruptedException {
        Configuration conf = context.getConfiguration();

From source file mappers.EdgeListBlockEntryMapper.java

public class EdgeListBlockEntryMapper extends Mapper<LongWritable, Text, Text, BlockEntry> {

    Text outKey = new Text();
    BlockEntry outVal = new BlockEntry();

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

From source file mappers.MatrixBlockRowPartMapper.java

public class MatrixBlockRowPartMapper extends Mapper<Text, MatrixBlock, Text, RowPart> {

    Text outKey = new Text();

    //could pre-allocate the whole array
    // protected void setup (Context context) {

From source file mappers.SquareBlockTraceMultiplicationGroupingMapper.java

public class SquareBlockTraceMultiplicationGroupingMapper extends Mapper<Text, MatrixBlock, Text, MatrixBlock> {

    public Text outKey = new Text();

    public void map(Text key, MatrixBlock value, Context context) throws IOException, InterruptedException {
        Configuration conf = context.getConfiguration();

From source file mappers.UniformDoublyStochasticMapper.java

public class UniformDoublyStochasticMapper extends Mapper<LongWritable, Text, Text, MatrixBlock> {

    Text outKey;
    MatrixBlock outVal;

    protected void setup(Context context) {

From source file mapreduce.MapSideMapper.java

public class MapSideMapper extends Mapper<Text, TupleWritable, Text, Text> {
    Text _keyOut = new Text();
    Text _outValue = new Text();

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

From source file mapreducemaxstock.StockPriceMapper.java

/**
 *
 * @author luisf
 */
public class StockPriceMapper extends Mapper<LongWritable, Text, Text, FloatWritable> {

From source file mapreducesentiment.SentimentMapper.java

/**
 *
 * @author camila
 */
public class SentimentMapper
        extends Mapper<SentimentKeyWritableComparable, Text, SentimentKeyWritableComparable, LongWritable> {