Methods in org.apache.hadoop.mapred that return RawKeyValueIterator |
static
|
Merger.merge(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
Class<K> keyClass,
Class<V> valueClass,
org.apache.hadoop.io.compress.CompressionCodec codec,
List<Merger.Segment<K,V>> segments,
int mergeFactor,
int inMemSegments,
org.apache.hadoop.fs.Path tmpDir,
org.apache.hadoop.io.RawComparator<K> comparator,
org.apache.hadoop.util.Progressable reporter,
boolean sortSegments,
Counters.Counter readsCounter,
Counters.Counter writesCounter,
org.apache.hadoop.util.Progress mergePhase)
|
static
|
Merger.merge(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
Class<K> keyClass,
Class<V> valueClass,
org.apache.hadoop.io.compress.CompressionCodec codec,
List<Merger.Segment<K,V>> segments,
int mergeFactor,
org.apache.hadoop.fs.Path tmpDir,
org.apache.hadoop.io.RawComparator<K> comparator,
org.apache.hadoop.util.Progressable reporter,
boolean sortSegments,
Counters.Counter readsCounter,
Counters.Counter writesCounter,
org.apache.hadoop.util.Progress mergePhase)
|
static
|
Merger.merge(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
Class<K> keyClass,
Class<V> valueClass,
org.apache.hadoop.io.compress.CompressionCodec codec,
org.apache.hadoop.fs.Path[] inputs,
boolean deleteInputs,
int mergeFactor,
org.apache.hadoop.fs.Path tmpDir,
org.apache.hadoop.io.RawComparator<K> comparator,
org.apache.hadoop.util.Progressable reporter,
Counters.Counter readsCounter,
Counters.Counter writesCounter,
Counters.Counter mergedMapOutputsCounter,
org.apache.hadoop.util.Progress mergePhase)
|
static
|
Merger.merge(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
Class<K> keyClass,
Class<V> valueClass,
org.apache.hadoop.io.compress.CompressionCodec codec,
org.apache.hadoop.fs.Path[] inputs,
boolean deleteInputs,
int mergeFactor,
org.apache.hadoop.fs.Path tmpDir,
org.apache.hadoop.io.RawComparator<K> comparator,
org.apache.hadoop.util.Progressable reporter,
Counters.Counter readsCounter,
Counters.Counter writesCounter,
org.apache.hadoop.util.Progress mergePhase)
|
static
|
Merger.merge(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
Class<K> keyClass,
Class<V> valueClass,
List<Merger.Segment<K,V>> segments,
int mergeFactor,
int inMemSegments,
org.apache.hadoop.fs.Path tmpDir,
org.apache.hadoop.io.RawComparator<K> comparator,
org.apache.hadoop.util.Progressable reporter,
boolean sortSegments,
Counters.Counter readsCounter,
Counters.Counter writesCounter,
org.apache.hadoop.util.Progress mergePhase)
|
static
|
Merger.merge(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
Class<K> keyClass,
Class<V> valueClass,
List<Merger.Segment<K,V>> segments,
int mergeFactor,
org.apache.hadoop.fs.Path tmpDir,
org.apache.hadoop.io.RawComparator<K> comparator,
org.apache.hadoop.util.Progressable reporter,
boolean sortSegments,
Counters.Counter readsCounter,
Counters.Counter writesCounter,
org.apache.hadoop.util.Progress mergePhase)
|
static
|
Merger.merge(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
Class<K> keyClass,
Class<V> valueClass,
List<Merger.Segment<K,V>> segments,
int mergeFactor,
org.apache.hadoop.fs.Path tmpDir,
org.apache.hadoop.io.RawComparator<K> comparator,
org.apache.hadoop.util.Progressable reporter,
Counters.Counter readsCounter,
Counters.Counter writesCounter,
org.apache.hadoop.util.Progress mergePhase)
|
RawKeyValueIterator |
ShuffleConsumerPlugin.run()
|
Methods in org.apache.hadoop.mapred with parameters of type RawKeyValueIterator |
abstract void |
Task.CombinerRunner.combine(RawKeyValueIterator iterator,
OutputCollector<K,V> collector)
Run the combiner over a set of inputs. |
void |
Task.OldCombinerRunner.combine(RawKeyValueIterator kvIter,
OutputCollector<K,V> combineCollector)
|
void |
Task.NewCombinerRunner.combine(RawKeyValueIterator iterator,
OutputCollector<K,V> collector)
|
protected static
|
Task.createReduceContext(Reducer<INKEY,INVALUE,OUTKEY,OUTVALUE> reducer,
org.apache.hadoop.conf.Configuration job,
TaskAttemptID taskId,
RawKeyValueIterator rIter,
Counter inputKeyCounter,
Counter inputValueCounter,
RecordWriter<OUTKEY,OUTVALUE> output,
OutputCommitter committer,
StatusReporter reporter,
org.apache.hadoop.io.RawComparator<INKEY> comparator,
Class<INKEY> keyClass,
Class<INVALUE> valueClass)
|
static
|
Merger.writeFile(RawKeyValueIterator records,
IFile.Writer<K,V> writer,
org.apache.hadoop.util.Progressable progressable,
org.apache.hadoop.conf.Configuration conf)
|