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 org.janusgraph.hadoop.formats.util.HadoopRecordReader.java

/**
 * @author Marko A. Rodriguez (https://markorodriguez.com)
 */
public class HadoopRecordReader extends RecordReader<NullWritable, VertexWritable> {

    private final RecordReader<StaticBuffer, Iterable<Entry>> reader;

From source file org.kiji.avro.mapreduce.AvroRecordReaderBase.java

/**
 * Abstract base class for <code>RecordReader</code>s that read Avro container files.
 *
 * @param <K> The type of key the record reader should generate.
 * @param <V> The type of value the record reader should generate.
 * @param <T> The type of the entries within the Avro container file being read.

From source file org.kiji.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 org.kiji.mapreduce.input.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 org.kitesdk.data.spi.AbstractKeyRecordReaderWrapper.java

/**
 * A wrapper class for converting a {@code RecordReader<K, V>} to a
 * {@code RecordReader<E, Void>}.
 *
 * @param <E> The {@code Dataset} entity type.
 * @param <K> The type of the key to convert.

From source file org.kitesdk.data.spi.filesystem.AbstractCombineFileRecordReader.java

/**
 * Base class for wrapping file-based record readers with CombineFileInputFormat functionality. This allows multiple
 * files to be combined into a single InputSplit, with the main pre-requisite being that the InputFormat being wrapped
 * must make use of FileInputSplits.
 * <p/>
 * Sub-classes need only implement the method to instantiate an instance of their owning InputFormat class.

From source file org.kitesdk.data.spi.FilteredRecordReader.java

public class FilteredRecordReader<E> extends RecordReader<E, Void> {
    private RecordReader<E, Void> unfiltered;
    private Predicate<E> predicate;
    private E current;

    public FilteredRecordReader(RecordReader<E, Void> unfiltered, Constraints constraints,

From source file org.length.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 org.lilyproject.mapreduce.LilyScanIdRecordReader.java

/**
 * A Hadoop RecordReader based on Lily RecordScanners. Used by {@link LilyScanInputFormat}.
 */
public class LilyScanIdRecordReader extends RecordReader<RecordIdWritable, IdRecordWritable> {
    private LilyClient lilyClient;
    private IdRecordScanner scanner;

From source file org.lilyproject.mapreduce.LilyScanRecordReader.java

/**
 * A Hadoop RecordReader based on Lily RecordScanners. Used by {@link LilyScanInputFormat}.
 */
public class LilyScanRecordReader extends RecordReader<RecordIdWritable, RecordWritable> {
    private LilyClient lilyClient;
    private RecordScanner scanner;