A B C D E F G H I J L M N O P Q R S T U V W 

A

accuracy(long, boolean) - Static method in class org.apache.hadoop.examples.pi.Util
Estimate accuracy.
addColumn(ColumnName, boolean) - Method in class org.apache.hadoop.examples.dancing.DancingLinks
Add a column to the table
addColumn(ColumnName) - Method in class org.apache.hadoop.examples.dancing.DancingLinks
Add a column to the table
addMod(double, double) - Static method in class org.apache.hadoop.examples.pi.math.Modular
Given x in [0,1) and a in (-1,1), return (x, a) mod 1.0.
addRow(boolean[]) - Method in class org.apache.hadoop.examples.dancing.DancingLinks
Add a row to the table.
AggregateWordCount - Class in org.apache.hadoop.examples
This is an example Aggregated Hadoop Map/Reduce application.
AggregateWordCount() - Constructor for class org.apache.hadoop.examples.AggregateWordCount
 
AggregateWordCount.WordCountPlugInClass - Class in org.apache.hadoop.examples
 
AggregateWordCount.WordCountPlugInClass() - Constructor for class org.apache.hadoop.examples.AggregateWordCount.WordCountPlugInClass
 
AggregateWordHistogram - Class in org.apache.hadoop.examples
This is an example Aggregated Hadoop Map/Reduce application.
AggregateWordHistogram() - Constructor for class org.apache.hadoop.examples.AggregateWordHistogram
 
AggregateWordHistogram.AggregateWordHistogramPlugin - Class in org.apache.hadoop.examples
 
AggregateWordHistogram.AggregateWordHistogramPlugin() - Constructor for class org.apache.hadoop.examples.AggregateWordHistogram.AggregateWordHistogramPlugin
 
ArithmeticProgression - Class in org.apache.hadoop.examples.pi.math
An arithmetic progression
ArithmeticProgression(char, long, long, long) - Constructor for class org.apache.hadoop.examples.pi.math.ArithmeticProgression
Constructor

B

BaileyBorweinPlouffe - Class in org.apache.hadoop.examples
A map/reduce program that uses Bailey-Borwein-Plouffe to compute exact digits of Pi.
BaileyBorweinPlouffe() - Constructor for class org.apache.hadoop.examples.BaileyBorweinPlouffe
 
BaileyBorweinPlouffe.BbpInputFormat - Class in org.apache.hadoop.examples
Input format for the BaileyBorweinPlouffe.BbpMapper.
BaileyBorweinPlouffe.BbpInputFormat() - Constructor for class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpInputFormat
 
BaileyBorweinPlouffe.BbpMapper - Class in org.apache.hadoop.examples
Mapper class computing digits of Pi.
BaileyBorweinPlouffe.BbpMapper() - Constructor for class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpMapper
 
BaileyBorweinPlouffe.BbpReducer - Class in org.apache.hadoop.examples
Reducer for concatenating map outputs.
BaileyBorweinPlouffe.BbpReducer() - Constructor for class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpReducer
 
BaileyBorweinPlouffe.BbpSplit - Class in org.apache.hadoop.examples
BaileyBorweinPlouffe.BbpSplit() - Constructor for class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpSplit
Public default constructor for the Writable interface.
Bellard - Class in org.apache.hadoop.examples.pi.math
Bellard's BBP-type Pi formula 1/2^6 \sum_{n=0}^\infty (-1)^n/2^{10n} (-2^5/(4n+1) -1/(4n+3) +2^8/(10n+1) -2^6/(10n+3) -2^2/(10n+5) -2^2/(10n+7) +1/(10n+9)) References: [1] David H.
Bellard() - Constructor for class org.apache.hadoop.examples.pi.math.Bellard
 
Bellard.Parameter - Enum in org.apache.hadoop.examples.pi.math
Parameters for the sums
Bellard.Sum - Class in org.apache.hadoop.examples.pi.math
The sums in the Bellard's formula
bit2terms(long) - Static method in class org.apache.hadoop.examples.pi.math.Bellard
Estimate the number of terms.
BlockLocality - Class in org.apache.hadoop.examples.blocklocality
Launches the job, and waits for it to finish.
BlockLocality() - Constructor for class org.apache.hadoop.examples.blocklocality.BlockLocality
 
BYTES_PER_MAP - Static variable in class org.apache.hadoop.examples.RandomTextWriter
 
BYTES_PER_MAP - Static variable in class org.apache.hadoop.examples.RandomWriter
 

C

checkDirectory(File) - Static method in class org.apache.hadoop.examples.pi.Util
Check local directory.
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.examples.terasort.TeraOutputFormat
 
CLASS - Static variable in class org.apache.hadoop.examples.dancing.Pentomino
 
cleanup(Reducer<LongWritable, BytesWritable, LongWritable, BytesWritable>.Context) - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpReducer
Write output to files.
cleanup(Reducer<BooleanWritable, LongWritable, WritableComparable<?>, Writable>.Context) - Method in class org.apache.hadoop.examples.QuasiMonteCarlo.QmcReducer
Reduce task done, write output to a file.
cleanup(Mapper<LongWritable, NullWritable, Text, Text>.Context) - Method in class org.apache.hadoop.examples.terasort.TeraGen.SortGenMapper
 
cleanup(Mapper<LongWritable, NullWritable, Text, Text>.Context) - Method in class org.apache.hadoop.examples.terasort.TeraGenWithCRC.SortGenMapper
 
close() - Method in class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
close() - Method in class org.apache.hadoop.examples.SleepJob
 
Combinable<T> - Interface in org.apache.hadoop.examples.pi
A class is Combinable if its object can be combined with other objects.
combine(T) - Method in interface org.apache.hadoop.examples.pi.Combinable
Combine this with that.
combine(Summation) - Method in class org.apache.hadoop.examples.pi.math.Summation
Combine this with that.
combine(TaskResult) - Method in class org.apache.hadoop.examples.pi.TaskResult
Combine this with that.
combine(Collection<T>) - Static method in class org.apache.hadoop.examples.pi.Util
Combine a list of items.
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.examples.SecondarySort.FirstGroupingComparator
 
compare(SecondarySort.IntPair, SecondarySort.IntPair) - Method in class org.apache.hadoop.examples.SecondarySort.FirstGroupingComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.examples.SecondarySort.IntPair.Comparator
 
compareTo(Object) - Method in class org.apache.hadoop.examples.MultiFileWordCount.WordOffset
 
compareTo(ArithmeticProgression) - Method in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
compareTo(Summation) - Method in class org.apache.hadoop.examples.pi.math.Summation
compareTo(SummationWritable) - Method in class org.apache.hadoop.examples.pi.SummationWritable
compareTo(TaskResult) - Method in class org.apache.hadoop.examples.pi.TaskResult
compareTo(SecondarySort.IntPair) - Method in class org.apache.hadoop.examples.SecondarySort.IntPair
 
compute() - Method in class org.apache.hadoop.examples.pi.math.Summation
Compute the value of the summation.
computePi(long, Map<Bellard.Parameter, T>) - Static method in class org.apache.hadoop.examples.pi.math.Bellard
Compute bits of Pi from the results.
computePi(long) - Static method in class org.apache.hadoop.examples.pi.math.Bellard
Compute bits of Pi in the local machine.
configure(JobConf) - Method in class org.apache.hadoop.examples.SleepJob
 
