程序包 | 说明 |
---|---|
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.
|
限定符和类型 | 方法和说明 |
---|---|
protected TupleWritable |
CompositeRecordReader.createInternalValue()
Create a value to be used internally for joins.
|
TupleWritable |
JoinRecordReader.createValue()
Create an object of the appropriate type to be used as a value.
|
限定符和类型 | 方法和说明 |
---|---|
protected ResetableIterator<TupleWritable> |
JoinRecordReader.getDelegate()
Return an iterator wrapping the JoinCollector.
|
ComposableRecordReader<K,TupleWritable> |
CompositeInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter)
Construct a CompositeRecordReader for the children of this InputFormat
as defined in the init expression.
|
限定符和类型 | 方法和说明 |
---|---|
void |
JoinRecordReader.JoinDelegationIterator.add(TupleWritable item) |
protected boolean |
OuterJoinRecordReader.combine(Object[] srcs,
TupleWritable dst)
Emit everything from the collector.
|
protected boolean |
MultiFilterRecordReader.combine(Object[] srcs,
TupleWritable dst)
Default implementation offers
MultiFilterRecordReader.emit(org.apache.hadoop.mapred.join.TupleWritable) every Tuple from the
collector (the outer join of child RRs). |
protected boolean |
InnerJoinRecordReader.combine(Object[] srcs,
TupleWritable dst)
Return true iff the tuple is full (all data sources contain this key).
|
protected abstract boolean |
CompositeRecordReader.combine(Object[] srcs,
TupleWritable value) |
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).
|
boolean |
JoinRecordReader.next(K key,
TupleWritable value)
Emit the next set of key, value pairs as defined by the child
RecordReaders and operation associated with this composite RR.
|
boolean |
JoinRecordReader.JoinDelegationIterator.next(TupleWritable val) |
boolean |
JoinRecordReader.JoinDelegationIterator.replay(TupleWritable val) |
Copyright © 2009 The Apache Software Foundation