Uses of Class
org.apache.hadoop.mapreduce.lib.join.TupleWritable

Packages that use TupleWritable
org.apache.hadoop.mapred.join   
org.apache.hadoop.mapreduce.lib.join   
 

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

Subclasses of TupleWritable in org.apache.hadoop.mapred.join
 class TupleWritable
          Writable type storing multiple Writables.
 

Uses of TupleWritable in org.apache.hadoop.mapreduce.lib.join
 

Methods in org.apache.hadoop.mapreduce.lib.join that return TupleWritable
protected  TupleWritable CompositeRecordReader.createTupleWritable()
          Create a value to be used internally for joins.
 TupleWritable JoinRecordReader.createValue()
           
 

Methods in org.apache.hadoop.mapreduce.lib.join that return types with arguments of type TupleWritable
 RecordReader<K,TupleWritable> CompositeInputFormat.createRecordReader(InputSplit split, TaskAttemptContext taskContext)
          Construct a CompositeRecordReader for the children of this InputFormat as defined in the init expression.
protected  ResetableIterator<TupleWritable> JoinRecordReader.getDelegate()
          Return an iterator wrapping the JoinCollector.
 

Methods in org.apache.hadoop.mapreduce.lib.join with parameters of type TupleWritable
protected abstract  boolean CompositeRecordReader.combine(Object[] srcs, TupleWritable value)
           
protected  boolean OuterJoinRecordReader.combine(Object[] srcs, TupleWritable dst)
          Emit everything from the collector.
protected  boolean InnerJoinRecordReader.combine(Object[] srcs, TupleWritable dst)
          Return true iff the tuple is full (all data sources contain this key).
protected  boolean MultiFilterRecordReader.combine(Object[] srcs, TupleWritable dst)
          Default implementation offers MultiFilterRecordReader.emit(org.apache.hadoop.mapreduce.lib.join.TupleWritable) every Tuple from the collector (the outer join of child RRs).
protected  V OverrideRecordReader.emit(TupleWritable dst)
          Emit the value with the highest position in the tuple.
protected abstract  V MultiFilterRecordReader.emit(TupleWritable dst)
          For each tuple emitted, return a value (typically one of the values in the tuple).
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.