Container<T> - Interface in org.apache.hadoop.examples.pi
A class is a Container if it contains an element.
contains(Summation) - Method in class org.apache.hadoop.examples.pi.math.Summation
Does this contains that?
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpInputFormat
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.examples.MultiFileWordCount.MyInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.examples.pi.DistSum.Machine.AbstractInputFormat
Specify how to read the records
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.examples.terasort.TeraInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.examples.terasort.TeraInputFormatWithCRC
 
createWriter(File, String) - Static method in class org.apache.hadoop.examples.pi.Util
Create a writer of a local file.

D

DancingLinks<ColumnName> - Class in org.apache.hadoop.examples.dancing
A generic solver for tile laying problems using Knuth's dancing link algorithm.
DancingLinks() - Constructor for class org.apache.hadoop.examples.dancing.DancingLinks
 
DancingLinks.SolutionAcceptor<ColumnName> - Interface in org.apache.hadoop.examples.dancing
Applications should implement this to receive the solutions to their problems.
DBCountPageView - Class in org.apache.hadoop.examples
This is a demonstrative program, which uses DBInputFormat for reading the input data from a database, and DBOutputFormat for writing the data to the database.
DBCountPageView() - Constructor for class org.apache.hadoop.examples.DBCountPageView
 
delta - Variable in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
Difference between terms
DEPTH - Static variable in class org.apache.hadoop.examples.dancing.Pentomino
 
DESCRIPTION - Static variable in class org.apache.hadoop.examples.BaileyBorweinPlouffe
 
DESCRIPTION - Static variable in class org.apache.hadoop.examples.pi.DistBbp
 
DistBbp - Class in org.apache.hadoop.examples.pi
A map/reduce program that uses a BBP-type method to compute exact binary digits of Pi.
DistBbp() - Constructor for class org.apache.hadoop.examples.pi.DistBbp
 
DistributedPentomino - Class in org.apache.hadoop.examples.dancing
Launch a distributed pentomino solver.
DistributedPentomino() - Constructor for class org.apache.hadoop.examples.dancing.DistributedPentomino
 
DistributedPentomino.PentMap - Class in org.apache.hadoop.examples.dancing
Each map takes a line, which represents a prefix move and finds all of the solutions that start with that prefix.
DistributedPentomino.PentMap() - Constructor for class org.apache.hadoop.examples.dancing.DistributedPentomino.PentMap
 
DistSum - Class in org.apache.hadoop.examples.pi
The main class for computing sums using map/reduce jobs.
DistSum() - Constructor for class org.apache.hadoop.examples.pi.DistSum
 
DistSum.Machine - Class in org.apache.hadoop.examples.pi
Abstract machine for job execution.
DistSum.Machine() - Constructor for class org.apache.hadoop.examples.pi.DistSum.Machine
 
DistSum.Machine.AbstractInputFormat - Class in org.apache.hadoop.examples.pi
An abstract InputFormat for the jobs
DistSum.Machine.AbstractInputFormat() - Constructor for class org.apache.hadoop.examples.pi.DistSum.Machine.AbstractInputFormat
 
DistSum.Machine.SummationSplit - Class in org.apache.hadoop.examples.pi
Split for the summations
DistSum.Machine.SummationSplit() - Constructor for class org.apache.hadoop.examples.pi.DistSum.Machine.SummationSplit
 
DistSum.MapSide - Class in org.apache.hadoop.examples.pi
A machine which does computation on the map side.
DistSum.MapSide() - Constructor for class org.apache.hadoop.examples.pi.DistSum.MapSide
 
DistSum.MapSide.PartitionInputFormat - Class in org.apache.hadoop.examples.pi
An InputFormat which partitions a summation
DistSum.MapSide.PartitionInputFormat() - Constructor for class org.apache.hadoop.examples.pi.DistSum.MapSide.PartitionInputFormat
 
DistSum.MapSide.SummingMapper - Class in org.apache.hadoop.examples.pi
A mapper which computes sums
DistSum.MapSide.SummingMapper() - Constructor for class org.apache.hadoop.examples.pi.DistSum.MapSide.SummingMapper
 
DistSum.MixMachine - Class in org.apache.hadoop.examples.pi
A machine which chooses Machine in runtime according to the cluster status
DistSum.MixMachine() - Constructor for class org.apache.hadoop.examples.pi.DistSum.MixMachine
 
DistSum.ReduceSide - Class in org.apache.hadoop.examples.pi
A machine which does computation on the reduce side.
DistSum.ReduceSide() - Constructor for class org.apache.hadoop.examples.pi.DistSum.ReduceSide
 
DistSum.ReduceSide.IndexPartitioner - Class in org.apache.hadoop.examples.pi
Use the index for partitioning.
DistSum.ReduceSide.IndexPartitioner() - Constructor for class org.apache.hadoop.examples.pi.DistSum.ReduceSide.IndexPartitioner
 
DistSum.ReduceSide.PartitionMapper - Class in org.apache.hadoop.examples.pi
A Mapper which partitions a summation
DistSum.ReduceSide.PartitionMapper() - Constructor for class org.apache.hadoop.examples.pi.DistSum.ReduceSide.PartitionMapper
 
DistSum.ReduceSide.SummationInputFormat - Class in org.apache.hadoop.examples.pi
An InputFormat which returns a single summation.
DistSum.ReduceSide.SummationInputFormat() - Constructor for class org.apache.hadoop.examples.pi.DistSum.ReduceSide.SummationInputFormat
 
DistSum.ReduceSide.SummingReducer - Class in org.apache.hadoop.examples.pi
A Reducer which computes sums
DistSum.ReduceSide.SummingReducer() - Constructor for class org.apache.hadoop.examples.pi.DistSum.ReduceSide.SummingReducer
 

E

E - Variable in class org.apache.hadoop.examples.pi.math.Summation
Variable e in the summation.
equals(Object) - Method in class org.apache.hadoop.examples.MultiFileWordCount.WordOffset
 
equals(Object) - Method in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
equals(Object) - Method in class org.apache.hadoop.examples.pi.math.Summation
equals(Object) - Method in class org.apache.hadoop.examples.pi.SummationWritable
equals(Object) - Method in class org.apache.hadoop.examples.pi.TaskResult
equals(Object) - Method in class org.apache.hadoop.examples.SecondarySort.IntPair
 
err - Static variable in class org.apache.hadoop.examples.pi.Util
Error stream
estimatePi(int, long, Path, Configuration) - Static method in class org.apache.hadoop.examples.QuasiMonteCarlo
Run a map/reduce job for estimating Pi.
ExampleDriver - Class in org.apache.hadoop.examples
A description of an example program based on its class and a human-readable description.
ExampleDriver() - Constructor for class org.apache.hadoop.examples.ExampleDriver
 
execute(int, List<E>) - Static method in class org.apache.hadoop.examples.pi.Util
Execute the callables by a number of threads

F

fourRotations - Static variable in class org.apache.hadoop.examples.dancing.Pentomino
Are all 4 rotations unique?

G

generateKeyValPairs(Object, Object) - Method in class org.apache.hadoop.examples.AggregateWordCount.WordCountPlugInClass
 
generateKeyValPairs(Object, Object) - Method in class org.apache.hadoop.examples.AggregateWordHistogram.AggregateWordHistogramPlugin
Parse the given value, generate an aggregation-id/value pair per word.
GenSort - Class in org.apache.hadoop.examples.terasort
A single process data generator for the terasort data.
GenSort() - Constructor for class org.apache.hadoop.examples.terasort.GenSort
 
