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 edu.iu.common.SingleFileRecordReader.java

public class SingleFileRecordReader extends RecordReader<String, String> {
    private Path path;
    private boolean done = false;

    @Override
    public void initialize(InputSplit split, TaskAttemptContext context) throws IOException, InterruptedException {

From source file edu.iu.fileformat.MultiFileRecordReader.java

public class MultiFileRecordReader extends RecordReader<String, String> {
    private List<Path> pathList;
    private int progress;

    @Override
    public void initialize(InputSplit split, TaskAttemptContext context) throws IOException, InterruptedException {

From source file edu.iu.fileformat.SingleFileRecordReader.java

public class SingleFileRecordReader extends RecordReader<String, String> {
    private Path path;
    private boolean done = false;

    @Override
    public void initialize(InputSplit split, TaskAttemptContext context) throws IOException, InterruptedException {

From source file edu.umn.cs.spatialHadoop.mapreduce.RTreeRecordReader3.java

/**
 * Reads a file that contains R-trees.
 * @author Ahmed Eldawy
 *
 */
public class RTreeRecordReader3<V extends Shape> extends RecordReader<Partition, Iterable<V>> {

From source file edu.umn.cs.spatialHadoop.mapreduce.SpatialRecordReader3.java

/**
 * @author Ahmed Eldawy
 *
 */
public class SpatialRecordReader3<V extends Shape> extends RecordReader<Partition, Iterable<V>> {

From source file edu.umn.cs.spatialHadoop.nasa.HDFRecordReader.java

/**
 * A record reader for HDF files with the new mapreduce interface
 * @author Ahmed Eldawy
 *
 */
public class HDFRecordReader<S extends NASAShape> extends RecordReader<NASADataset, Iterable<S>> {

From source file edu.umn.cs.spatialHadoop.nasa.HDFRecordReader3.java

/**
 * A record reader for HDF files with the new mapreduce interface
 * @author Ahmed Eldawy
 *
 */
public class HDFRecordReader3<S extends NASAShape> extends RecordReader<NASADataset, Iterable<S>> {

From source file edu.umn.cs.sthadoop.mapreduce.SpatioTemporalRecordReader.java

/**
 * @author louai alarabi
 *
 */
public class SpatioTemporalRecordReader<V extends STPoint> extends RecordReader<Partition, Iterable<V>> {

From source file edu.usc.pgroup.louvain.hadoop.GraphPartitionRecordReader.java

/**
 * Created by Charith Wickramaarachchi on 6/28/14.
 */
public class GraphPartitionRecordReader extends RecordReader<Text, BytesWritable> {

    /** Uncompressed file name */

From source file eu.edisonproject.utility.commons.WholeFileRecordReader.java

/**
 *
 * From https://gist.github.com/sritchie/808035
 */
public class WholeFileRecordReader extends RecordReader<NullWritable, Text> {