org.apache.hadoop.mapreduce.lib.join
Class OuterJoinRecordReader<K extends WritableComparable<?>>

java.lang.Object
  extended by org.apache.hadoop.mapreduce.RecordReader<K,V>
      extended by org.apache.hadoop.mapreduce.lib.join.ComposableRecordReader<K,X>
          extended by org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader<K,Writable,TupleWritable>
              extended by org.apache.hadoop.mapreduce.lib.join.JoinRecordReader<K>
                  extended by org.apache.hadoop.mapreduce.lib.join.OuterJoinRecordReader<K>
All Implemented Interfaces:
Closeable, Comparable<ComposableRecordReader<K,?>>, Configurable

@InterfaceAudience.Public
@InterfaceStability.Stable
public class OuterJoinRecordReader<K extends WritableComparable<?>>
extends JoinRecordReader<K>

Full outer join.


Field Summary
 
Fields inherited from class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
conf, jc, key, keyclass, kids, value
 
Method Summary
protected  boolean combine(Object[] srcs, TupleWritable dst)
          Emit everything from the collector.
 
Methods inherited from class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader
createValue, getDelegate, nextKeyValue
 
Methods inherited from class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
accept, add, close, compareTo, createKey, createTupleWritable, fillJoinCollector, getComparator, getConf, getCurrentKey, getCurrentValue, getProgress, getRecordReaderQueue, hasNext, id, initialize, key, key, setConf, skip
 
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 

Method Detail

combine

protected boolean combine(Object[] srcs,
                          TupleWritable dst)
Emit everything from the collector.

Specified by:
combine in class CompositeRecordReader<K extends WritableComparable<?>,Writable,TupleWritable>


Copyright © 2014 Apache Software Foundation. All Rights Reserved.