get(String) - Static method in enum org.apache.hadoop.examples.pi.math.Bellard.Parameter
Get the Parameter represented by the String
getCategory(List<List<Pentomino.ColumnName>>) - Method in class org.apache.hadoop.examples.dancing.Pentomino
Find whether the solution has the x in the upper left quadrant, the x-midline, the y-midline or in the center.
getColumnName(int) - Method in class org.apache.hadoop.examples.dancing.DancingLinks
Get the name of a given column as a string
getConf() - Method in class org.apache.hadoop.examples.terasort.TeraSort.SimplePartitioner
 
getCurrentKey() - Method in class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
getElement() - Method in interface org.apache.hadoop.examples.pi.Container
 
getElement() - Method in class org.apache.hadoop.examples.pi.DistSum.Machine.SummationSplit
getElement() - Method in class org.apache.hadoop.examples.pi.math.Bellard.Sum
getElement() - Method in class org.apache.hadoop.examples.pi.math.Summation
getElement() - Method in class org.apache.hadoop.examples.pi.SummationWritable
getElement() - Method in class org.apache.hadoop.examples.pi.TaskResult
getFinalSync(JobConf) - Static method in class org.apache.hadoop.examples.blocklocality.LocalityOutputFormat
Does the user want a final sync at close?
getFinalSync(JobContext) - Static method in class org.apache.hadoop.examples.terasort.TeraOutputFormat
Does the user want a final sync at close?
getFinalSync(JobContext) - Static method in class org.apache.hadoop.examples.terasort.TeraOutputFormatWithCRC
Does the user want a final sync at close?
getFirst() - Method in class org.apache.hadoop.examples.SecondarySort.IntPair
 
getFlippable() - Method in class org.apache.hadoop.examples.dancing.Pentomino.Piece
 
getLength() - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpSplit
getLength() - Method in class org.apache.hadoop.examples.pi.DistSum.Machine.SummationSplit
getLength() - Method in class org.apache.hadoop.examples.SleepJob.EmptySplit
 
getLocations() - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpSplit
No location is needed.
getLocations() - Method in class org.apache.hadoop.examples.pi.DistSum.Machine.SummationSplit
getLocations() - Method in class org.apache.hadoop.examples.SleepJob.EmptySplit
 
getMean() - Method in class org.apache.hadoop.examples.WordMean
Only valuable after run() called.
getMedian() - Method in class org.apache.hadoop.examples.WordMedian
 
getName() - Method in class org.apache.hadoop.examples.dancing.Pentomino.Piece
 
getNumberColumns() - Method in class org.apache.hadoop.examples.dancing.DancingLinks
Get the number of columns.
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.examples.terasort.TeraOutputFormat
 
getOutputReplication(JobContext) - Static method in class org.apache.hadoop.examples.terasort.TeraSort
 
getPartition(IntWritable, SummationWritable, int) - Method in class org.apache.hadoop.examples.pi.DistSum.ReduceSide.IndexPartitioner
Return the index as the partition.
getPartition(SecondarySort.IntPair, IntWritable, int) - Method in class org.apache.hadoop.examples.SecondarySort.FirstPartitioner
 
getPartition(IntWritable, NullWritable, int) - Method in class org.apache.hadoop.examples.SleepJob
 
getPartition(Text, Text, int) - Method in class org.apache.hadoop.examples.terasort.TeraSort.SimplePartitioner
 
getProgress() - Method in class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.examples.blocklocality.LocalityInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.examples.SleepJob.SleepInputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.examples.blocklocality.LocalityOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.examples.terasort.TeraOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.examples.terasort.TeraOutputFormatWithCRC
 
getResult() - Method in class org.apache.hadoop.examples.Sort
Get the last job that was run using this instance.
getRotations() - Method in class org.apache.hadoop.examples.dancing.Pentomino.Piece
 
getSecond() - Method in class org.apache.hadoop.examples.SecondarySort.IntPair
 
getShape(boolean, int) - Method in class org.apache.hadoop.examples.dancing.Pentomino.Piece
 
getSplits(JobContext) - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpInputFormat
getSplits(int) - Method in class org.apache.hadoop.examples.dancing.Pentomino
Generate a list of prefixes to a given depth
getSplits(JobContext) - Method in class org.apache.hadoop.examples.pi.DistSum.MapSide.PartitionInputFormat
Partitions the summation into parts and then return them as splits
getSplits(JobContext) - Method in class org.apache.hadoop.examples.pi.DistSum.ReduceSide.SummationInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.examples.SleepJob.SleepInputFormat
 
getSplits(JobContext) - Method in class org.apache.hadoop.examples.terasort.TeraInputFormat
 
getSplits(JobContext) - Method in class org.apache.hadoop.examples.terasort.TeraInputFormatWithCRC
 
getStandardDeviation() - Method in class org.apache.hadoop.examples.WordStandardDeviation
 
getSteps() - Method in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
Get the number of steps
getSums(long, int, Map<Bellard.Parameter, List<T>>) - Static method in class org.apache.hadoop.examples.pi.math.Bellard
Get the sums for the Bellard formula.
getUseSimplePartitioner(JobContext) - Static method in class org.apache.hadoop.examples.terasort.TeraSort
 
getValue() - Method in class org.apache.hadoop.examples.pi.math.Bellard.Sum
get the value of sigma
getValue() - Method in class org.apache.hadoop.examples.pi.math.Summation
Return the value of this summation
Grep - Class in org.apache.hadoop.examples
 

H

hashCode() - Method in class org.apache.hadoop.examples.MultiFileWordCount.WordOffset
 
hashCode() - Method in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
Not supported
hashCode() - Method in class org.apache.hadoop.examples.pi.math.Summation
Not supported
hashCode() - Method in class org.apache.hadoop.examples.pi.SummationWritable
Not supported
hashCode() - Method in class org.apache.hadoop.examples.pi.TaskResult
Not supported
hashCode() - Method in class org.apache.hadoop.examples.SecondarySort.IntPair
 
HEIGHT - Static variable in class org.apache.hadoop.examples.dancing.Pentomino
 
height - Variable in class org.apache.hadoop.examples.dancing.Pentomino
 

I

init(Job) - Method in class org.apache.hadoop.examples.pi.DistSum.MapSide
Initialize a job
init(Job) - Method in class org.apache.hadoop.examples.pi.DistSum.MixMachine
Initialize a job
init(Job) - Method in class org.apache.hadoop.examples.pi.DistSum.ReduceSide
Initialize a job
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
initializePieces() - Method in class org.apache.hadoop.examples.dancing.OneSidedPentomino
Define the one sided pieces.
initializePieces() - Method in class org.apache.hadoop.examples.dancing.Pentomino
Fill in the pieces list.
iterator() - Method in class org.apache.hadoop.examples.pi.math.Bellard.Sum

J

Join - Class in org.apache.hadoop.examples
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.
Join() - Constructor for class org.apache.hadoop.examples.Join
 

L

limit - Variable in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
Ending value
LocalityInputFormat - Class in org.apache.hadoop.examples.blocklocality
An input format that reads block location information from input file and returns 1 as key and block location information as value.
LocalityInputFormat() - Constructor for class org.apache.hadoop.examples.blocklocality.LocalityInputFormat
 
LocalityOutputFormat - Class in org.apache.hadoop.examples.blocklocality
A streamlined text output format that writes key, value, and "\r\n".
LocalityOutputFormat() - Constructor for class org.apache.hadoop.examples.blocklocality.LocalityOutputFormat
 
