- 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
-
- 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
-
- 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
-
- 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
-
- 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
- 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?