@InterfaceAudience.Public @InterfaceStability.Stable public abstract class MultiFilterRecordReader<K extends WritableComparable,V extends Writable> extends CompositeRecordReader<K,V,V> implements ComposableRecordReader<K,V>
jc, kids
Constructor and Description |
---|
MultiFilterRecordReader(int id,
JobConf conf,
int capacity,
Class<? extends WritableComparator> cmpcl) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
combine(Object[] srcs,
TupleWritable dst)
Default implementation offers
emit(org.apache.hadoop.mapred.join.TupleWritable) every Tuple from the
collector (the outer join of child RRs). |
V |
createValue()
Create an object of the appropriate type to be used as a value.
|
protected abstract V |
emit(TupleWritable dst)
For each tuple emitted, return a value (typically one of the values
in the tuple).
|
protected ResetableIterator<V> |
getDelegate()
Return an iterator returning a single value from the tuple.
|
boolean |
next(K key,
V value)
Reads the next key/value pair from the input for processing.
|
accept, add, close, compareTo, createInternalValue, createKey, fillJoinCollector, getComparator, getConf, getPos, getProgress, getRecordReaderQueue, hasNext, id, key, key, setConf, skip
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
accept, hasNext, id, key, key, skip
close, createKey, getPos, getProgress
compareTo
public MultiFilterRecordReader(int id, JobConf conf, int capacity, Class<? extends WritableComparator> cmpcl) throws IOException
IOException
protected abstract V emit(TupleWritable dst) throws IOException
IOException
protected boolean combine(Object[] srcs, TupleWritable dst)
emit(org.apache.hadoop.mapred.join.TupleWritable)
every Tuple from the
collector (the outer join of child RRs).combine
in class CompositeRecordReader<K extends WritableComparable,V extends Writable,V extends Writable>
public boolean next(K key, V value) throws IOException
next
in interface RecordReader<K extends WritableComparable,V extends Writable>
key
- the key to read data intovalue
- the value to read data intoIOException
public V createValue()
createValue
in interface RecordReader<K extends WritableComparable,V extends Writable>
protected ResetableIterator<V> getDelegate()
getDelegate
in class CompositeRecordReader<K extends WritableComparable,V extends Writable,V extends Writable>
MultiFilterRecordReader.MultiFilterDelegationIterator
Copyright © 2024 Apache Software Foundation. All rights reserved.