long2string(long) - Static method in class org.apache.hadoop.examples.pi.Util
Covert a long to a String in comma separated number format.

M

main(String[]) - Static method in class org.apache.hadoop.examples.AggregateWordCount
The main driver for word count map/reduce program.
main(String[]) - Static method in class org.apache.hadoop.examples.AggregateWordHistogram
The main driver for word count map/reduce program.
main(String[]) - Static method in class org.apache.hadoop.examples.BaileyBorweinPlouffe
The main method for running it as a stand alone command.
main(String[]) - Static method in class org.apache.hadoop.examples.blocklocality.BlockLocality
 
main(String[]) - Static method in class org.apache.hadoop.examples.dancing.DistributedPentomino
Launch the solver on 9x10 board and the one sided pentominos.
main(String[]) - Static method in class org.apache.hadoop.examples.dancing.OneSidedPentomino
Solve the 3x30 puzzle.
main(String[]) - Static method in class org.apache.hadoop.examples.dancing.Pentomino
Solve the 6x10 pentomino puzzle.
main(String[]) - Static method in class org.apache.hadoop.examples.dancing.Sudoku
Solves a set of sudoku puzzles.
main(String[]) - Static method in class org.apache.hadoop.examples.DBCountPageView
 
main(String[]) - Static method in class org.apache.hadoop.examples.ExampleDriver
 
main(String[]) - Static method in class org.apache.hadoop.examples.Grep
 
main(String[]) - Static method in class org.apache.hadoop.examples.Join
 
main(String[]) - Static method in class org.apache.hadoop.examples.MultiFileWordCount
 
main(String[]) - Static method in class org.apache.hadoop.examples.pi.DistBbp
main
main(String[]) - Static method in class org.apache.hadoop.examples.pi.DistSum
main
main(String[]) - Static method in class org.apache.hadoop.examples.pi.math.Bellard
main
main(String[]) - Static method in class org.apache.hadoop.examples.pi.Parser
main
main(String[]) - Static method in class org.apache.hadoop.examples.QuasiMonteCarlo
main method for running it as a stand alone command.
main(String[]) - Static method in class org.apache.hadoop.examples.RandomTextWriter
 
main(String[]) - Static method in class org.apache.hadoop.examples.RandomWriter
 
main(String[]) - Static method in class org.apache.hadoop.examples.SecondarySort
 
main(String[]) - Static method in class org.apache.hadoop.examples.SleepJob
 
main(String[]) - Static method in class org.apache.hadoop.examples.Sort
 
main(String[]) - Static method in class org.apache.hadoop.examples.terasort.GenSort
 
main(String[]) - Static method in class org.apache.hadoop.examples.terasort.TeraChecksum
 
main(String[]) - Static method in class org.apache.hadoop.examples.terasort.TeraGen
 
main(String[]) - Static method in class org.apache.hadoop.examples.terasort.TeraGenWithCRC
 
main(String[]) - Static method in class org.apache.hadoop.examples.terasort.TeraSort
 
main(String[]) - Static method in class org.apache.hadoop.examples.terasort.TeraSortWithCRC
 
main(String[]) - Static method in class org.apache.hadoop.examples.terasort.TeraValidate
 
main(String[]) - Static method in class org.apache.hadoop.examples.terasort.TeraValidateRecords
 
main(String[]) - Static method in class org.apache.hadoop.examples.terasort.TeraValidateWithCRC
 
main(String[]) - Static method in class org.apache.hadoop.examples.WordCount
 
main(String[]) - Static method in class org.apache.hadoop.examples.WordMean
 
main(String[]) - Static method in class org.apache.hadoop.examples.WordMedian
 
main(String[]) - Static method in class org.apache.hadoop.examples.WordStandardDeviation
 
map(LongWritable, IntWritable, Mapper<LongWritable, IntWritable, LongWritable, BytesWritable>.Context) - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpMapper
Compute the (offset+1)th to (offset+length)th digits.
map(WritableComparable<?>, Text, Mapper<WritableComparable<?>, Text, Text, Text>.Context) - Method in class org.apache.hadoop.examples.dancing.DistributedPentomino.PentMap
Break the prefix string into moves (a sequence of integer row ids that will be selected for each column in order).
map(MultiFileWordCount.WordOffset, Text, Mapper<MultiFileWordCount.WordOffset, Text, Text, IntWritable>.Context) - Method in class org.apache.hadoop.examples.MultiFileWordCount.MapClass
 
map(NullWritable, SummationWritable, Mapper<NullWritable, SummationWritable, NullWritable, TaskResult>.Context) - Method in class org.apache.hadoop.examples.pi.DistSum.MapSide.SummingMapper
 
map(NullWritable, SummationWritable, Mapper<NullWritable, SummationWritable, IntWritable, SummationWritable>.Context) - Method in class org.apache.hadoop.examples.pi.DistSum.ReduceSide.PartitionMapper
Partitions sigma into parts
map(LongWritable, LongWritable, Mapper<LongWritable, LongWritable, BooleanWritable, LongWritable>.Context) - Method in class org.apache.hadoop.examples.QuasiMonteCarlo.QmcMapper
Map method.
map(LongWritable, Text, Mapper<LongWritable, Text, SecondarySort.IntPair, IntWritable>.Context) - Method in class org.apache.hadoop.examples.SecondarySort.MapClass
 
map(IntWritable, IntWritable, OutputCollector<IntWritable, NullWritable>, Reporter) - Method in class org.apache.hadoop.examples.SleepJob
 
map(LongWritable, NullWritable, Mapper<LongWritable, NullWritable, Text, Text>.Context) - Method in class org.apache.hadoop.examples.terasort.TeraGen.SortGenMapper
 
map(LongWritable, NullWritable, Mapper<LongWritable, NullWritable, Text, Text>.Context) - Method in class org.apache.hadoop.examples.terasort.TeraGenWithCRC.SortGenMapper
 
map(Object, Text, Mapper<Object, Text, Text, IntWritable>.Context) - Method in class org.apache.hadoop.examples.WordCount.TokenizerMapper
 
map(Object, Text, Mapper<Object, Text, Text, LongWritable>.Context) - Method in class org.apache.hadoop.examples.WordMean.WordMeanMapper
Emits 2 key-value pairs for counting the word and its length.
map(Object, Text, Mapper<Object, Text, IntWritable, IntWritable>.Context) - Method in class org.apache.hadoop.examples.WordMedian.WordMedianMapper
Emits a key-value pair for counting the word.
map(Object, Text, Mapper<Object, Text, Text, LongWritable>.Context) - Method in class org.apache.hadoop.examples.WordStandardDeviation.WordStandardDeviationMapper
Emits 3 key-value pairs for counting the word, its length, and the squares of its length.
MAPS_PER_HOST - Static variable in class org.apache.hadoop.examples.RandomTextWriter
 
MAPS_PER_HOST - Static variable in class org.apache.hadoop.examples.RandomWriter
 
MAX_KEY - Static variable in class org.apache.hadoop.examples.RandomTextWriter
 
MAX_KEY - Static variable in class org.apache.hadoop.examples.RandomWriter
 
MAX_VALUE - Static variable in class org.apache.hadoop.examples.RandomTextWriter
 
MAX_VALUE - Static variable in class org.apache.hadoop.examples.RandomWriter
 
millis2String(long) - Static method in class org.apache.hadoop.examples.pi.Util
Covert milliseconds to a String.
MIN_KEY - Static variable in class org.apache.hadoop.examples.RandomTextWriter
 
