@InterfaceAudience.Public @InterfaceStability.Stable public abstract class MultiFilterRecordReader<K extends WritableComparable<?>,V extends Writable> extends CompositeRecordReader<K,V,V>
| Constructor and Description | 
|---|
| MultiFilterRecordReader(int id,
                       Configuration 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.mapreduce.lib.join.TupleWritable)every Tuple from the
 collector (the outer join of child RRs). | 
| 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. | 
| void | initialize(InputSplit split,
          TaskAttemptContext context)Called once at initialization. | 
| boolean | nextKeyValue()Read the next key, value pair. | 
accept, add, close, compareTo, createKey, createTupleWritable, fillJoinCollector, getComparator, getConf, getCurrentKey, getCurrentValue, getProgress, getRecordReaderQueue, hasNext, id, key, key, setConf, skippublic MultiFilterRecordReader(int id,
                               Configuration conf,
                               int capacity,
                               Class<? extends WritableComparator> cmpcl)
                        throws IOException
IOExceptionprotected abstract V emit(TupleWritable dst) throws IOException
IOExceptionprotected boolean combine(Object[] srcs, TupleWritable dst)
emit(org.apache.hadoop.mapreduce.lib.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 nextKeyValue()
                     throws IOException,
                            InterruptedException
nextKeyValue in class RecordReader<K extends WritableComparable<?>,V extends Writable>IOExceptionInterruptedExceptionpublic void initialize(InputSplit split, TaskAttemptContext context) throws IOException, InterruptedException
RecordReaderinitialize in class CompositeRecordReader<K extends WritableComparable<?>,V extends Writable,V extends Writable>split - the split that defines the range of records to readcontext - the information about the taskIOExceptionInterruptedExceptionprotected ResetableIterator<V> getDelegate()
getDelegate in class CompositeRecordReader<K extends WritableComparable<?>,V extends Writable,V extends Writable>MultiFilterRecordReader.MultiFilterDelegationIteratorCopyright © 2023 Apache Software Foundation. All rights reserved.