Uses of Interface
org.apache.hadoop.mapred.RecordReader

Packages that use RecordReader
org.apache.hadoop.contrib.index.example   
org.apache.hadoop.examples Hadoop example code. 
org.apache.hadoop.mapred A software framework for easily writing applications which process vast amounts of data (multi-terabyte data-sets) parallelly on large clusters (thousands of nodes) built of commodity hardware in a reliable, fault-tolerant manner. 
org.apache.hadoop.mapred.join Given a set of sorted datasets keyed with the same class and yielding equal partitions, it is possible to effect a join of those datasets prior to the map. 
org.apache.hadoop.mapred.lib Library of generally useful mappers, reducers, and partitioners. 
org.apache.hadoop.streaming Hadoop Streaming is a utility which allows users to create and run Map-Reduce jobs with any executables (e.g. 
 

Uses of RecordReader in org.apache.hadoop.contrib.index.example
 

Classes in org.apache.hadoop.contrib.index.example that implement RecordReader
 class LineDocRecordReader
          A simple RecordReader for LineDoc for plain text files where each line is a doc.
 

Methods in org.apache.hadoop.contrib.index.example that return RecordReader
 RecordReader<DocumentID,LineDocTextAndOp> LineDocInputFormat.getRecordReader(InputSplit split, JobConf job, Reporter reporter)
           
 

Uses of RecordReader in org.apache.hadoop.examples
 

Classes in org.apache.hadoop.examples that implement RecordReader
static class MultiFileWordCount.MultiFileLineRecordReader
          RecordReader is responsible from extracting records from the InputSplit.
 

Methods in org.apache.hadoop.examples that return RecordReader
 RecordReader<MultiFileWordCount.WordOffset,Text> MultiFileWordCount.MyInputFormat.getRecordReader(InputSplit split, JobConf job, Reporter reporter)
           
 

Uses of RecordReader in org.apache.hadoop.mapred
 

Classes in org.apache.hadoop.mapred that implement RecordReader
 class KeyValueLineRecordReader
          This class treats a line in the input as a key/value pair separated by a separator character.
 class LineRecordReader
          Treats keys as offset in file and value as line.
static class SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
          Read records from a SequenceFile as binary (raw) bytes.
 class SequenceFileAsTextRecordReader
          This class converts the input keys and values to their String forms by calling toString() method.
 class SequenceFileRecordReader<K,V>
          An RecordReader for SequenceFiles.
 

Methods in org.apache.hadoop.mapred that return RecordReader
 RecordReader<LongWritable,Text> TextInputFormat.getRecordReader(InputSplit genericSplit, JobConf job, Reporter reporter)
           
 RecordReader<K,V> SequenceFileInputFilter.getRecordReader(InputSplit split, JobConf job, Reporter reporter)
          Create a record reader for the given split
 RecordReader<Text,Text> SequenceFileAsTextInputFormat.getRecordReader(InputSplit split, JobConf job, Reporter reporter)
           
 RecordReader<K,V> SequenceFileInputFormat.getRecordReader(InputSplit split, JobConf job, Reporter reporter)
           
 RecordReader<BytesWritable,BytesWritable> SequenceFileAsBinaryInputFormat.getRecordReader(InputSplit split, JobConf job, Reporter reporter)
           
abstract  RecordReader<K,V> MultiFileInputFormat.getRecordReader(InputSplit split, JobConf job, Reporter reporter)
           
 RecordReader<Text,Text> KeyValueTextInputFormat.getRecordReader(InputSplit genericSplit, JobConf job, Reporter reporter)
           
abstract  RecordReader<K,V> FileInputFormat.getRecordReader(InputSplit split, JobConf job, Reporter reporter)
           
 RecordReader<K,V> InputFormat.getRecordReader(InputSplit split, JobConf job, Reporter reporter)
          Get the RecordReader for the given InputSplit.
 

Methods in org.apache.hadoop.mapred with parameters of type RecordReader
 void MapRunner.run(RecordReader<K1,V1> input, OutputCollector<K2,V2> output, Reporter reporter)
           
 void MapRunnable.run(RecordReader<K1,V1> input, OutputCollector<K2,V2> output, Reporter reporter)
          Start mapping input <key, value> pairs.
 

Uses of RecordReader in org.apache.hadoop.mapred.join
 

Subinterfaces of RecordReader in org.apache.hadoop.mapred.join
 interface ComposableRecordReader<K extends WritableComparable,V extends Writable>
          Additional operations required of a RecordReader to participate in a join.
 

Classes in org.apache.hadoop.mapred.join that implement RecordReader
 class InnerJoinRecordReader<K extends WritableComparable>
          Full inner join.
 class JoinRecordReader<K extends WritableComparable>
          Base class for Composite joins returning Tuples of arbitrary Writables.
 class MultiFilterRecordReader<K extends WritableComparable,V extends Writable>
          Base class for Composite join returning values derived from multiple sources, but generally not tuples.
 class OuterJoinRecordReader<K extends WritableComparable>
          Full outer join.
 class OverrideRecordReader<K extends WritableComparable,V extends Writable>
          Prefer the "rightmost" data source for this key.
 class WrappedRecordReader<K extends WritableComparable,U extends Writable>
          Proxy class for a RecordReader participating in the join framework.
 

Uses of RecordReader in org.apache.hadoop.mapred.lib
 

Methods in org.apache.hadoop.mapred.lib that return RecordReader
 RecordReader<LongWritable,Text> NLineInputFormat.getRecordReader(InputSplit genericSplit, JobConf job, Reporter reporter)
           
 

Methods in org.apache.hadoop.mapred.lib with parameters of type RecordReader
 void MultithreadedMapRunner.run(RecordReader<K1,V1> input, OutputCollector<K2,V2> output, Reporter reporter)
           
 

Uses of RecordReader in org.apache.hadoop.streaming
 

Classes in org.apache.hadoop.streaming that implement RecordReader
 class StreamBaseRecordReader
          Shared functionality for hadoopStreaming formats.
 class StreamXmlRecordReader
          A way to interpret XML fragments as Mapper input records.
 

Methods in org.apache.hadoop.streaming that return RecordReader
 RecordReader<Text,Text> StreamInputFormat.getRecordReader(InputSplit genericSplit, JobConf job, Reporter reporter)
           
 



Copyright © 2008 The Apache Software Foundation