MIN_KEY - Static variable in class org.apache.hadoop.examples.RandomWriter
 
MIN_VALUE - Static variable in class org.apache.hadoop.examples.RandomTextWriter
 
MIN_VALUE - Static variable in class org.apache.hadoop.examples.RandomWriter
 
mod(long, long) - Static method in class org.apache.hadoop.examples.pi.math.Modular
Compute 2^e mod n
modInverse(long, long) - Static method in class org.apache.hadoop.examples.pi.math.Modular
Given 0 < x < y, return x^(-1) mod y.
Modular - Class in org.apache.hadoop.examples.pi.math
Modular arithmetics
Modular() - Constructor for class org.apache.hadoop.examples.pi.math.Modular
 
MultiFileWordCount - Class in org.apache.hadoop.examples
MultiFileWordCount is an example to demonstrate the usage of MultiFileInputFormat.
MultiFileWordCount() - Constructor for class org.apache.hadoop.examples.MultiFileWordCount
 
MultiFileWordCount.CombineFileLineRecordReader - Class in org.apache.hadoop.examples
RecordReader is responsible from extracting records from a chunk of the CombineFileSplit.
MultiFileWordCount.CombineFileLineRecordReader(CombineFileSplit, TaskAttemptContext, Integer) - Constructor for class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
MultiFileWordCount.MapClass - Class in org.apache.hadoop.examples
This Mapper is similar to the one in WordCount.TokenizerMapper.
MultiFileWordCount.MapClass() - Constructor for class org.apache.hadoop.examples.MultiFileWordCount.MapClass
 
MultiFileWordCount.MyInputFormat - Class in org.apache.hadoop.examples
To use CombineFileInputFormat, one should extend it, to return a (custom) RecordReader.
MultiFileWordCount.MyInputFormat() - Constructor for class org.apache.hadoop.examples.MultiFileWordCount.MyInputFormat
 
MultiFileWordCount.WordOffset - Class in org.apache.hadoop.examples
This record keeps <filename,offset> pairs.
MultiFileWordCount.WordOffset() - Constructor for class org.apache.hadoop.examples.MultiFileWordCount.WordOffset
 

N

N - Variable in class org.apache.hadoop.examples.pi.math.Summation
Variable n in the summation.
nextKeyValue() - Method in class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
NUM_ROWS - Static variable in class org.apache.hadoop.examples.terasort.TeraGen
 

O

oneRotation - Static variable in class org.apache.hadoop.examples.dancing.Pentomino
Is the piece fixed under rotation?
OneSidedPentomino - Class in org.apache.hadoop.examples.dancing
Of the "normal" 12 pentominos, 6 of them have distinct shapes when flipped.
OneSidedPentomino() - Constructor for class org.apache.hadoop.examples.dancing.OneSidedPentomino
 
OneSidedPentomino(int, int) - Constructor for class org.apache.hadoop.examples.dancing.OneSidedPentomino
 
org.apache.hadoop.examples - package org.apache.hadoop.examples
Hadoop example code.
org.apache.hadoop.examples.blocklocality - package org.apache.hadoop.examples.blocklocality
 
org.apache.hadoop.examples.dancing - package org.apache.hadoop.examples.dancing
This package is a distributed implementation of Knuth's dancing links algorithm that can run under Hadoop.
org.apache.hadoop.examples.pi - package org.apache.hadoop.examples.pi
This package consists of a map/reduce application, distbbp, which computes exact binary digits of the mathematical constant π.
org.apache.hadoop.examples.pi.math - package org.apache.hadoop.examples.pi.math
This package provides useful mathematical library classes for the distbbp program.
org.apache.hadoop.examples.terasort - package org.apache.hadoop.examples.terasort
This package consists of 3 map/reduce applications for Hadoop to compete in the annual terabyte sort competition.
out - Static variable in class org.apache.hadoop.examples.pi.Util
Output stream
outputRecords(OutputStream, boolean, Unsigned16, Unsigned16, Unsigned16) - Static method in class org.apache.hadoop.examples.terasort.GenSort
 

P

parseLongVariable(String, String) - Static method in class org.apache.hadoop.examples.pi.Util
Parse a variable.
Parser - Class in org.apache.hadoop.examples.pi
A class for parsing outputs
Parser(boolean) - Constructor for class org.apache.hadoop.examples.pi.Parser
 
parseStringVariable(String, String) - Static method in class org.apache.hadoop.examples.pi.Util
Parse a variable.
partition(int) - Method in class org.apache.hadoop.examples.pi.math.Summation
Partition the summation.
Pentomino - Class in org.apache.hadoop.examples.dancing
 
Pentomino(int, int) - Constructor for class org.apache.hadoop.examples.dancing.Pentomino
Create the model for a given pentomino set of pieces and board size.
Pentomino() - Constructor for class org.apache.hadoop.examples.dancing.Pentomino
Create the object without initialization.
Pentomino.ColumnName - Interface in org.apache.hadoop.examples.dancing
This interface just is a marker for what types I expect to get back as column names.
Pentomino.Piece - Class in org.apache.hadoop.examples.dancing
Maintain information about a puzzle piece.
Pentomino.Piece(String, String, boolean, int[]) - Constructor for class org.apache.hadoop.examples.dancing.Pentomino.Piece
 
Pentomino.SolutionCategory - Enum in org.apache.hadoop.examples.dancing
 
pi2string(double, long) - Static method in class org.apache.hadoop.examples.pi.Util
Convert a pi value to a String.
pieces - Variable in class org.apache.hadoop.examples.dancing.Pentomino
 
printBitSkipped(long) - Static method in class org.apache.hadoop.examples.pi.Util
Print a "bits skipped" message.
printUsage(String[], String) - Static method in class org.apache.hadoop.examples.pi.Util
Print usage messages

Q

QuasiMonteCarlo - Class in org.apache.hadoop.examples
A map/reduce program that estimates the value of Pi using a quasi-Monte Carlo (qMC) method.
QuasiMonteCarlo() - Constructor for class org.apache.hadoop.examples.QuasiMonteCarlo
 
QuasiMonteCarlo.QmcMapper - Class in org.apache.hadoop.examples
Mapper class for Pi estimation.
QuasiMonteCarlo.QmcMapper() - Constructor for class org.apache.hadoop.examples.QuasiMonteCarlo.QmcMapper
 
QuasiMonteCarlo.QmcReducer - Class in org.apache.hadoop.examples
Reducer class for Pi estimation.
QuasiMonteCarlo.QmcReducer() - Constructor for class org.apache.hadoop.examples.QuasiMonteCarlo.QmcReducer
 

R

RandomTextWriter - Class in org.apache.hadoop.examples
This program uses map/reduce to just run a distributed job where there is no interaction between the tasks and each task writes a large unsorted random sequence of words.
RandomTextWriter() - Constructor for class org.apache.hadoop.examples.RandomTextWriter
 
RandomWriter - Class in org.apache.hadoop.examples
This program uses map/reduce to just run a distributed job where there is no interaction between the tasks and each task write a large unsorted random binary sequence file of BytesWritable.
RandomWriter() - Constructor for class org.apache.hadoop.examples.RandomWriter
 
read(Class<?>, Configuration) - Static method in class org.apache.hadoop.examples.pi.SummationWritable
Read sigma from conf
readFields(DataInput) - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpSplit
readFields(DataInput) - Method in class org.apache.hadoop.examples.MultiFileWordCount.WordOffset
 
