Package | Description |
---|---|
org.apache.hadoop.examples.pi |
This package consists of a map/reduce application,
distbbp,
which computes exact binary digits of the mathematical constant π.
|
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.NullWritable,SummationWritable> |
DistSum.Machine.AbstractInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit generic,
org.apache.hadoop.mapreduce.TaskAttemptContext context)
Specify how to read the records
|
Modifier and Type | Method and Description |
---|---|
int |
SummationWritable.compareTo(SummationWritable that) |
int |
DistSum.ReduceSide.IndexPartitioner.getPartition(org.apache.hadoop.io.IntWritable index,
SummationWritable value,
int numPartitions)
Return the index as the partition.
|
protected void |
DistSum.ReduceSide.PartitionMapper.map(org.apache.hadoop.io.NullWritable nw,
SummationWritable sigma,
org.apache.hadoop.mapreduce.Mapper.Context context)
Partitions sigma into parts
|
protected void |
DistSum.MapSide.SummingMapper.map(org.apache.hadoop.io.NullWritable nw,
SummationWritable sigma,
org.apache.hadoop.mapreduce.Mapper.Context context) |
Modifier and Type | Method and Description |
---|---|
protected void |
DistSum.ReduceSide.SummingReducer.reduce(org.apache.hadoop.io.IntWritable index,
Iterable<SummationWritable> sums,
org.apache.hadoop.mapreduce.Reducer.Context context) |
Copyright © 2017 Apache Software Foundation. All Rights Reserved.