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

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

Introduction

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

Usage

From source file com.marklogic.mapreduce.ForestReader.java

/**
 * RecordReader that reads from forest data dirs.
 * 
 * @author jchen
 *
 * @param <VALUEIN> Currently only support ForestDocument, but other types like

From source file com.marklogic.mapreduce.MarkLogicRecordReader.java

/**
 * A RecordReader that fetches data from MarkLogic server and generates 
 * <K, V> key value pairs.
 * 
 * @author jchen
 * 

From source file com.mcd.gdw.daas.mapreduce.ZipFileRecordReader.java

/**
* This RecordReader implementation extracts individual files from a ZIP
* file and hands them over to the Mapper. The "key" is the decompressed
* file name, the "value" is the file contents.
*/
public class ZipFileRecordReader extends RecordReader<Text, BytesWritable> {

From source file com.metamx.milano.hadoop.MilanoProtoFileRecordReader.java

/**
 *
 */
public class MilanoProtoFileRecordReader extends RecordReader<String, Message> {
    private static final Logger log = Logger.getLogger(MilanoProtoFileRecordReader.class);

From source file com.mongodb.hadoop.input.BSONFileRecordReader.java

/**
 * Copyright (c) 2008 - 2013 10gen, Inc. <http://10gen.com>
 * <p/>
 * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with the License. You may
 * obtain a copy of the License at
 * <p/>

From source file com.mongodb.hadoop.input.MongoRecordReader.java

public class MongoRecordReader extends RecordReader<Object, BSONObject> {

    public MongoRecordReader(final MongoInputSplit split) {
        this.split = split;
        cursor = split.getCursor();
    }

From source file com.moz.fiji.mapreduce.input.impl.WholeFileRecordReader.java

/**
 * <p>A RecordReader that reads an entire file as a single key-value.
 * The key is the qualified path to this file, and the value is the Text contents of the file.
 * This is intended for reading small files.
 * (Note that the entire file must be able to fit in ram)</p>
 */

From source file com.mycompany.keywordsearch.LineRecordReaderV2.java

/**
 * Treats keys as offset in file and value as line. 
 */
@InterfaceAudience.LimitedPrivate({ "MapReduce", "Pig" })
@InterfaceStability.Evolving
public class LineRecordReaderV2 extends RecordReader<Text, Text> {

From source file com.netflix.aegisthus.input.readers.AegisthusRecordReader.java

public abstract class AegisthusRecordReader extends RecordReader<Text, Text> {
    protected long start;
    protected long end;
    protected long pos;
    protected final Text key = new Text();
    protected final Text value = new Text();

From source file com.nikoo28.excel.mapreduce.ExcelRecordReader.java

/**
 * Reads excel spread sheet , where keys are offset in file and value is the row
 * containing all column as a string.
 */
public class ExcelRecordReader extends RecordReader<LongWritable, Text> {