readFields(DataInput) - Method in class org.apache.hadoop.examples.pi.DistSum.Machine.SummationSplit
readFields(DataInput) - Method in class org.apache.hadoop.examples.pi.SummationWritable
readFields(DataInput) - Method in class org.apache.hadoop.examples.pi.TaskResult
readFields(DataInput) - Method in class org.apache.hadoop.examples.SecondarySort.IntPair
Read the two integers.
readFields(DataInput) - Method in class org.apache.hadoop.examples.SleepJob.EmptySplit
 
reduce(LongWritable, Iterable<BytesWritable>, Reducer<LongWritable, BytesWritable, LongWritable, BytesWritable>.Context) - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpReducer
Concatenate map outputs.
reduce(IntWritable, Iterable<SummationWritable>, Reducer<IntWritable, SummationWritable, NullWritable, TaskResult>.Context) - Method in class org.apache.hadoop.examples.pi.DistSum.ReduceSide.SummingReducer
 
reduce(BooleanWritable, Iterable<LongWritable>, Reducer<BooleanWritable, LongWritable, WritableComparable<?>, Writable>.Context) - Method in class org.apache.hadoop.examples.QuasiMonteCarlo.QmcReducer
Accumulate number of points inside/outside results from the mappers.
reduce(SecondarySort.IntPair, Iterable<IntWritable>, Reducer<SecondarySort.IntPair, IntWritable, Text, IntWritable>.Context) - Method in class org.apache.hadoop.examples.SecondarySort.Reduce
 
reduce(IntWritable, Iterator<NullWritable>, OutputCollector<NullWritable, NullWritable>, Reporter) - Method in class org.apache.hadoop.examples.SleepJob
 
reduce(Text, Iterable<IntWritable>, Reducer<Text, IntWritable, Text, IntWritable>.Context) - Method in class org.apache.hadoop.examples.WordCount.IntSumReducer
 
reduce(Text, Iterable<LongWritable>, Reducer<Text, LongWritable, Text, LongWritable>.Context) - Method in class org.apache.hadoop.examples.WordMean.WordMeanReducer
Sums all the individual values within the iterator and writes them to the same key.
reduce(IntWritable, Iterable<IntWritable>, Reducer<IntWritable, IntWritable, IntWritable, IntWritable>.Context) - Method in class org.apache.hadoop.examples.WordMedian.WordMedianReducer
Sums all the individual values within the iterator and writes them to the same key.
reduce(Text, Iterable<LongWritable>, Reducer<Text, LongWritable, Text, LongWritable>.Context) - Method in class org.apache.hadoop.examples.WordStandardDeviation.WordStandardDeviationReducer
Sums all the individual values within the iterator and writes them to the same key.
REDUCES_PER_HOST - Static variable in class org.apache.hadoop.examples.Join
 
REDUCES_PER_HOST - Static variable in class org.apache.hadoop.examples.Sort
 
remainingTerms(List<T>) - Method in class org.apache.hadoop.examples.pi.math.Summation
Find the remaining terms.
run(String[]) - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe
Parse arguments and then runs a map/reduce job.
run(String[]) - Method in class org.apache.hadoop.examples.blocklocality.BlockLocality
 
run(String[]) - Method in class org.apache.hadoop.examples.dancing.DistributedPentomino
 
run(String[]) - Method in class org.apache.hadoop.examples.DBCountPageView
 
run(String[]) - Method in class org.apache.hadoop.examples.Grep
 
run(String[]) - Method in class org.apache.hadoop.examples.Join
The main driver for sort program.
run(String[]) - Method in class org.apache.hadoop.examples.MultiFileWordCount
 
run(String[]) - Method in class org.apache.hadoop.examples.pi.DistBbp
run(String[]) - Method in class org.apache.hadoop.examples.pi.DistSum
run(String[]) - Method in class org.apache.hadoop.examples.QuasiMonteCarlo
Parse arguments and then runs a map/reduce job.
run(String[]) - Method in class org.apache.hadoop.examples.RandomTextWriter
This is the main routine for launching a distributed random write job.
run(String[]) - Method in class org.apache.hadoop.examples.RandomWriter
This is the main routine for launching a distributed random write job.
run(int, int, long, int, long, int) - Method in class org.apache.hadoop.examples.SleepJob
 
run(String[]) - Method in class org.apache.hadoop.examples.SleepJob
 
run(String[]) - Method in class org.apache.hadoop.examples.Sort
The main driver for sort program.
run(String[]) - Method in class org.apache.hadoop.examples.terasort.TeraChecksum
 
run(String[]) - Method in class org.apache.hadoop.examples.terasort.TeraGen
 
run(String[]) - Method in class org.apache.hadoop.examples.terasort.TeraGenWithCRC
 
run(String[]) - Method in class org.apache.hadoop.examples.terasort.TeraSort
 
run(String[]) - Method in class org.apache.hadoop.examples.terasort.TeraSortWithCRC
 
run(String[]) - Method in class org.apache.hadoop.examples.terasort.TeraValidate
 
run(String[]) - Method in class org.apache.hadoop.examples.terasort.TeraValidateRecords
 
run(String[]) - Method in class org.apache.hadoop.examples.terasort.TeraValidateWithCRC
 
run(String[]) - Method in class org.apache.hadoop.examples.WordMean
 
run(String[]) - Method in class org.apache.hadoop.examples.WordMedian
 
run(String[]) - Method in class org.apache.hadoop.examples.WordStandardDeviation
 

S

SecondarySort - Class in org.apache.hadoop.examples
This is an example Hadoop Map/Reduce application.
SecondarySort() - Constructor for class org.apache.hadoop.examples.SecondarySort
 
SecondarySort.FirstGroupingComparator - Class in org.apache.hadoop.examples
Compare only the first part of the pair, so that reduce is called once for each value of the first part.
SecondarySort.FirstGroupingComparator() - Constructor for class org.apache.hadoop.examples.SecondarySort.FirstGroupingComparator
 
SecondarySort.FirstPartitioner - Class in org.apache.hadoop.examples
Partition based on the first part of the pair.
SecondarySort.FirstPartitioner() - Constructor for class org.apache.hadoop.examples.SecondarySort.FirstPartitioner
 
SecondarySort.IntPair - Class in org.apache.hadoop.examples
Define a pair of integers that are writable.
SecondarySort.IntPair() - Constructor for class org.apache.hadoop.examples.SecondarySort.IntPair
 
SecondarySort.IntPair.Comparator - Class in org.apache.hadoop.examples
A Comparator that compares serialized IntPair.
SecondarySort.IntPair.Comparator() - Constructor for class org.apache.hadoop.examples.SecondarySort.IntPair.Comparator
 
SecondarySort.MapClass - Class in org.apache.hadoop.examples
Read two integers from each line and generate a key, value pair as ((left, right), right).
SecondarySort.MapClass() - Constructor for class org.apache.hadoop.examples.SecondarySort.MapClass
 
SecondarySort.Reduce - Class in org.apache.hadoop.examples
A reducer class that just emits the sum of the input values.
SecondarySort.Reduce() - Constructor for class org.apache.hadoop.examples.SecondarySort.Reduce
 
set(int, int) - Method in class org.apache.hadoop.examples.SecondarySort.IntPair
Set the left and right values.
setConf(Configuration) - Method in class org.apache.hadoop.examples.terasort.TeraSort.SimplePartitioner
 
