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 nl.cwi.kba.thrift.bin.ThriftRecordReader.java

/**
 * RecordReader that emits filename, StreamItemWritable pairs. 
 * 
 * @author emeij
 *
 */

From source file nl.cwi.kba2013.thrift.bin.ThriftRecordReader.java

/**
 * RecordReader that emits filename, StreamItemWritable pairs. 
 * 
 * @author emeij
 *
 */

From source file nl.cwi.wikilink.thrift.bin.ThriftRecordReader.java

/**
 * RecordReader that emits filename, StreamItemWritable pairs. 
 * 
 * @author emeij
 *
 */

From source file nl.surfsara.warcutils.WarcRecordReader.java

/**
 * Hadoop RecordReader for regular (or compressed) warc wat and wet files. Used
 * by the WarcInputFormat. Values are provides as WarcRecords from the Java Web
 * Archive Toolkit.
 * 
 * @author mathijs.kattenberg@surfsara.nl

From source file nl.surfsara.warcutils.WarcSequenceFileRecordReader.java

/**
 * Hadoop RecordReader for warc wat and wet files which have been converted to
 * sequencefiles. The sequencefiles are expected to be in the format
 * <LongWritable, Text>. Where each text value parses as one WarcRecord from the
 * Java Web Archive Toolkit. Used by the WarcSequenceFileInputFormat.
 * 

From source file nyu.cs.webgraph.MRhelpers.LzoTabSeperatedLineRecordReader.java

/**
 * Reads line from an lzo compressed text file. Treats keys as offset in file
 * and value as line.
 */
public class LzoTabSeperatedLineRecordReader extends RecordReader<Text, Text> {

From source file oracle.kv.hadoop.KVRecordReaderBase.java

/**
 * @hidden
 */
abstract class KVRecordReaderBase<K, V> extends RecordReader<K, V> {

    protected KVStoreImpl kvstore;

From source file oracle.kv.hadoop.table.TableRecordReaderBase.java

/**
 * Abstract parent class for RecordReader implementations used to read
 * table rows from an InputSplit. This class provides common, useful,
 * and/or convenient mechanisms that are intended to be shared by
 * subclasses of this class.
 * <p>

From source file org.apache.accumulo.examples.wikisearch.reader.LongLineRecordReader.java

/**
 * A copy of {@link LineRecordReader} which does not discard lines longer than "mapred.linerecordreader.maxlength". Instead, it returns them, leaving it to the
 * mapper to decide what to do with it. It also does not treat '\r' (CR) characters as new lines -- it uses {@link LfLineReader} instead of {@link LineReader}
 * to read lines.
 */
public class LongLineRecordReader extends RecordReader<LongWritable, Text> {

From source file org.apache.accumulo.hadoopImpl.mapreduce.AccumuloRecordReader.java

/**
 * An implementation of {@link org.apache.hadoop.mapreduce.RecordReader} that converts Accumulo
 * {@link org.apache.accumulo.core.data.Key}/{@link org.apache.accumulo.core.data.Value} pairs to
 * the user's K/V types.
 */
public abstract class AccumuloRecordReader<K, V> extends RecordReader<K, V> {