setFinalSync(JobConf, boolean) - Static method in class org.apache.hadoop.examples.blocklocality.LocalityOutputFormat
Set the requirement for a final sync before the stream is closed.
setFinalSync(JobContext, boolean) - Static method in class org.apache.hadoop.examples.terasort.TeraOutputFormatWithCRC
Set the requirement for a final sync before the stream is closed.
setOutputReplication(Job, int) - Static method in class org.apache.hadoop.examples.terasort.TeraSort
 
setPrinter(DancingLinks.SolutionAcceptor<Pentomino.ColumnName>) - Method in class org.apache.hadoop.examples.dancing.Pentomino
Set the printer for the puzzle.
setup(Mapper<WritableComparable<?>, Text, Text, Text>.Context) - Method in class org.apache.hadoop.examples.dancing.DistributedPentomino.PentMap
 
setupJobConf(int, int, long, int, long, int) - Method in class org.apache.hadoop.examples.SleepJob
 
setUseSimplePartitioner(Job, boolean) - Static method in class org.apache.hadoop.examples.terasort.TeraSort
 
setValue(Summation) - Method in class org.apache.hadoop.examples.pi.math.Bellard.Sum
Set the value of sigma
setValue(double) - Method in class org.apache.hadoop.examples.pi.math.Summation
Set the value of this summation
SleepJob - Class in org.apache.hadoop.examples
Dummy class for testing MR framefork.
SleepJob() - Constructor for class org.apache.hadoop.examples.SleepJob
 
SleepJob.EmptySplit - Class in org.apache.hadoop.examples
 
SleepJob.EmptySplit() - Constructor for class org.apache.hadoop.examples.SleepJob.EmptySplit
 
SleepJob.SleepInputFormat - Class in org.apache.hadoop.examples
 
SleepJob.SleepInputFormat() - Constructor for class org.apache.hadoop.examples.SleepJob.SleepInputFormat
 
solution(List<List<ColumnName>>) - Method in interface org.apache.hadoop.examples.dancing.DancingLinks.SolutionAcceptor
A callback to return a solution to the application.
solve(int[], DancingLinks.SolutionAcceptor<ColumnName>) - Method in class org.apache.hadoop.examples.dancing.DancingLinks
Given a prefix, find solutions under it.
solve(DancingLinks.SolutionAcceptor<ColumnName>) - Method in class org.apache.hadoop.examples.dancing.DancingLinks
Solve a complete problem
solve(int[]) - Method in class org.apache.hadoop.examples.dancing.Pentomino
Find all of the solutions that start with the given prefix.
solve() - Method in class org.apache.hadoop.examples.dancing.Pentomino
Find all of the solutions to the puzzle.
solve() - Method in class org.apache.hadoop.examples.dancing.Sudoku
 
Sort<K,V> - Class in org.apache.hadoop.examples
This is the trivial map/reduce program that does absolutely nothing other than use the framework to fragment and sort the input values.
Sort() - Constructor for class org.apache.hadoop.examples.Sort
 
split(int) - Method in class org.apache.hadoop.examples.dancing.DancingLinks
Generate a list of row choices to cover the first moves.
string2long(String) - Static method in class org.apache.hadoop.examples.pi.Util
Covert a String to a long.
string2TaskResult(String) - Static method in class org.apache.hadoop.examples.pi.DistSum
Convert a String to a (String, TaskResult) pair
stringifySolution(int, int, List<List<Pentomino.ColumnName>>) - Static method in class org.apache.hadoop.examples.dancing.Pentomino
Convert a solution to the puzzle returned by the model into a string that represents the placement of the pieces onto the board.
Sudoku - Class in org.apache.hadoop.examples.dancing
This class uses the dancing links algorithm from Knuth to solve sudoku puzzles.
Sudoku(InputStream) - Constructor for class org.apache.hadoop.examples.dancing.Sudoku
Set up a puzzle board to the given size.
Sudoku.ColumnName - Interface in org.apache.hadoop.examples.dancing
This interface is a marker class for the columns created for the Sudoku solver.
Summation - Class in org.apache.hadoop.examples.pi.math
Represent the summation \sum \frac{2^e \mod n}{n}.
Summation(ArithmeticProgression, ArithmeticProgression) - Constructor for class org.apache.hadoop.examples.pi.math.Summation
Constructor
SummationWritable - Class in org.apache.hadoop.examples.pi
A Writable class for Summation
SummationWritable() - Constructor for class org.apache.hadoop.examples.pi.SummationWritable
 
symbol - Variable in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
A symbol

T

TaskResult - Class in org.apache.hadoop.examples.pi
A class for map task results or reduce task results.
TaskResult() - Constructor for class org.apache.hadoop.examples.pi.TaskResult
 
taskResult2string(String, TaskResult) - Static method in class org.apache.hadoop.examples.pi.DistSum
Convert a TaskResult to a String
TeraChecksum - Class in org.apache.hadoop.examples.terasort
 
TeraChecksum() - Constructor for class org.apache.hadoop.examples.terasort.TeraChecksum
 
TeraGen - Class in org.apache.hadoop.examples.terasort
Generate the official GraySort input data set.
TeraGen() - Constructor for class org.apache.hadoop.examples.terasort.TeraGen
 
TeraGen.Counters - Enum in org.apache.hadoop.examples.terasort
 
TeraGen.SortGenMapper - Class in org.apache.hadoop.examples.terasort
The Mapper class that given a row number, will generate the appropriate output line.
TeraGen.SortGenMapper() - Constructor for class org.apache.hadoop.examples.terasort.TeraGen.SortGenMapper
 
TeraGenWithCRC - Class in org.apache.hadoop.examples.terasort
Generate the official terasort input data set.
TeraGenWithCRC() - Constructor for class org.apache.hadoop.examples.terasort.TeraGenWithCRC
 
TeraGenWithCRC.SortGenMapper - Class in org.apache.hadoop.examples.terasort
The Mapper class that given a row number, will generate the appropriate output line.
TeraGenWithCRC.SortGenMapper() - Constructor for class org.apache.hadoop.examples.terasort.TeraGenWithCRC.SortGenMapper
 
TeraInputFormat - Class in org.apache.hadoop.examples.terasort
An input format that reads the first 10 characters of each line as the key and the rest of the line as the value.
TeraInputFormat() - Constructor for class org.apache.hadoop.examples.terasort.TeraInputFormat
 
TeraInputFormatWithCRC - Class in org.apache.hadoop.examples.terasort
An input format that reads the first 10 characters of each line as the key and the rest of the line as the value.
TeraInputFormatWithCRC() - Constructor for class org.apache.hadoop.examples.terasort.TeraInputFormatWithCRC
 
TeraOutputFormat - Class in org.apache.hadoop.examples.terasort
An output format that writes the key and value appended together.
TeraOutputFormat() - Constructor for class org.apache.hadoop.examples.terasort.TeraOutputFormat
 
TeraOutputFormatWithCRC - Class in org.apache.hadoop.examples.terasort
A streamlined text output format that writes key, value, and "\r\n".
TeraOutputFormatWithCRC() - Constructor for class org.apache.hadoop.examples.terasort.TeraOutputFormatWithCRC
 
TeraSort - Class in org.apache.hadoop.examples.terasort
Generates the sampled split points, launches the job, and waits for it to finish.
TeraSort() - Constructor for class org.apache.hadoop.examples.terasort.TeraSort
 
TeraSort.SimplePartitioner - Class in org.apache.hadoop.examples.terasort
A total order partitioner that assigns keys based on their first PREFIX_LENGTH bytes, assuming a flat distribution.
TeraSort.SimplePartitioner() - Constructor for class org.apache.hadoop.examples.terasort.TeraSort.SimplePartitioner
 
TeraSortWithCRC - Class in org.apache.hadoop.examples.terasort
Generates the sampled split points, launches the job, and waits for it to finish.
TeraSortWithCRC() - Constructor for class org.apache.hadoop.examples.terasort.TeraSortWithCRC
 
TeraValidate - Class in org.apache.hadoop.examples.terasort
Generate 1 mapper per a file that checks to make sure the keys are sorted within each file.
TeraValidate() - Constructor for class org.apache.hadoop.examples.terasort.TeraValidate
 
TeraValidateRecords - Class in org.apache.hadoop.examples.terasort
 
TeraValidateRecords() - Constructor for class org.apache.hadoop.examples.terasort.TeraValidateRecords
 
TeraValidateWithCRC - Class in org.apache.hadoop.examples.terasort
Generate 1 mapper per a file that checks to make sure the keys are sorted within each file.
TeraValidateWithCRC() - Constructor for class org.apache.hadoop.examples.terasort.TeraValidateWithCRC
 
tick() - Method in class org.apache.hadoop.examples.pi.Util.Timer
Same as tick(null).
tick(String) - Method in class org.apache.hadoop.examples.pi.Util.Timer
Tick
toString() - Method in class org.apache.hadoop.examples.pi.DistSum.Machine
toString() - Method in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
toString() - Method in class org.apache.hadoop.examples.pi.math.Bellard.Sum
toString() - Method in class org.apache.hadoop.examples.pi.math.Summation
toString() - Method in class org.apache.hadoop.examples.pi.SummationWritable
toString() - Method in class org.apache.hadoop.examples.pi.TaskResult
TOTAL_BYTES - Static variable in class org.apache.hadoop.examples.RandomTextWriter
 
TOTAL_BYTES - Static variable in class org.apache.hadoop.examples.RandomWriter
 
twoRotations - Static variable in class org.apache.hadoop.examples.dancing.Pentomino
Is the piece identical if rotated 180 degrees?

U

Util - Class in org.apache.hadoop.examples.pi
Utility methods
Util() - Constructor for class org.apache.hadoop.examples.pi.Util
 
Util.Timer - Class in org.apache.hadoop.examples.pi
Timer
Util.Timer(boolean) - Constructor for class org.apache.hadoop.examples.pi.Util.Timer
Timer constructor

V

value - Variable in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
Starting value
valueOf(String) - Static method in enum org.apache.hadoop.examples.dancing.Pentomino.SolutionCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.examples.pi.math.Bellard.Parameter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.apache.hadoop.examples.pi.math.Summation
Covert a String to a Summation.
valueOf(String) - Static method in class org.apache.hadoop.examples.pi.TaskResult
Covert a String to a TaskResult
valueOf(String) - Static method in enum org.apache.hadoop.examples.terasort.TeraGen.Counters
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.hadoop.examples.dancing.Pentomino.SolutionCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.examples.pi.math.Bellard.Parameter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.examples.terasort.TeraGen.Counters
Returns an array containing the constants of this enum type, in the order they are declared.

W

WIDTH - Static variable in class org.apache.hadoop.examples.dancing.Pentomino
 
width - Variable in class org.apache.hadoop.examples.dancing.Pentomino
 
WordCount - Class in org.apache.hadoop.examples
 
WordCount() - Constructor for class org.apache.hadoop.examples.WordCount
 
WordCount.IntSumReducer - Class in org.apache.hadoop.examples
 
WordCount.IntSumReducer() - Constructor for class org.apache.hadoop.examples.WordCount.IntSumReducer
 
WordCount.TokenizerMapper - Class in org.apache.hadoop.examples
 
WordCount.TokenizerMapper() - Constructor for class org.apache.hadoop.examples.WordCount.TokenizerMapper
 
WordMean - Class in org.apache.hadoop.examples
 
WordMean() - Constructor for class org.apache.hadoop.examples.WordMean
 
WordMean.WordMeanMapper - Class in org.apache.hadoop.examples
Maps words from line of text into 2 key-value pairs; one key-value pair for counting the word, another for counting its length.
WordMean.WordMeanMapper() - Constructor for class org.apache.hadoop.examples.WordMean.WordMeanMapper
 
WordMean.WordMeanReducer - Class in org.apache.hadoop.examples
Performs integer summation of all the values for each key.
WordMean.WordMeanReducer() - Constructor for class org.apache.hadoop.examples.WordMean.WordMeanReducer
 
WordMedian - Class in org.apache.hadoop.examples
 
WordMedian() - Constructor for class org.apache.hadoop.examples.WordMedian
 
WordMedian.WordMedianMapper - Class in org.apache.hadoop.examples
Maps words from line of text into a key-value pair; the length of the word as the key, and 1 as the value.
WordMedian.WordMedianMapper() - Constructor for class org.apache.hadoop.examples.WordMedian.WordMedianMapper
 
WordMedian.WordMedianReducer - Class in org.apache.hadoop.examples
Performs integer summation of all the values for each key.
WordMedian.WordMedianReducer() - Constructor for class org.apache.hadoop.examples.WordMedian.WordMedianReducer
 
WordStandardDeviation - Class in org.apache.hadoop.examples
 
WordStandardDeviation() - Constructor for class org.apache.hadoop.examples.WordStandardDeviation
 
WordStandardDeviation.WordStandardDeviationMapper - Class in org.apache.hadoop.examples
Maps words from line of text into 3 key-value pairs; one key-value pair for counting the word, one for counting its length, and one for counting the square of its length.
WordStandardDeviation.WordStandardDeviationMapper() - Constructor for class org.apache.hadoop.examples.WordStandardDeviation.WordStandardDeviationMapper
 
WordStandardDeviation.WordStandardDeviationReducer - Class in org.apache.hadoop.examples
Performs integer summation of all the values for each key.
WordStandardDeviation.WordStandardDeviationReducer() - Constructor for class org.apache.hadoop.examples.WordStandardDeviation.WordStandardDeviationReducer
 
write(DataOutput) - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpSplit
write(DataOutput) - Method in class org.apache.hadoop.examples.MultiFileWordCount.WordOffset
 
write(DataOutput) - Method in class org.apache.hadoop.examples.pi.DistSum.Machine.SummationSplit
write(Summation, Class<?>, Configuration) - Static method in class org.apache.hadoop.examples.pi.SummationWritable
Write sigma to conf
write(Summation, DataOutput) - Static method in class org.apache.hadoop.examples.pi.SummationWritable
Write sigma to DataOutput
write(DataOutput) - Method in class org.apache.hadoop.examples.pi.SummationWritable
write(DataOutput) - Method in class org.apache.hadoop.examples.pi.TaskResult
write(DataOutput) - Method in class org.apache.hadoop.examples.SecondarySort.IntPair
 
write(DataOutput) - Method in class org.apache.hadoop.examples.SleepJob.EmptySplit
 
writePartitionFile(JobContext, Path) - Static method in class org.apache.hadoop.examples.terasort.TeraInputFormat
Use the input splits to take samples of the input and generate sample keys.
writePartitionFile(JobContext, Path) - Static method in class org.apache.hadoop.examples.terasort.TeraInputFormatWithCRC
Use the input splits to take samples of the input and generate sample keys.
A B C D E F G H I J L M N O P Q R S T U V W 

Copyright © 2017 Apache Software Foundation. All Rights Reserved.