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

A

abort() - Method in class org.apache.hadoop.mapred.gridmix.Statistics
 
abortJob(JobContext, int) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
abortJob(JobContext, int) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. For aborting an unsuccessful job's output.
abortJob(JobContext, JobStatus.State) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. This method implements the new interface by calling the old method.
abortJob(JobContext, JobStatus.State) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Delete the temporary directory, including all of the work directories.
abortJob(JobContext, JobStatus.State) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
For aborting an unsuccessful job's output.
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. Discard the task output
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. This method implements the new interface by calling the old method.
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Delete the work directory
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
Discard the task output
AbstractClusterStory - Class in org.apache.hadoop.tools.rumen
AbstractClusterStory provides a partial implementation of ClusterStory by parsing the topology tree.
AbstractClusterStory() - Constructor for class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
accept(CompositeRecordReader.JoinCollector, K) - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
Deprecated. While key-value pairs from this RecordReader match the given key, register them with the JoinCollector provided.
accept(CompositeRecordReader.JoinCollector, K) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. If key provided matches that of this Composite, give JoinCollector iterator over values it may emit.
accept(CompositeRecordReader.JoinCollector, K) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Add an iterator to the collector at the position occupied by this RecordReader over the values in this stream paired with the key provided (ie register a stream of values from this source matching K with a collector).
accept(Path) - Method in class org.apache.hadoop.mapred.OutputLogFilter
Deprecated.  
accept(Object) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.MD5Filter
Deprecated. Filtering method If MD5(key) % frequency==0, return true; otherwise return false
accept(Object) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.PercentFilter
Deprecated. Filtering method If record# % frequency==0, return true; otherwise return false
accept(Object) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.RegexFilter
Deprecated. Filtering method If key matches the regex, return true; otherwise return false
accept(Path) - Method in class org.apache.hadoop.mapred.Utils.OutputFileUtils.OutputFilesFilter
 
accept(Path) - Method in class org.apache.hadoop.mapred.Utils.OutputFileUtils.OutputLogFilter
 
accept(Object) - Method in interface org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.Filter
filter function Decide if a record should be filtered or not
accept(Object) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.MD5Filter
Filtering method If MD5(key) % frequency==0, return true; otherwise return false
accept(Object) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.PercentFilter
Filtering method If record# % frequency==0, return true; otherwise return false
accept(Object) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.RegexFilter
Filtering method If key matches the regex, return true; otherwise return false
accept(CompositeRecordReader.JoinCollector, K) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
If key provided matches that of this Composite, give JoinCollector iterator over values it may emit.
accept(CompositeRecordReader.JoinCollector, K) - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Add an iterator to the collector at the position occupied by this RecordReader over the values in this stream paired with the key provided (ie register a stream of values from this source matching K with a collector).
accuracy(long, boolean) - Static method in class org.apache.hadoop.examples.pi.Util
Estimate accuracy.
activateOptions() - Method in class org.apache.hadoop.mapred.TaskLogAppender
 
add(Object) - Method in class org.apache.hadoop.contrib.utils.join.ArrayListBackedIterator
 
add(Object) - Method in interface org.apache.hadoop.contrib.utils.join.ResetableIterator
 
add(Job) - Method in class org.apache.hadoop.mapred.gridmix.Statistics
Used by JobMonitor to add the completed job.
add(InputSplit) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Deprecated. Add an InputSplit to this collection.
add(ComposableRecordReader<K, ? extends V>) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Add a RecordReader to this collection.
add(TupleWritable) - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
Deprecated.  
add(V) - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
Deprecated.  
add(X) - Method in class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
 
add(InputSplit) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
Add an InputSplit to this collection.
add(ComposableRecordReader<K, ? extends V>) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Add a RecordReader to this collection.
add(int, ResetableIterator<X>) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader.JoinCollector
Register a given iterator at position id.
add(TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader.JoinDelegationIterator
 
add(V) - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
add(T) - Method in interface org.apache.hadoop.mapreduce.lib.join.ResetableIterator
Add an element to the collection of elements to iterate over.
add(U) - Method in class org.apache.hadoop.mapreduce.lib.join.ResetableIterator.EMPTY
 
add(X) - Method in class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
 
addArchiveToClassPath(Path) - Method in class org.apache.hadoop.mapreduce.Job
Add an archive path to the current set of classpath entries.
addCacheArchive(URI) - Method in class org.apache.hadoop.mapreduce.Job
Add a archives to be localized
addCacheFile(URI) - Method in class org.apache.hadoop.mapreduce.Job
Add a file to be localized
addChild(Node) - Method in class org.apache.hadoop.tools.rumen.MachineNode
 
addChild(Node) - Method in class org.apache.hadoop.tools.rumen.Node
Add a child node to this node.
addChild(Node) - Method in class org.apache.hadoop.tools.rumen.RackNode
 
addClusterStatsObservers(StatListener<Statistics.ClusterStats>) - Method in class org.apache.hadoop.mapred.gridmix.Statistics
 
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
addCounter(Counter) - Method in class org.apache.hadoop.mapreduce.CounterGroup
Add a counter to this group.
addDefaults() - Method in class org.apache.hadoop.mapred.join.CompositeInputFormat
Deprecated. Adds the default set of identifiers to the parser.
addDefaults() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
Adds the default set of identifiers to the parser.
addDependingJob(ControlledJob) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Add a job to this jobs' dependency list.
addDoubleValue(Object, double) - Method in class org.apache.hadoop.contrib.utils.join.JobBase
Increment the given counter by the given incremental value If the counter does not exist, one is created with value 0.
addFileToClassPath(Path) - Method in class org.apache.hadoop.mapreduce.Job
Add an file path to the current set of classpath entries It adds the file to cache as well.
addGroup(CounterGroup) - Method in class org.apache.hadoop.mapreduce.Counters
Add a group.
addIdentifier(String, Class<?>[], Class<? extends Parser.Node>, Class<? extends ComposableRecordReader>) - Static method in class org.apache.hadoop.mapred.join.Parser.Node
Deprecated. For a given identifier, add a mapping to the nodetype for the parse tree and to the ComposableRecordReader to be created, including the formals required to invoke the constructor.
addIdentifier(String, Class<?>[], Class<? extends Parser.Node>, Class<? extends ComposableRecordReader>) - Static method in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
For a given identifier, add a mapping to the nodetype for the parse tree and to the ComposableRecordReader to be created, including the formals required to invoke the constructor.
addInputPath(JobConf, Path) - Static method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. Add a Path to the list of inputs for the map-reduce job.
addInputPath(JobConf, Path, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.mapred.lib.MultipleInputs
Deprecated. Add a Path with a custom InputFormat to the list of inputs for the map-reduce job.
addInputPath(JobConf, Path, Class<? extends InputFormat>, Class<? extends Mapper>) - Static method in class org.apache.hadoop.mapred.lib.MultipleInputs
Deprecated. Add a Path with a custom InputFormat and Mapper to the list of inputs for the map-reduce job.
addInputPath(Job, Path) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Add a Path to the list of inputs for the map-reduce job.
addInputPath(Job, Path, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.mapreduce.lib.input.MultipleInputs
Add a Path with a custom InputFormat to the list of inputs for the map-reduce job.
addInputPath(Job, Path, Class<? extends InputFormat>, Class<? extends Mapper>) - Static method in class org.apache.hadoop.mapreduce.lib.input.MultipleInputs
Add a Path with a custom InputFormat and Mapper to the list of inputs for the map-reduce job.
addInputPathRecursively(List<FileStatus>, FileSystem, Path, PathFilter) - Method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. Add files in the input path recursively into the results.
addInputPaths(JobConf, String) - Static method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. Add the given comma separated paths to the list of inputs for the map-reduce job.
addInputPaths(Job, String) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Add the given comma separated paths to the list of inputs for the map-reduce job.
additionalConfSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
addJob(ControlledJob) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
Add a new job.
addJobCollection(Collection<ControlledJob>) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
Add a collection of jobs
addJobs(Collection<Job>) - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
Deprecated. Add a collection of jobs
addJobStats(Job, JobStory) - Method in class org.apache.hadoop.mapred.gridmix.Statistics
 
addJobStatsListeners(StatListener<Statistics.JobStats>) - Method in class org.apache.hadoop.mapred.gridmix.Statistics
 
addLongValue(Object, long) - Method in class org.apache.hadoop.contrib.utils.join.JobBase
Increment the given counter by the given incremental value If the counter does not exist, one is created with value 0.
addMapper(JobConf, Class<? extends Mapper<K1, V1, K2, V2>>, Class<? extends K1>, Class<? extends V1>, Class<? extends K2>, Class<? extends V2>, boolean, JobConf) - Static method in class org.apache.hadoop.mapred.lib.ChainMapper
Deprecated. Adds a Mapper class to the chain job's JobConf.
addMapper(JobConf, Class<? extends Mapper<K1, V1, K2, V2>>, Class<? extends K1>, Class<? extends V1>, Class<? extends K2>, Class<? extends V2>, boolean, JobConf) - Static method in class org.apache.hadoop.mapred.lib.ChainReducer
Deprecated. Adds a Mapper class to the chain job's JobConf.
addMapper(Job, Class<? extends Mapper>, Class<?>, Class<?>, Class<?>, Class<?>, Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.chain.ChainMapper
Adds a Mapper class to the chain mapper.
addMapper(Job, Class<? extends Mapper>, Class<?>, Class<?>, Class<?>, Class<?>, Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.chain.ChainReducer
Adds a Mapper class to the chain reducer.
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.
addMultiNamedOutput(JobConf, String, Class<? extends OutputFormat>, Class<?>, Class<?>) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Adds a multi named output for the job.
addNamedOutput(JobConf, String, Class<? extends OutputFormat>, Class<?>, Class<?>) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Adds a named output for the job.
addNamedOutput(Job, String, Class<? extends OutputFormat>, Class<?>, Class<?>) - Static method in class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
Adds a named output for the job.
addNextValue(Object) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.DoubleValueSum
add a value to the aggregator
addNextValue(double) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.DoubleValueSum
add a value to the aggregator
addNextValue(Object) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMax
add a value to the aggregator
addNextValue(long) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMax
add a value to the aggregator
addNextValue(Object) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMin
add a value to the aggregator
addNextValue(long) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMin
add a value to the aggregator
addNextValue(Object) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueSum
add a value to the aggregator
addNextValue(long) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueSum
add a value to the aggregator
addNextValue(Object) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMax
add a value to the aggregator
addNextValue(Object) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMin
add a value to the aggregator
addNextValue(Object) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
add a value to the aggregator
addNextValue(Object) - Method in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregator
add a value to the aggregator
addNextValue(Object) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueHistogram
add the given val to the aggregator.
addRow(boolean[]) - Method in class org.apache.hadoop.examples.dancing.DancingLinks
Add a row to the table.
addTaskEnvironment_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
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
 
aggregatorDescriptorList - Variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
Deprecated.  
aggregatorDescriptorList - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
allFinished() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
append(LoggingEvent) - Method in class org.apache.hadoop.mapred.TaskLogAppender
 
appendTo(StringBuilder) - Method in class org.apache.hadoop.mapreduce.JobID
Add the stuff after the "job" prefix to the given builder.
appendTo(StringBuilder) - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
Add the unique string to the StringBuilder
appendTo(StringBuilder) - Method in class org.apache.hadoop.mapreduce.TaskID
Add the unique string to the given builder.
archiveURIs - Variable in class org.apache.hadoop.streaming.StreamJob
 
argv_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
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
ArrayListBackedIterator - Class in org.apache.hadoop.contrib.utils.join
This class provides an implementation of ResetableIterator.
ArrayListBackedIterator() - Constructor for class org.apache.hadoop.contrib.utils.join.ArrayListBackedIterator
 
ArrayListBackedIterator(ArrayList<Object>) - Constructor for class org.apache.hadoop.contrib.utils.join.ArrayListBackedIterator
 
ArrayListBackedIterator<X extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.join
Deprecated. Use ArrayListBackedIterator instead
ArrayListBackedIterator() - Constructor for class org.apache.hadoop.mapred.join.ArrayListBackedIterator
Deprecated.  
ArrayListBackedIterator(ArrayList<X>) - Constructor for class org.apache.hadoop.mapred.join.ArrayListBackedIterator
Deprecated.  
ArrayListBackedIterator<X extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.join
This class provides an implementation of ResetableIterator.
ArrayListBackedIterator() - Constructor for class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
 
ArrayListBackedIterator(ArrayList<X>) - Constructor for class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
 
ATTEMPT - Static variable in class org.apache.hadoop.mapreduce.TaskAttemptID
 
AutoInputFormat - Class in org.apache.hadoop.streaming
An InputFormat that tries to deduce the types of the input files automatically.
AutoInputFormat() - Constructor for class org.apache.hadoop.streaming.AutoInputFormat
 
available() - Method in class org.apache.hadoop.mapred.TaskLog.Reader
 

B

background_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
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
Input split for the BaileyBorweinPlouffe.BbpInputFormat.
BaileyBorweinPlouffe.BbpSplit() - Constructor for class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpSplit
Public default constructor for the Writable interface.
BalancedReducePartitioning - Class in org.apache.hadoop.vaidya.postexdiagnosis.tests
 
BalancedReducePartitioning() - Constructor for class org.apache.hadoop.vaidya.postexdiagnosis.tests.BalancedReducePartitioning
 
BASE_OUTPUT_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
baseOut - Variable in class org.apache.hadoop.mapred.lib.FilterOutputFormat
Deprecated.  
baseOut - Variable in class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat
 
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
BigDecimalSplitter - Class in org.apache.hadoop.mapreduce.lib.db
Implement DBSplitter over BigDecimal values.
BigDecimalSplitter() - Constructor for class org.apache.hadoop.mapreduce.lib.db.BigDecimalSplitter
 
BinaryPartitioner<V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use BinaryPartitioner instead.
BinaryPartitioner() - Constructor for class org.apache.hadoop.mapred.lib.BinaryPartitioner
Deprecated.  
BinaryPartitioner<V> - Class in org.apache.hadoop.mapreduce.lib.partition
Partition BinaryComparable keys using a configurable part of the bytes array returned by BinaryComparable.getBytes().
BinaryPartitioner() - Constructor for class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
 
bindTo(Path, Configuration) - Method in class org.apache.hadoop.tools.rumen.DefaultInputDemuxer
 
bindTo(Path, Configuration) - Method in interface org.apache.hadoop.tools.rumen.InputDemuxer
Bind the InputDemuxer to a particular file.
bit2terms(long) - Static method in class org.apache.hadoop.examples.pi.math.Bellard
Estimate the number of terms.
BooleanSplitter - Class in org.apache.hadoop.mapreduce.lib.db
Implement DBSplitter over boolean values.
BooleanSplitter() - Constructor for class org.apache.hadoop.mapreduce.lib.db.BooleanSplitter
 
build() - Method in class org.apache.hadoop.tools.rumen.JobBuilder
Request the builder to build the final object.
build() - Method in class org.apache.hadoop.tools.rumen.MachineNode.Builder
Build the MachineNode object.
build() - Method in class org.apache.hadoop.tools.rumen.TopologyBuilder
Request the builder to build the final object.
buildMachineNodeMap() - Method in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
buildRackNodeMap() - Method in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
BYTES_PER_MAP - Static variable in class org.apache.hadoop.examples.RandomTextWriter
 
BYTES_PER_MAP - Static variable in class org.apache.hadoop.examples.RandomWriter
 
BYTES_READ - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 

C

cacheArchives - Variable in class org.apache.hadoop.streaming.StreamJob
 
cacheFiles - Variable in class org.apache.hadoop.streaming.StreamJob
 
call() - Method in class org.apache.hadoop.mapred.gridmix.SleepJob
 
cancelDelegationToken(Token<DelegationTokenIdentifier>) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Cancel a delegation token from the JobTracker
cancelDelegationToken(Token<DelegationTokenIdentifier>) - Method in class org.apache.hadoop.mapreduce.Cluster
Cancel a delegation token from the JobTracker
canParse(InputStream) - Static method in class org.apache.hadoop.tools.rumen.CurrentJHParser
Can this parser parse the input?
canParse(InputStream) - Static method in class org.apache.hadoop.tools.rumen.Hadoop20JHParser
Can this parser parse the input?
CDFPiecewiseLinearRandomGenerator - Class in org.apache.hadoop.tools.rumen
 
CDFPiecewiseLinearRandomGenerator(LoggedDiscreteCDF) - Constructor for class org.apache.hadoop.tools.rumen.CDFPiecewiseLinearRandomGenerator
 
CDFPiecewiseLinearRandomGenerator(LoggedDiscreteCDF, long) - Constructor for class org.apache.hadoop.tools.rumen.CDFPiecewiseLinearRandomGenerator
 
CDFRandomGenerator - Class in org.apache.hadoop.tools.rumen
An instance of this class generates random values that confirm to the embedded LoggedDiscreteCDF .
ChainMapper - Class in org.apache.hadoop.mapred.lib
Deprecated. Use ChainMapper instead
ChainMapper() - Constructor for class org.apache.hadoop.mapred.lib.ChainMapper
Deprecated. Constructor.
ChainMapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce.lib.chain
The ChainMapper class allows to use multiple Mapper classes within a single Map task.
ChainMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.chain.ChainMapper
 
ChainReducer - Class in org.apache.hadoop.mapred.lib
Deprecated. Use ChainReducer instead
ChainReducer() - Constructor for class org.apache.hadoop.mapred.lib.ChainReducer
Deprecated. Constructor.
ChainReducer<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce.lib.chain
The ChainReducer class allows to chain multiple Mapper classes after a Reducer within the Reducer task.
ChainReducer() - Constructor for class org.apache.hadoop.mapreduce.lib.chain.ChainReducer
 
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
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.mapred.FileOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.mapred.lib.db.DBOutputFormat
Deprecated. Check for validity of the output-specification for the job.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.mapred.lib.FilterOutputFormat
Deprecated.  
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.mapred.lib.LazyOutputFormat
Deprecated.  
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.mapred.lib.NullOutputFormat
Deprecated.  
checkOutputSpecs(FileSystem, JobConf) - Method in interface org.apache.hadoop.mapred.OutputFormat
Deprecated. Check for validity of the output-specification for the job.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
Deprecated.  
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.output.LazyOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.output.NullOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.mapreduce.OutputFormat
Check for validity of the output-specification for the job.
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.vertica.VerticaOutputFormat
Check for validity of the output-specification for the job.
checkOutputSpecs(JobContext, boolean) - Method in class org.apache.hadoop.vertica.VerticaOutputFormat
Test check specs (don't connect to db)
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.vertica.VerticaStreamingOutput
 
checkOutputSpecs(Configuration) - Static method in class org.apache.hadoop.vertica.VerticaUtil
 
chooseShardForDelete(DocumentID) - Method in class org.apache.hadoop.contrib.index.example.HashingDistributionPolicy
 
chooseShardForDelete(DocumentID) - Method in class org.apache.hadoop.contrib.index.example.RoundRobinDistributionPolicy
 
chooseShardForDelete(DocumentID) - Method in interface org.apache.hadoop.contrib.index.mapred.IDistributionPolicy
Choose a shard or all shards to send a delete request.
chooseShardForInsert(DocumentID) - Method in class org.apache.hadoop.contrib.index.example.HashingDistributionPolicy
 
chooseShardForInsert(DocumentID) - Method in class org.apache.hadoop.contrib.index.example.RoundRobinDistributionPolicy
 
chooseShardForInsert(DocumentID) - Method in interface org.apache.hadoop.contrib.index.mapred.IDistributionPolicy
Choose a shard to send an insert request.
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, LongWritable, GridmixKey, NullWritable>.Context) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepMapper
 
cleanup(Reducer<GridmixKey, NullWritable, NullWritable, NullWritable>.Context) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepReducer
 
cleanup(Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Mapper
Called once at the end of the task.
cleanup(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Reducer
Called once at the end of the task.
cleanupJob(JobContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
Deprecated. 
cleanupJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. Use OutputCommitter.commitJob(JobContext) or OutputCommitter.abortJob(JobContext, int) instead.
cleanupJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. Use OutputCommitter.commitJob(org.apache.hadoop.mapreduce.JobContext) or OutputCommitter.abortJob(org.apache.hadoop.mapreduce.JobContext, org.apache.hadoop.mapreduce.JobStatus.State) instead.
cleanupJob(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Deprecated. 
cleanupJob(JobContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
Deprecated. Use OutputCommitter.commitJob(JobContext) or OutputCommitter.abortJob(JobContext, JobStatus.State) instead.
cleanupProgress() - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
cleanupProgress() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Get the progress of the job's cleanup-tasks, as a float between 0.0 and 1.0.
cleanupProgress() - Method in class org.apache.hadoop.mapreduce.Job
Get the progress of the job's cleanup-tasks, as a float between 0.0 and 1.0.
clear() - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
Deprecated.  
clear() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
Deprecated.  
clear() - Method in class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
 
clear() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader.JoinCollector
Clear all state information.
clear() - Method in class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader.JoinDelegationIterator
 
clear() - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
clear() - Method in interface org.apache.hadoop.mapreduce.lib.join.ResetableIterator
Close datasources, but do not release internal resources.
clear() - Method in class org.apache.hadoop.mapreduce.lib.join.ResetableIterator.EMPTY
 
clear() - Method in class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
 
clearMark() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
 
clearMark() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterator
 
CLI - Class in org.apache.hadoop.mapreduce.tools
Interprets the map reduce cli options
CLI() - Constructor for class org.apache.hadoop.mapreduce.tools.CLI
 
CLI(Configuration) - Constructor for class org.apache.hadoop.mapreduce.tools.CLI
 
clone(JobConf) - Method in class org.apache.hadoop.contrib.utils.join.TaggedMapOutput
 
clone() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
cloneContext(JobContext, Configuration) - Static method in class org.apache.hadoop.mapreduce.ContextFactory
Clone a job or task attempt context with a new configuration.
cloneFrom(MachineNode) - Method in class org.apache.hadoop.tools.rumen.MachineNode.Builder
Clone the settings from a reference MachineNode object.
cloneMapContext(MapContext<K1, V1, K2, V2>, Configuration, RecordReader<K1, V1>, RecordWriter<K2, V2>) - Static method in class org.apache.hadoop.mapreduce.ContextFactory
Copy a mapper context, optionally replacing the input and output.
close() - Method in class org.apache.hadoop.contrib.index.example.IdentityLocalAnalysis
 
close() - Method in class org.apache.hadoop.contrib.index.example.LineDocLocalAnalysis
 
close() - Method in class org.apache.hadoop.contrib.index.example.LineDocRecordReader
 
close() - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
close() - Method in class org.apache.hadoop.contrib.index.lucene.ShardWriter
Close the shard writer.
close() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateCombiner
 
close() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateMapper
 
close() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateReducer
 
close() - Method in class org.apache.hadoop.contrib.utils.join.ArrayListBackedIterator
 
close() - Method in class org.apache.hadoop.contrib.utils.join.DataJoinMapperBase
 
close() - Method in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
close() - Method in interface org.apache.hadoop.contrib.utils.join.ResetableIterator
 
close() - Method in class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
close() - Method in class org.apache.hadoop.fs.HarFileSystem
 
close() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Close the JobClient.
close() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Close all child RRs.
close() - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
Deprecated.  
close() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
Deprecated.  
close() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Forward close request to proxied RR.
close() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
Deprecated.  
close() - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Deprecated. Do nothing.
close() - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
Deprecated.  
close() - Method in class org.apache.hadoop.mapred.lib.ChainMapper
Deprecated. Closes the ChainMapper and all the Mappers in the chain.
close() - Method in class org.apache.hadoop.mapred.lib.ChainReducer
Deprecated. Closes the ChainReducer, the Reducer and all the Mappers in the chain.
close() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
close(Reporter) - Method in class org.apache.hadoop.mapred.lib.db.DBOutputFormat.DBRecordWriter
Deprecated. Close this RecordWriter to future operations.
close() - Method in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
Deprecated.  
close(Reporter) - Method in class org.apache.hadoop.mapred.lib.FilterOutputFormat.FilterRecordWriter
Deprecated.  
close() - Method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Closes all the opened named outputs.
close() - Method in class org.apache.hadoop.mapred.MapReduceBase
Deprecated. Default implementation that does nothing.
close() - Method in interface org.apache.hadoop.mapred.RecordReader
Close this InputSplit to future operations.
close(Reporter) - Method in interface org.apache.hadoop.mapred.RecordWriter
Close this RecordWriter to future operations.
close() - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Deprecated.  
close() - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
Deprecated.  
close() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
close() - Method in class org.apache.hadoop.mapred.TaskLog.Reader
 
close() - Method in class org.apache.hadoop.mapred.TaskLogAppender
 
close(Reporter) - Method in class org.apache.hadoop.mapred.TextOutputFormat.LineRecordWriter
Deprecated.  
close() - Method in class org.apache.hadoop.mapreduce.Cluster
Close the Cluster.
close(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat.DBRecordWriter
Close this RecordWriter to future operations.
close() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Close the record reader.
close() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
close() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
close() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
 
close() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextRecordReader
 
close() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
 
close() - Method in class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
 
close() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Close all child RRs.
close() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader.JoinCollector
Close all child iterators.
close() - Method in class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader.JoinDelegationIterator
 
close() - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
close() - Method in interface org.apache.hadoop.mapreduce.lib.join.ResetableIterator
Close datasources and release resources.
close() - Method in class org.apache.hadoop.mapreduce.lib.join.ResetableIterator.EMPTY
 
close() - Method in class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
 
close() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Forward close request to proxied RR.
close(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat.FilterRecordWriter
 
close() - Method in class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
Closes all the opened outputs.
close(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.TextOutputFormat.LineRecordWriter
 
close() - Method in class org.apache.hadoop.mapreduce.RecordReader
Close the record reader.
close(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.RecordWriter
Close this RecordWriter to future operations.
close() - Method in class org.apache.hadoop.streaming.PipeMapper
 
close() - Method in class org.apache.hadoop.streaming.PipeReducer
 
close() - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
Close this to future operations.
close() - Method in class org.apache.hadoop.tools.rumen.CurrentJHParser
 
close() - Method in class org.apache.hadoop.tools.rumen.DefaultInputDemuxer
 
close() - Method in class org.apache.hadoop.tools.rumen.DefaultOutputter
 
close() - Method in class org.apache.hadoop.tools.rumen.DeskewedJobTraceReader
 
close() - Method in class org.apache.hadoop.tools.rumen.Hadoop20JHParser
 
close() - Method in class org.apache.hadoop.tools.rumen.JsonObjectMapperWriter
 
close() - Method in class org.apache.hadoop.tools.rumen.RewindableInputStream
 
close() - Method in class org.apache.hadoop.tools.rumen.ZombieJobProducer
 
close() - Method in class org.apache.hadoop.vertica.VerticaInputSplit
(@inheritDoc)
close() - Method in class org.apache.hadoop.vertica.VerticaRecordReader
Close the record reader.
close(TaskAttemptContext) - Method in class org.apache.hadoop.vertica.VerticaRecordWriter
 
close() - Method in class org.apache.hadoop.vertica.VerticaStreamingRecordReader
Close the record reader.
close(TaskAttemptContext) - Method in class org.apache.hadoop.vertica.VerticaStreamingRecordWriter
 
closeConnection() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
closeWriter() - Method in class org.apache.hadoop.contrib.index.mapred.IntermediateForm
Close the Lucene index writer associated with the intermediate form, if created.
Cluster - Class in org.apache.hadoop.mapreduce
Provides a way to access information about the map/reduce cluster.
Cluster(Configuration) - Constructor for class org.apache.hadoop.mapreduce.Cluster
 
Cluster(InetSocketAddress, Configuration) - Constructor for class org.apache.hadoop.mapreduce.Cluster
 
Cluster.JobTrackerStatus - Enum in org.apache.hadoop.mapreduce
 
ClusterMetrics - Class in org.apache.hadoop.mapreduce
Status information on the current state of the Map-Reduce cluster.
ClusterMetrics() - Constructor for class org.apache.hadoop.mapreduce.ClusterMetrics
 
ClusterMetrics(int, int, int, int, int, int, int, int, int, int, int, int) - Constructor for class org.apache.hadoop.mapreduce.ClusterMetrics
 
ClusterStatus - Class in org.apache.hadoop.mapred
Deprecated. Use ClusterMetrics or TaskTrackerInfo instead
ClusterStatus.BlackListInfo - Class in org.apache.hadoop.mapred
Deprecated. Class which encapsulates information about a blacklisted tasktracker.
ClusterStory - Interface in org.apache.hadoop.tools.rumen
ClusterStory represents all configurations of a MapReduce cluster, including nodes, network topology, and slot configurations.
ClusterTopologyReader - Class in org.apache.hadoop.tools.rumen
Reading JSON-encoded cluster topology and produce the parsed LoggedNetworkTopology object.
ClusterTopologyReader(Path, Configuration) - Constructor for class org.apache.hadoop.tools.rumen.ClusterTopologyReader
Constructor.
ClusterTopologyReader(InputStream) - Constructor for class org.apache.hadoop.tools.rumen.ClusterTopologyReader
Constructor.
cmp - Variable in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
 
cmpcl - Variable in class org.apache.hadoop.mapred.join.Parser.Node
Deprecated.  
cmpcl - Variable in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
collect(Object, TaggedMapOutput, OutputCollector, Reporter) - Method in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
The subclass can overwrite this method to perform additional filtering and/or other processing logic before a value is collected.
collect(K, V) - Method in interface org.apache.hadoop.mapred.OutputCollector
Adds a key/value pair to the output.
collected - Variable in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
COLUMN_SEPARATOR - Static variable in class org.apache.hadoop.tools.Logalyzer
 
Combinable<T> - Interface in org.apache.hadoop.examples.pi
A class is Combinable if its object can be combined with other objects.
combine(Object[], Object[]) - Method in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
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.
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated.  
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapred.join.InnerJoinRecordReader
Deprecated. Return true iff the tuple is full (all data sources contain this key).
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader
Deprecated. Default implementation offers MultiFilterRecordReader.emit(org.apache.hadoop.mapred.join.TupleWritable) every Tuple from the collector (the outer join of child RRs).
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapred.join.OuterJoinRecordReader
Deprecated. Emit everything from the collector.
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.InnerJoinRecordReader
Return true iff the tuple is full (all data sources contain this key).
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader
Default implementation offers MultiFilterRecordReader.emit(org.apache.hadoop.mapreduce.lib.join.TupleWritable) every Tuple from the collector (the outer join of child RRs).
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.OuterJoinRecordReader
Emit everything from the collector.
CombineFileInputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use CombineFileInputFormat
CombineFileInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.CombineFileInputFormat
Deprecated. default constructor
CombineFileInputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
An abstract InputFormat that returns CombineFileSplit's in InputFormat.getSplits(JobContext) method.
CombineFileInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
default constructor
CombineFileRecordReader<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use CombineFileRecordReader
CombineFileRecordReader(JobConf, CombineFileSplit, Reporter, Class<RecordReader<K, V>>) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated. A generic RecordReader that can hand out different recordReaders for each chunk in the CombineFileSplit.
CombineFileRecordReader<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
A generic RecordReader that can hand out different recordReaders for each chunk in a CombineFileSplit.
CombineFileRecordReader(CombineFileSplit, TaskAttemptContext, Class<? extends RecordReader<K, V>>) - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
A generic RecordReader that can hand out different recordReaders for each chunk in the CombineFileSplit.
CombineFileSplit - Class in org.apache.hadoop.mapred.lib
Deprecated. Use CombineFileSplit
CombineFileSplit() - Constructor for class org.apache.hadoop.mapred.lib.CombineFileSplit
Deprecated.  
CombineFileSplit(JobConf, Path[], long[], long[], String[]) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileSplit
Deprecated.  
CombineFileSplit(JobConf, Path[], long[]) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileSplit
Deprecated.  
CombineFileSplit(CombineFileSplit) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileSplit
Deprecated. Copy constructor
CombineFileSplit - Class in org.apache.hadoop.mapreduce.lib.input
A sub-collection of input files.
CombineFileSplit() - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
default constructor
CombineFileSplit(Path[], long[], long[], String[]) - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
 
CombineFileSplit(Path[], long[]) - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
 
CombineFileSplit(CombineFileSplit) - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Copy constructor
comCmd_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
commitJob(JobContext) - Method in class org.apache.hadoop.examples.terasort.TeraOutputFormat.TeraOutputCommitter
 
commitJob(JobContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
commitJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. For committing job's output after successful job completion.
commitJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. This method implements the new interface by calling the old method.
commitJob(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Delete the temporary directory, including all of the work directories.
commitJob(JobContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
For committing job's output after successful job completion.
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. To promote the task's temporary output to final output location The task's output is moved to the job's output directory.
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. This method implements the new interface by calling the old method.
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Move the files from the work directory to the job output directory
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
To promote the task's temporary output to final output location The task's output is moved to the job's output directory.
COMPARATOR_OPTIONS - Static variable in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
 
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
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.tools.Logalyzer.LogComparator
 
compareTo(Object) - Method in class org.apache.hadoop.contrib.index.mapred.DocumentID
 
compareTo(Object) - Method in class org.apache.hadoop.contrib.index.mapred.Shard
 
compareTo(Shard) - Method in class org.apache.hadoop.contrib.index.mapred.Shard
Compare to another shard.
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
 
compareTo(ComposableRecordReader<K, ?>) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Implement Comparable contract (compare key of join or head of heap with that of another).
compareTo(ComposableRecordReader<K, ?>) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Implement Comparable contract (compare key at head of proxied RR with that of another).
compareTo(ID) - Method in class org.apache.hadoop.mapreduce.ID
Compare IDs by associated numbers
compareTo(ID) - Method in class org.apache.hadoop.mapreduce.JobID
Compare JobIds by first jtIdentifiers, then by job numbers
compareTo(ComposableRecordReader<K, ?>) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Implement Comparable contract (compare key of join or head of heap with that of another).
compareTo(ComposableRecordReader<K, ?>) - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Implement Comparable contract (compare key at head of proxied RR with that of another).
compareTo(ID) - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
Compare TaskIds by first tipIds, then by task numbers.
compareTo(ID) - Method in class org.apache.hadoop.mapreduce.TaskID
Compare TaskInProgressIds by first jobIds, then by tip numbers.
compareTo(Node) - Method in class org.apache.hadoop.tools.rumen.Node
 
completeLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.HarFileSystem
not implemented.
COMPLETION_POLL_INTERVAL_KEY - Static variable in class org.apache.hadoop.mapreduce.Job
Key in mapred-*.xml that sets completionPollInvervalMillis
ComposableInputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Interface in org.apache.hadoop.mapred.join
Deprecated. Use ComposableInputFormat instead
ComposableInputFormat<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.join
Refinement of InputFormat requiring implementors to provide ComposableRecordReader instead of RecordReader.
ComposableInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.join.ComposableInputFormat
 
ComposableRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Interface in org.apache.hadoop.mapred.join
Deprecated. Use ComposableRecordReader instead
ComposableRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.join
Additional operations required of a RecordReader to participate in a join.
ComposableRecordReader() - Constructor for class org.apache.hadoop.mapreduce.lib.join.ComposableRecordReader
 
compose(Class<? extends InputFormat>, String) - Static method in class org.apache.hadoop.mapred.join.CompositeInputFormat
Deprecated. Convenience method for constructing composite formats.
compose(String, Class<? extends InputFormat>, String...) - Static method in class org.apache.hadoop.mapred.join.CompositeInputFormat
Deprecated. Convenience method for constructing composite formats.
compose(String, Class<? extends InputFormat>, Path...) - Static method in class org.apache.hadoop.mapred.join.CompositeInputFormat
Deprecated. Convenience method for constructing composite formats.
compose(Class<? extends InputFormat>, String) - Static method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
Convenience method for constructing composite formats.
compose(String, Class<? extends InputFormat>, String...) - Static method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
Convenience method for constructing composite formats.
compose(String, Class<? extends InputFormat>, Path...) - Static method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
Convenience method for constructing composite formats.
CompositeInputFormat<K extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.hadoop.mapred.join
Deprecated. Use CompositeInputFormat instead
CompositeInputFormat() - Constructor for class org.apache.hadoop.mapred.join.CompositeInputFormat
Deprecated.  
CompositeInputFormat<K extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.hadoop.mapreduce.lib.join
An InputFormat capable of performing joins over a set of data sources sorted and partitioned the same way.
CompositeInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
 
CompositeInputSplit - Class in org.apache.hadoop.mapred.join
Deprecated. Use CompositeInputSplit instead
CompositeInputSplit() - Constructor for class org.apache.hadoop.mapred.join.CompositeInputSplit
Deprecated.  
CompositeInputSplit(int) - Constructor for class org.apache.hadoop.mapred.join.CompositeInputSplit
Deprecated.  
CompositeInputSplit - Class in org.apache.hadoop.mapreduce.lib.join
This InputSplit contains a set of child InputSplits.
CompositeInputSplit() - Constructor for class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
 
CompositeInputSplit(int) - Constructor for class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
 
CompositeRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,X extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.join
Deprecated. Use CompositeRecordReader instead
CompositeRecordReader(int, int, Class<? extends WritableComparator>) - Constructor for class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Create a RecordReader with capacity children to position id in the parent reader.
CompositeRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable,X extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.join
A RecordReader that can effect joins of RecordReaders sharing a common key type and partitioning.
CompositeRecordReader(int, int, Class<? extends WritableComparator>) - Constructor for class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Create a RecordReader with capacity children to position id in the parent reader.
CompositeRecordReader.JoinCollector - Class in org.apache.hadoop.mapreduce.lib.join
Collector for join values.
CompositeRecordReader.JoinCollector(int) - Constructor for class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader.JoinCollector
Construct a collector capable of handling the specified number of children.
COMPRESS - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
COMPRESS_CODEC - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
COMPRESS_TYPE - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
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.
computeSplitSize(long, long, long) - Method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated.  
computeSplitSize(long, long, long) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
conf - Variable in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
conf - Variable in class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
 
conf - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
CONF_MAX_JOB_TRACKER_RATIO - Static variable in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
CONF_MAX_MAPSLOT_SHARE_PER_JOB - Static variable in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
CONF_MAX_REDUCESLOT_SHARE_PER_JOB - Static variable in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
CONF_OVERLOAD_MAPTASK_MAPSLOT_RATIO - Static variable in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
CONF_OVERLOAD_REDUCETASK_REDUCESLOT_RATIO - Static variable in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
config_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
configure(JobConf) - Method in class org.apache.hadoop.contrib.index.example.IdentityLocalAnalysis
 
configure(JobConf) - Method in class org.apache.hadoop.contrib.index.example.LineDocLocalAnalysis
 
configure(JobConf) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateCombiner
 
configure(JobConf) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateMapper
 
configure(JobConf) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdatePartitioner
 
configure(JobConf) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateReducer
 
configure(IndexUpdateConfiguration) - Method in class org.apache.hadoop.contrib.index.mapred.IntermediateForm
Configure using an index update configuration.
configure(JobConf) - Method in class org.apache.hadoop.contrib.utils.join.DataJoinMapperBase
 
configure(JobConf) - Method in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
configure(JobConf) - Method in class org.apache.hadoop.contrib.utils.join.JobBase
Initializes a new instance from a JobConf.
configure(JobConf) - Method in interface org.apache.hadoop.mapred.JobConfigurable
Deprecated. Initializes a new instance from a JobConf.
configure(JobConf) - Method in class org.apache.hadoop.mapred.KeyValueTextInputFormat
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.aggregate.UserDefinedValueAggregatorDescriptor
Deprecated. Do nothing.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
Deprecated. get the input file name.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Deprecated. Combiner does not need to configure.
configure(JobConf) - Method in interface org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorDescriptor
Deprecated. Configure the object
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.BinaryPartitioner
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.ChainMapper
Deprecated. Configures the ChainMapper and all the Mappers in the chain.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.ChainReducer
Deprecated. Configures the ChainReducer, the Reducer and all the Mappers in the chain.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
Deprecated. Initializes a new instance from a JobConf.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.HashPartitioner
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.KeyFieldBasedComparator
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.KeyFieldBasedPartitioner
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.MultithreadedMapRunner
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.NLineInputFormat
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.RegexMapper
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.TotalOrderPartitioner
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.mapred.MapReduceBase
Deprecated. Default implementation that does nothing.
configure(JobConf) - Method in class org.apache.hadoop.mapred.MapRunner
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.TextInputFormat
Deprecated.  
configure(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UserDefinedValueAggregatorDescriptor
Do nothing.
configure(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
get the input file name.
configure(Configuration) - Method in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorDescriptor
Configure the object
configure(JobConf) - Method in class org.apache.hadoop.streaming.AutoInputFormat
 
configure(JobConf) - Method in class org.apache.hadoop.streaming.PipeMapper
 
configure(JobConf) - Method in class org.apache.hadoop.streaming.PipeMapRed
 
configure(JobConf) - Method in class org.apache.hadoop.streaming.PipeReducer
 
configure(JobConf) - Method in class org.apache.hadoop.tools.Logalyzer.LogRegexMapper
 
configure(Configuration) - Method in class org.apache.hadoop.vertica.VerticaInputSplit
(@inheritDoc)
configureDB(JobConf, String, String, String, String) - Static method in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. Sets the DB access related fields in the JobConf.
configureDB(JobConf, String, String) - Static method in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. Sets the DB access related fields in the JobConf.
configureDB(Configuration, String, String, String, String) - Static method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Sets the DB access related fields in the Configuration.
configureDB(Configuration, String, String) - Static method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Sets the DB access related fields in the JobConf.
configureVertica(Configuration, String[], String, String, String) - Static method in class org.apache.hadoop.vertica.VerticaConfiguration
Sets the Vertica database connection information in the (@link Configuration)
configureVertica(Configuration, String[], String, String, String, String[], String, String, String) - Static method in class org.apache.hadoop.vertica.VerticaConfiguration
Sets the Vertica database connection information in the (@link Configuration)
constructQuery(String, String[]) - Method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat
Constructs the query used as the prepared statement to insert data.
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?
context - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
ContextFactory - Class in org.apache.hadoop.mapreduce
A factory to allow applications to deal with inconsistencies between MapReduce Context Objects API between hadoop-0.20 and later versions.
ContextFactory() - Constructor for class org.apache.hadoop.mapreduce.ContextFactory
 
ControlledJob - Class in org.apache.hadoop.mapreduce.lib.jobcontrol
This class encapsulates a MapReduce job and its dependency.
ControlledJob(Job, List<ControlledJob>) - Constructor for class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Construct a job.
ControlledJob(Configuration) - Constructor for class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Construct a job.
ControlledJob.State - Enum in org.apache.hadoop.mapreduce.lib.jobcontrol
 
copy(Configuration, String, String, Path, boolean, boolean) - Static method in class org.apache.hadoop.tools.DistCp
Deprecated. 
copyFromLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.HarFileSystem
not implemented.
copyToLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.HarFileSystem
copies the file in the har filesystem to a local file.
countByTagName(String, Document) - Static method in class org.apache.hadoop.vaidya.util.XMLUtils
Count Elements in Document by Tag Name
countCounters() - Method in class org.apache.hadoop.mapreduce.Counters
Returns the total number of counters, by summing the number of counters in each group.
Counter - Class in org.apache.hadoop.mapreduce
A named counter that tracks the progress of a map/reduce job.
Counter() - Constructor for class org.apache.hadoop.mapreduce.Counter
 
Counter(String, String) - Constructor for class org.apache.hadoop.mapreduce.Counter
 
Counter(String, String, long) - Constructor for class org.apache.hadoop.mapreduce.Counter
Create a counter.
COUNTER_GROUP - Static variable in class org.apache.hadoop.mapred.SkipBadRecords
Special counters which are written by the application and are used by the framework for detecting bad records.
COUNTER_GROUP - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
COUNTER_MAP_PROCESSED_RECORDS - Static variable in class org.apache.hadoop.mapred.SkipBadRecords
Number of processed map records.
COUNTER_REDUCE_PROCESSED_GROUPS - Static variable in class org.apache.hadoop.mapred.SkipBadRecords
Number of processed reduce groups.
CounterGroup - Class in org.apache.hadoop.mapreduce
A group of Counters that logically belong together.
CounterGroup(String) - Constructor for class org.apache.hadoop.mapreduce.CounterGroup
 
CounterGroup(String, String) - Constructor for class org.apache.hadoop.mapreduce.CounterGroup
Create a CounterGroup.
Counters - Class in org.apache.hadoop.mapred
Deprecated. Use Counters instead.
Counters() - Constructor for class org.apache.hadoop.mapred.Counters
Deprecated.  
Counters - Class in org.apache.hadoop.mapreduce
 
Counters() - Constructor for class org.apache.hadoop.mapreduce.Counters
 
Counters(Counters) - Constructor for class org.apache.hadoop.mapreduce.Counters
Utility method to create a Counters object from the org.apache.hadoop.mapred counters
Counters.Counter - Class in org.apache.hadoop.mapred
Deprecated. A counter record, comprising its name and value.
Counters.Group - Class in org.apache.hadoop.mapred
Deprecated. Group of counters, comprising of counters from a particular counter Enum class.
create(Path, int) - Method in class org.apache.hadoop.fs.HarFileSystem
 
create(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.HarFileSystem
 
CREATE_DIR - Static variable in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
createDataJoinJob(String[]) - Static method in class org.apache.hadoop.contrib.utils.join.DataJoinJob
 
createDBRecordReader(DBInputFormat.DBInputSplit, Configuration) - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
 
createDBRecordReader(DBInputFormat.DBInputSplit, Configuration) - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
createDBRecordReader(DBInputFormat.DBInputSplit, Configuration) - Method in class org.apache.hadoop.mapreduce.lib.db.OracleDataDrivenDBInputFormat
 
createGridmixJob(Configuration, long, JobStory, Path, UserGroupInformation, int) - Method in enum org.apache.hadoop.mapred.gridmix.JobCreator
 
createInstance(String) - Static method in class org.apache.hadoop.mapred.lib.aggregate.UserDefinedValueAggregatorDescriptor
Deprecated. Create an instance of the given class
createInstance(String) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.UserDefinedValueAggregatorDescriptor
Create an instance of the given class
createInternalValue() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Create a value to be used internally for joins.
createJob(String[]) - Static method in class org.apache.hadoop.streaming.StreamJob
This method creates a streaming job from the given argument list.
createJobFactory(JobSubmitter, String, Path, Configuration, CountDownLatch, UserResolver) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
createJobMonitor(Statistics) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
createJobStoryProducer(String, Configuration) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
Create an appropriate JobStoryProducer object for the given trace.
createJobSubmitter(JobMonitor, int, int, FilePool, UserResolver, Statistics) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
createKey() - Method in class org.apache.hadoop.contrib.index.example.LineDocRecordReader
 
createKey() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Create a new key value common to all child RRs.
createKey() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Request new key from proxied RR.
createKey() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
Deprecated.  
createKey() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
createKey() - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBRecordReader
Deprecated. Create an object of the appropriate type to be used as a key.
createKey() - Method in interface org.apache.hadoop.mapred.RecordReader
Create an object of the appropriate type to be used as a key.
createKey() - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Deprecated.  
createKey() - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
Deprecated.  
createKey() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
createKey() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Create a new key common to all child RRs.
createKey() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Request new key from proxied RR.
createKey() - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
 
createOutput(String) - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
createPool(JobConf, List<PathFilter>) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
Deprecated. Use CombineFileInputFormat.createPool(List).
createPool(JobConf, PathFilter...) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
Deprecated. Use CombineFileInputFormat.createPool(PathFilter...).
createPool(List<PathFilter>) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
Create a new pool and add the filters to it.
createPool(PathFilter...) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
Create a new pool and add the filters to it.
createReaderThread() - Method in class org.apache.hadoop.mapred.gridmix.SerialJobFactory
 
createReaderThread() - Method in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpInputFormat
Create a record reader for a given split.
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.mapred.gridmix.SleepJob.SleepInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
Deprecated.  
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.InputFormat
Create a record reader for a given split.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
Create a record reader for a given split.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
This is not implemented yet.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueTextInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
Create a record reader for the given split
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.TextInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.join.ComposableInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
Construct a CompositeRecordReader for the children of this InputFormat as defined in the init expression.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.vertica.VerticaInputFormat
Create a record reader for a given split.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.vertica.VerticaStreamingInput
 
createResetableIterator() - Method in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
The subclass can provide a different implementation on ResetableIterator.
createSymlink() - Method in class org.apache.hadoop.mapreduce.Job
This method allows you to create symlinks in the current working directory of the task to all the cache files/archives
createTupleWritable() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Create a value to be used internally for joins.
createValue() - Method in class org.apache.hadoop.contrib.index.example.LineDocRecordReader
 
createValue() - Method in class org.apache.hadoop.mapred.join.JoinRecordReader
Deprecated. Create an object of the appropriate type to be used as a value.
createValue() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader
Deprecated. Create an object of the appropriate type to be used as a value.
createValue() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Request new value from proxied RR.
createValue() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
Deprecated.  
createValue() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
createValue() - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBRecordReader
Deprecated. Create an object of the appropriate type to be used as a value.
createValue() - Method in interface org.apache.hadoop.mapred.RecordReader
Create an object of the appropriate type to be used as a value.
createValue() - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Deprecated.  
createValue() - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
Deprecated.  
createValue() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
createValue() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Deprecated.  
createValue() - Method in class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader
 
createValue() - Method in class org.apache.hadoop.mapreduce.lib.join.OverrideRecordReader
 
createValue() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
 
createValue() - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
 
createValueAggregatorJob(String[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
Deprecated. Create an Aggregate based map/reduce job.
createValueAggregatorJob(String[], Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
Deprecated.  
createValueAggregatorJob(Configuration, String[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
Create an Aggregate based map/reduce job.
createValueAggregatorJob(String[], Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
 
createValueAggregatorJobs(String[], Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
Deprecated.  
createValueAggregatorJobs(String[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
Deprecated.  
createValueAggregatorJobs(String[], Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
 
createValueAggregatorJobs(String[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
 
createWriter(File, String) - Static method in class org.apache.hadoop.examples.pi.Util
Create a writer of a local file.
curReader - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
curReader - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
CurrentJHParser - Class in org.apache.hadoop.tools.rumen
JobHistoryParser that parses JobHistory files produced by JobHistory in the same source code tree as rumen.
CurrentJHParser(InputStream) - Constructor for class org.apache.hadoop.tools.rumen.CurrentJHParser
 

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.
DATA_FIELD_SEPERATOR - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
DATABASE_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Name of database to connect to
DataDrivenDBInputFormat<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A InputFormat that reads input data from an SQL table.
DataDrivenDBInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
 
DataDrivenDBInputFormat.DataDrivenDBInputSplit - Class in org.apache.hadoop.mapreduce.lib.db
A InputSplit that spans a set of rows
DataDrivenDBInputFormat.DataDrivenDBInputSplit() - Constructor for class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat.DataDrivenDBInputSplit
Default Constructor
DataDrivenDBInputFormat.DataDrivenDBInputSplit(String, String) - Constructor for class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat.DataDrivenDBInputSplit
Convenience Constructor
DataDrivenDBRecordReader<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A RecordReader that reads records from a SQL table, using data-driven WHERE clause splits.
DataDrivenDBRecordReader(DBInputFormat.DBInputSplit, Class<T>, Configuration, Connection, DBConfiguration, String, String[], String, String) - Constructor for class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBRecordReader
 
DataJoinJob - Class in org.apache.hadoop.contrib.utils.join
This class implements the main function for creating a map/reduce job to join data of different sources.
DataJoinJob() - Constructor for class org.apache.hadoop.contrib.utils.join.DataJoinJob
 
DataJoinMapperBase - Class in org.apache.hadoop.contrib.utils.join
This abstract class serves as the base class for the mapper class of a data join job.
DataJoinMapperBase() - Constructor for class org.apache.hadoop.contrib.utils.join.DataJoinMapperBase
 
DataJoinReducerBase - Class in org.apache.hadoop.contrib.utils.join
This abstract class serves as the base class for the reducer class of a data join job.
DataJoinReducerBase() - Constructor for class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
DATE_STRING - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Whether to marshal dates as strings
DateSplitter - Class in org.apache.hadoop.mapreduce.lib.db
Implement DBSplitter over date/time values.
DateSplitter() - Constructor for class org.apache.hadoop.mapreduce.lib.db.DateSplitter
 
dateToString(Date) - Method in class org.apache.hadoop.mapreduce.lib.db.DateSplitter
Given a Date 'd', format it as a string for use in a SQL date comparison operation.
dateToString(Date) - Method in class org.apache.hadoop.mapreduce.lib.db.OracleDateSplitter
 
DBConfiguration - Class in org.apache.hadoop.mapred.lib.db
Deprecated. Use DBConfiguration instead
DBConfiguration - Class in org.apache.hadoop.mapreduce.lib.db
A container for configuration property names for jobs with DB input/output.
DBConfiguration(Configuration) - Constructor for class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
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
 
DBInputFormat<T extends DBWritable> - Class in org.apache.hadoop.mapred.lib.db
Deprecated. Use DBInputFormat instead.
DBInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.db.DBInputFormat
Deprecated.  
DBInputFormat<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A InputFormat that reads input data from an SQL table.
DBInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
DBInputFormat.DBInputSplit - Class in org.apache.hadoop.mapred.lib.db
Deprecated. A InputSplit that spans a set of rows
DBInputFormat.DBInputSplit() - Constructor for class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBInputSplit
Deprecated. Default Constructor
DBInputFormat.DBInputSplit(long, long) - Constructor for class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBInputSplit
Deprecated. Convenience Constructor
DBInputFormat.DBInputSplit - Class in org.apache.hadoop.mapreduce.lib.db
A InputSplit that spans a set of rows
DBInputFormat.DBInputSplit() - Constructor for class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit
Default Constructor
DBInputFormat.DBInputSplit(long, long) - Constructor for class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit
Convenience Constructor
DBInputFormat.DBRecordReader - Class in org.apache.hadoop.mapred.lib.db
Deprecated. A RecordReader that reads records from a SQL table.
DBInputFormat.DBRecordReader(DBInputFormat.DBInputSplit, Class<T>, JobConf, Connection, DBConfiguration, String, String[], String) - Constructor for class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBRecordReader
Deprecated.  
DBInputFormat.NullDBWritable - Class in org.apache.hadoop.mapred.lib.db
Deprecated. A Class that does nothing, implementing DBWritable
DBInputFormat.NullDBWritable() - Constructor for class org.apache.hadoop.mapred.lib.db.DBInputFormat.NullDBWritable
Deprecated.  
DBInputFormat.NullDBWritable - Class in org.apache.hadoop.mapreduce.lib.db
A Class that does nothing, implementing DBWritable
DBInputFormat.NullDBWritable() - Constructor for class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.NullDBWritable
 
DBOutputFormat<K extends DBWritable,V> - Class in org.apache.hadoop.mapred.lib.db
Deprecated. Use org.apache.hadoop.mapreduce.lib.db.DBOutputFormat instead
DBOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.db.DBOutputFormat
Deprecated.  
DBOutputFormat<K extends DBWritable,V> - Class in org.apache.hadoop.mapreduce.lib.db
A OutputFormat that sends the reduce output to a SQL table.
DBOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat
 
DBOutputFormat.DBRecordWriter - Class in org.apache.hadoop.mapred.lib.db
Deprecated. A RecordWriter that writes the reduce output to a SQL table
DBOutputFormat.DBRecordWriter(Connection, PreparedStatement) - Constructor for class org.apache.hadoop.mapred.lib.db.DBOutputFormat.DBRecordWriter
Deprecated.  
DBOutputFormat.DBRecordWriter - Class in org.apache.hadoop.mapreduce.lib.db
A RecordWriter that writes the reduce output to a SQL table
DBOutputFormat.DBRecordWriter() - Constructor for class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat.DBRecordWriter
 
DBOutputFormat.DBRecordWriter(Connection, PreparedStatement) - Constructor for class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat.DBRecordWriter
 
DBRecordReader<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A RecordReader that reads records from a SQL table.
DBRecordReader(DBInputFormat.DBInputSplit, Class<T>, Configuration, Connection, DBConfiguration, String, String[], String) - Constructor for class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
DBSplitter - Interface in org.apache.hadoop.mapreduce.lib.db
DBSplitter will generate DBInputSplits to use with DataDrivenDBInputFormat.
DBWritable - Interface in org.apache.hadoop.mapred.lib.db
Deprecated. Use DBWritable instead
DBWritable - Interface in org.apache.hadoop.mapreduce.lib.db
Objects that are read from/written to a database should implement DBWritable.
debug_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
DeepCompare - Interface in org.apache.hadoop.tools.rumen
Classes that implement this interface can deep-compare [for equality only, not order] with another instance.
deepCompare(DeepCompare, TreePath) - Method in interface org.apache.hadoop.tools.rumen.DeepCompare
 
deepCompare(DeepCompare, TreePath) - Method in class org.apache.hadoop.tools.rumen.LoggedDiscreteCDF
 
deepCompare(DeepCompare, TreePath) - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
deepCompare(DeepCompare, TreePath) - Method in class org.apache.hadoop.tools.rumen.LoggedLocation
 
deepCompare(DeepCompare, TreePath) - Method in class org.apache.hadoop.tools.rumen.LoggedNetworkTopology
 
deepCompare(DeepCompare, TreePath) - Method in class org.apache.hadoop.tools.rumen.LoggedSingleRelativeRanking
 
deepCompare(DeepCompare, TreePath) - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
deepCompare(DeepCompare, TreePath) - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
DeepInequalityException - Exception in org.apache.hadoop.tools.rumen
We use this exception class in the unit test, and we do a deep comparison when we run the
DeepInequalityException(String, TreePath, Throwable) - Constructor for exception org.apache.hadoop.tools.rumen.DeepInequalityException
 
DeepInequalityException(String, TreePath) - Constructor for exception org.apache.hadoop.tools.rumen.DeepInequalityException
 
DEFAULT_LOG_LEVEL - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Default logging level for map/reduce tasks.
DEFAULT_MAPRED_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.  
DEFAULT_PATH - Static variable in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
DEFAULT_QUEUE_NAME - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Name of the queue to which jobs will be submitted, if no queue name is mentioned.
DefaultInputDemuxer - Class in org.apache.hadoop.tools.rumen
DefaultInputDemuxer acts as a pass-through demuxer.
DefaultInputDemuxer() - Constructor for class org.apache.hadoop.tools.rumen.DefaultInputDemuxer
 
DefaultOutputter<T> - Class in org.apache.hadoop.tools.rumen
The default Outputter that outputs to a plain file.
DefaultOutputter() - Constructor for class org.apache.hadoop.tools.rumen.DefaultOutputter
 
DELETE - Static variable in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp.Op
 
delete(Path, boolean) - Method in class org.apache.hadoop.fs.HarFileSystem
Not implemented.
deleteFile(String) - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
deleteLocalFiles() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. 
deleteLocalFiles(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated.  
deleteTermIterator() - Method in class org.apache.hadoop.contrib.index.mapred.IntermediateForm
Get an iterator for the delete terms in the intermediate form.
DELIMITER - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
 
delta - Variable in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
Difference between terms
DEPENDENT_FAILED - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated.  
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
 
DESCRIPTOR - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
DESCRIPTOR_NUM - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
DeskewedJobTraceReader - Class in org.apache.hadoop.tools.rumen
 
DeskewedJobTraceReader(JobTraceReader, int, boolean) - Constructor for class org.apache.hadoop.tools.rumen.DeskewedJobTraceReader
Constructor.
DeskewedJobTraceReader(JobTraceReader) - Constructor for class org.apache.hadoop.tools.rumen.DeskewedJobTraceReader
 
detailedUsage_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
DiagnosticTest - Class in org.apache.hadoop.vaidya
 
DiagnosticTest() - Constructor for class org.apache.hadoop.vaidya.DiagnosticTest
 
DIR_FORMATS - Static variable in class org.apache.hadoop.mapreduce.lib.input.MultipleInputs
 
DIR_MAPPERS - Static variable in class org.apache.hadoop.mapreduce.lib.input.MultipleInputs
 
DISABLED_MEMORY_LIMIT - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. A value which if set for memory related configuration options, indicates that the options are turned off.
displayJobList(Job[]) - Method in class org.apache.hadoop.mapreduce.tools.CLI
 
displayTasks(JobID, String, String) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Display the information about a job's tasks, of a particular type and in a particular state
displayTasks(Job, String, String) - Method in class org.apache.hadoop.mapreduce.tools.CLI
Display the information about a job's tasks, of a particular type and in a particular state
distance(Node, Node) - Method in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
distance(Node, Node) - Method in interface org.apache.hadoop.tools.rumen.ClusterStory
Determine the distance between two Nodes.
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
 
DistCh - Class in org.apache.hadoop.tools
A Map-reduce program to recursively change files properties such as owner, group and permission.
DistCp - Class in org.apache.hadoop.tools
A Map-reduce program to recursively copy directories between different file-systems.
DistCp(Configuration) - Constructor for class org.apache.hadoop.tools.DistCp
 
DistCp.DuplicationException - Exception in org.apache.hadoop.tools
An exception class for duplicated source files.
DistributedCache - Class in org.apache.hadoop.filecache
Deprecated. Use methods on Job.
DistributedCache() - Constructor for class org.apache.hadoop.filecache.DistributedCache
Deprecated.  
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
 
doAnalyze(String, String, String, String, String) - Method in class org.apache.hadoop.tools.Logalyzer
doAnalyze:
doArchive(String, String) - Method in class org.apache.hadoop.tools.Logalyzer
doArchive: Workhorse function to archive log-files.
DocumentAndOp - Class in org.apache.hadoop.contrib.index.mapred
This class represents an indexing operation.
DocumentAndOp() - Constructor for class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
Constructor for no operation.
DocumentAndOp(DocumentAndOp.Op, Document) - Constructor for class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
Constructor for an insert operation.
DocumentAndOp(DocumentAndOp.Op, Term) - Constructor for class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
Constructor for a delete operation.
DocumentAndOp(DocumentAndOp.Op, Document, Term) - Constructor for class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
Constructor for an insert, a delete or an update operation.
DocumentAndOp.Op - Class in org.apache.hadoop.contrib.index.mapred
This class represents the type of an operation - an insert, a delete or an update.
DocumentID - Class in org.apache.hadoop.contrib.index.mapred
The class represents a document id, which is of type text.
DocumentID() - Constructor for class org.apache.hadoop.contrib.index.mapred.DocumentID
Constructor.
DOUBLE_VALUE_SUM - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
Deprecated.  
DOUBLE_VALUE_SUM - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
DoubleValueSum - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use DoubleValueSum instead
DoubleValueSum() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.DoubleValueSum
Deprecated.  
DoubleValueSum - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements a value aggregator that sums up a sequence of double values.
DoubleValueSum() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.DoubleValueSum
The default constructor
downgrade(JobID) - Static method in class org.apache.hadoop.mapred.JobID
Deprecated. Downgrade a new JobID to an old one
downgrade(JobStatus) - Static method in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
downgrade(TaskAttemptID) - Static method in class org.apache.hadoop.mapred.TaskAttemptID
Deprecated. Downgrade a new TaskAttemptID to an old one
downgrade(TaskID) - Static method in class org.apache.hadoop.mapred.TaskID
Deprecated. Downgrade a new TaskID to an old one
DRIVER_CLASS_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. The JDBC Driver class name
DRIVER_CLASS_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
The JDBC Driver class name
DumpTypedBytes - Class in org.apache.hadoop.streaming
Utility program that fetches all files that match a given pattern and dumps their content to stdout as typed bytes.
DumpTypedBytes(Configuration) - Constructor for class org.apache.hadoop.streaming.DumpTypedBytes
 
DumpTypedBytes() - Constructor for class org.apache.hadoop.streaming.DumpTypedBytes
 

E

E - Variable in class org.apache.hadoop.examples.pi.math.Summation
Variable e in the summation.
EchoUserResolver - Class in org.apache.hadoop.mapred.gridmix
Echos the UGI offered.
EchoUserResolver() - Constructor for class org.apache.hadoop.mapred.gridmix.EchoUserResolver
 
emit(TupleWritable) - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader
Deprecated. For each tuple emitted, return a value (typically one of the values in the tuple).
emit(TupleWritable) - Method in class org.apache.hadoop.mapred.join.OverrideRecordReader
Deprecated. Emit the value with the highest position in the tuple.
emit(TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader
For each tuple emitted, return a value (typically one of the values in the tuple).
emit(TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.OverrideRecordReader
Emit the value with the highest position in the tuple.
empty - Variable in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
 
EMPTY_ARRAY - Static variable in class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated.  
EMPTY_ARRAY - Static variable in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
emptyText - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
endMap(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
endMap(TreeMap, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
endRecord(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
endRecord(Record, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
endVector(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
endVector(ArrayList, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
env_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
equals(Object) - Method in class org.apache.hadoop.contrib.index.mapred.Shard
 
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
 
equals(Object) - Method in class org.apache.hadoop.mapred.Counters
Deprecated.  
equals(Object) - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated. Checks for (content) equality of Groups
equals(Object) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Return true iff compareTo(other) retn true.
equals(Object) - Method in class org.apache.hadoop.mapreduce.Counter
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.CounterGroup
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.Counters
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.ID
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.JobID
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
equals(Object) - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Return true iff compareTo(other) retn true.
equals(Object) - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.TaskID
 
equals(Object) - Method in class org.apache.hadoop.tools.rumen.MachineNode
 
equals(Object) - Method in class org.apache.hadoop.tools.rumen.Node
 
err - Static variable in class org.apache.hadoop.examples.pi.Util
Error stream
ERROR_CODE - Static variable in exception org.apache.hadoop.tools.DistCp.DuplicationException
Error code for this exception
estimatePi(int, long, Configuration) - Static method in class org.apache.hadoop.examples.QuasiMonteCarlo
Run a map/reduce job for estimating Pi.
evaluate(JobStatistics) - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
evaluate(JobStatistics) - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.BalancedReducePartitioning
 
evaluate(JobStatistics) - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.MapSideDiskSpill
 
evaluate(JobStatistics) - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.MapsReExecutionImpact
 
evaluate(JobStatistics) - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.ReadingHDFSFilesAsSideEffect
 
evaluate(JobStatistics) - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.ReducesReExecutionImpact
 
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
 
EXECUTABLE - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
execute(int, List<E>) - Static method in class org.apache.hadoop.examples.pi.Util
Execute the callables by a number of threads
executeQuery(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
executeQuery(String) - Method in class org.apache.hadoop.mapreduce.lib.db.MySQLDataDrivenDBRecordReader
 
executeQuery(String) - Method in class org.apache.hadoop.mapreduce.lib.db.MySQLDBRecordReader
 
executeQuery() - Method in class org.apache.hadoop.vertica.VerticaInputSplit
Run the query that, when executed returns input for the mapper
exitUsage(boolean) - Method in class org.apache.hadoop.streaming.StreamJob
 
extractOutputKeyValue(String, String, String, List<Integer>, List<Integer>, int, boolean, boolean) - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 

F

fail(String) - Method in class org.apache.hadoop.streaming.StreamJob
 
FAILED - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated.  
FAILED - Static variable in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
failTask(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.Job
Fail indicated task attempt.
FieldSelectionHelper - Class in org.apache.hadoop.mapreduce.lib.fieldsel
This class implements a mapper/reducer class that can be used to perform field selections in a manner similar to unix cut.
FieldSelectionHelper() - Constructor for class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
FieldSelectionHelper(Text, Text) - Constructor for class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
FieldSelectionMapper<K,V> - Class in org.apache.hadoop.mapreduce.lib.fieldsel
This class implements a mapper class that can be used to perform field selections in a manner similar to unix cut.
FieldSelectionMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionMapper
 
FieldSelectionMapReduce<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use FieldSelectionMapper and FieldSelectionReducer instead
FieldSelectionMapReduce() - Constructor for class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
Deprecated.  
FieldSelectionReducer<K,V> - Class in org.apache.hadoop.mapreduce.lib.fieldsel
This class implements a reducer class that can be used to perform field selections in a manner similar to unix cut.
FieldSelectionReducer() - Constructor for class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionReducer
 
FileAlreadyExistsException - Exception in org.apache.hadoop.mapred
Deprecated. 
FileAlreadyExistsException() - Constructor for exception org.apache.hadoop.mapred.FileAlreadyExistsException
Deprecated.  
FileAlreadyExistsException(String) - Constructor for exception org.apache.hadoop.mapred.FileAlreadyExistsException
Deprecated.  
fileExists(String) - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
fileExtension(String) - Method in class org.apache.hadoop.streaming.JarBuilder
 
FileInputFormat<K,V> - Class in org.apache.hadoop.mapred
Deprecated. Use FileInputFormat instead.
FileInputFormat() - Constructor for class org.apache.hadoop.mapred.FileInputFormat
Deprecated.  
FileInputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
A base class for file-based InputFormats.
FileInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
fileLength(String) - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
fileModified(String) - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
FileOutputCommitter - Class in org.apache.hadoop.mapred
An OutputCommitter that commits files specified in job output directory i.e.
FileOutputCommitter() - Constructor for class org.apache.hadoop.mapred.FileOutputCommitter
 
FileOutputCommitter - Class in org.apache.hadoop.mapreduce.lib.output
An OutputCommitter that commits files specified in job output directory i.e.
FileOutputCommitter(Path, TaskAttemptContext) - Constructor for class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Create a file output committer
FileOutputFormat<K,V> - Class in org.apache.hadoop.mapred
A base class for OutputFormat.
FileOutputFormat() - Constructor for class org.apache.hadoop.mapred.FileOutputFormat
 
FileOutputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.output
A base class for OutputFormats that read from FileSystems.
FileOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
FileSplit - Class in org.apache.hadoop.mapred
Deprecated. Use FileSplit instead.
FileSplit() - Constructor for class org.apache.hadoop.mapred.FileSplit
Deprecated.  
FileSplit(Path, long, long, JobConf) - Constructor for class org.apache.hadoop.mapred.FileSplit
Deprecated.  
FileSplit(Path, long, long, String[]) - Constructor for class org.apache.hadoop.mapred.FileSplit
Deprecated. Constructs a split with host information
FileSplit(FileSplit) - Constructor for class org.apache.hadoop.mapred.FileSplit
Deprecated.  
FileSplit - Class in org.apache.hadoop.mapreduce.lib.input
A section of an input file.
FileSplit() - Constructor for class org.apache.hadoop.mapreduce.lib.input.FileSplit
 
FileSplit(Path, long, long, String[]) - Constructor for class org.apache.hadoop.mapreduce.lib.input.FileSplit
Constructs a split with host information
FileSystemDirectory - Class in org.apache.hadoop.contrib.index.lucene
This class implements a Lucene Directory on top of a general FileSystem.
FileSystemDirectory(FileSystem, Path, boolean, Configuration) - Constructor for class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
Constructor
fileURIs - Variable in class org.apache.hadoop.streaming.StreamJob
 
fillJoinCollector(K) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. For all child RRs offering the key provided, obtain an iterator at that position in the JoinCollector.
fillJoinCollector(K) - Method in class org.apache.hadoop.mapred.join.OverrideRecordReader
Deprecated. Instead of filling the JoinCollector with iterators from all data sources, fill only the rightmost for this key.
fillJoinCollector(K) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
For all child RRs offering the key provided, obtain an iterator at that position in the JoinCollector.
fillJoinCollector(K) - Method in class org.apache.hadoop.mapreduce.lib.join.OverrideRecordReader
Instead of filling the JoinCollector with iterators from all data sources, fill only the rightmost for this key.
FILTER_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
 
FILTER_FREQUENCY - Static variable in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
 
FILTER_REGEX - Static variable in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
 
FilterOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use FilterOutputFormat instead.
FilterOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.FilterOutputFormat
Deprecated.  
FilterOutputFormat(OutputFormat<K, V>) - Constructor for class org.apache.hadoop.mapred.lib.FilterOutputFormat
Deprecated. Create a FilterOutputFormat based on the supplied output format.
FilterOutputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.output
FilterOutputFormat is a convenience class that wraps OutputFormat.
FilterOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat
 
FilterOutputFormat(OutputFormat<K, V>) - Constructor for class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat
Create a FilterOutputFormat based on the underlying output format.
FilterOutputFormat.FilterRecordWriter<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. FilterRecordWriter is a convenience wrapper class that implements RecordWriter.
FilterOutputFormat.FilterRecordWriter() - Constructor for class org.apache.hadoop.mapred.lib.FilterOutputFormat.FilterRecordWriter
Deprecated.  
FilterOutputFormat.FilterRecordWriter(RecordWriter<K, V>) - Constructor for class org.apache.hadoop.mapred.lib.FilterOutputFormat.FilterRecordWriter
Deprecated.  
FilterOutputFormat.FilterRecordWriter<K,V> - Class in org.apache.hadoop.mapreduce.lib.output
FilterRecordWriter is a convenience wrapper class that extends the RecordWriter.
FilterOutputFormat.FilterRecordWriter() - Constructor for class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat.FilterRecordWriter
 
FilterOutputFormat.FilterRecordWriter(RecordWriter<K, V>) - Constructor for class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat.FilterRecordWriter
 
findCounter(Enum) - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Find the counter for the given enum.
findCounter(String, String) - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Find a counter given the group and the name.
findCounter(String, int, String) - Method in class org.apache.hadoop.mapred.Counters
Deprecated.  
findCounter(String, String) - Method in class org.apache.hadoop.mapreduce.CounterGroup
Find a counter in a group.
findCounter(String) - Method in class org.apache.hadoop.mapreduce.CounterGroup
 
findCounter(String, String) - Method in class org.apache.hadoop.mapreduce.Counters
 
findCounter(Enum<?>) - Method in class org.apache.hadoop.mapreduce.Counters
Find the counter for the given enum.
findSeparator(byte[], int, int, byte) - Static method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
Deprecated.  
findSeparator(byte[], int, int, byte) - Static method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
findTab(byte[], int, int) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
Find the first occured tab in a UTF-8 encoded string
findTab(byte[]) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
Find the first occured tab in a UTF-8 encoded string
FloatSplitter - Class in org.apache.hadoop.mapreduce.lib.db
Implement DBSplitter over floating-point values.
FloatSplitter() - Constructor for class org.apache.hadoop.mapreduce.lib.db.FloatSplitter
 
floorIndex(double) - Method in class org.apache.hadoop.tools.rumen.CDFRandomGenerator
 
flush() - Method in class org.apache.hadoop.mapred.TaskLogAppender
 
flush(TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader.JoinCollector
Write the next value into key, value as accepted by the operation associated with this set of RecordReaders.
Folder - Class in org.apache.hadoop.tools.rumen
 
Folder() - Constructor for class org.apache.hadoop.tools.rumen.Folder
 
forName(String) - Static method in class org.apache.hadoop.mapred.JobID
Deprecated. Construct a JobId object from given string
forName(String) - Static method in class org.apache.hadoop.mapred.TaskAttemptID
Deprecated. Construct a TaskAttemptID object from given string
forName(String) - Static method in class org.apache.hadoop.mapred.TaskID
Deprecated.  
forName(String) - Static method in class org.apache.hadoop.mapreduce.JobID
Construct a JobId object from given string
forName(String) - Static method in class org.apache.hadoop.mapreduce.TaskAttemptID
Construct a TaskAttemptID object from given string
forName(String) - Static method in class org.apache.hadoop.mapreduce.TaskID
Construct a TaskID object from given string
fourRotations - Static variable in class org.apache.hadoop.examples.dancing.Pentomino
Are all 4 rotations unique?
fromEscapedCompactString(String) - Static method in class org.apache.hadoop.mapred.Counters
Deprecated. Convert a stringified counter representation into a counter object.
fs - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
fs - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 

G

generateActualKey(K, V) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
Deprecated. Generate the actual key from the given key/value.
generateActualValue(K, V) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
Deprecated. Generate the actual value from the given key and value.
generateEntry(String, String, Text) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
Deprecated.  
generateEntry(String, String, Text) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
generateFileNameForKeyValue(K, V, String) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
Deprecated. Generate the file output file name based on the given key and the leaf file name.
generateGroupKey(TaggedMapOutput) - Method in class org.apache.hadoop.contrib.utils.join.DataJoinMapperBase
Generate a map output key.
generateInputTag(String) - Method in class org.apache.hadoop.contrib.utils.join.DataJoinMapperBase
Determine the source tag based on the input file name.
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.
generateKeyValPairs(Object, Object) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UserDefinedValueAggregatorDescriptor
Generate a list of aggregation-id/value pairs for the given key/value pairs by delegating the invocation to the real object.
generateKeyValPairs(Object, Object) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
Generate 1 or 2 aggregation-id/value pairs for the given key/value pair.
generateKeyValPairs(Object, Object) - Method in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorDescriptor
Generate a list of aggregation-id/value pairs for the given key/value pair.
generateLeafFileName(String) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
Deprecated. Generate the leaf name for the output file name.
generateTaggedMapOutput(Object) - Method in class org.apache.hadoop.contrib.utils.join.DataJoinMapperBase
Generate a tagged map output value.
generateValueAggregator(String) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
Deprecated.  
generateValueAggregator(String, long) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
generationFromSegmentsFileName(String) - Static method in class org.apache.hadoop.contrib.index.lucene.LuceneUtil
Parse the generation off the segments file name and return it.
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
get(int) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Deprecated. Get ith child InputSplit.
get(int) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
Get ith child InputSplit.
get(int) - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Get ith Writable from Tuple.
get() - Method in class org.apache.hadoop.tools.rumen.ClusterTopologyReader
Get the LoggedNetworkTopology object.
get(DataInput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesInput
Get a thread-local typed bytes input for the supplied DataInput.
get(DataOutput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Get a thread-local typed bytes output for the supplied DataOutput.
get(TypedBytesInput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
Get a thread-local typed bytes record input for the supplied TypedBytesInput.
get(DataInput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
Get a thread-local typed bytes record input for the supplied DataInput.
get(TypedBytesOutput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
Get a thread-local typed bytes record input for the supplied TypedBytesOutput.
get(DataOutput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
Get a thread-local typed bytes record output for the supplied DataOutput.
get(TypedBytesInput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
Get a thread-local typed bytes writable input for the supplied TypedBytesInput.
get(DataInput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
Get a thread-local typed bytes writable input for the supplied DataInput.
get(TypedBytesOutput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
Get a thread-local typed bytes writable input for the supplied TypedBytesOutput.
get(DataOutput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
Get a thread-local typed bytes writable output for the supplied DataOutput.
get(String) - Method in class org.apache.hadoop.vertica.VerticaRecord
 
get(int) - Method in class org.apache.hadoop.vertica.VerticaRecord
 
getActiveTaskTrackers() - Method in class org.apache.hadoop.mapreduce.Cluster
Get all active trackers in the cluster.
getActiveTrackerNames() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Get the names of task trackers in the cluster.
getAggregatorDescriptors(Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
getAllJobs() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get the jobs that are submitted.
getAllJobs() - Method in class org.apache.hadoop.mapreduce.Cluster
Get all the jobs in cluster.
getAllTaskAttempts() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
Get the map of all attempts for this task
getAllTasks() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the map of all tasks in this job
getAllTaskTypes() - Static method in class org.apache.hadoop.mapreduce.TaskID
 
getArchiveClassPaths() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the archive entries in classpath as an array of Path
getArchiveClassPaths() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getArchiveClassPaths() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getArchiveTimestamps() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the timestamps of the archives.
getArchiveTimestamps() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getArchiveTimestamps() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getAssignedJobID() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated.  
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the attempt Id
getAttemptID() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getAttempts() - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
getAttemptsToStartSkipping(Configuration) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Get the number of Task attempts AFTER which skip mode will be kicked off.
getAutoIncrMapperProcCount(Configuration) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Get the flag which if set to true, SkipBadRecords.COUNTER_MAP_PROCESSED_RECORDS is incremented by MapRunner after invoking the map function.
getAutoIncrReducerProcCount(Configuration) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Get the flag which if set to true, SkipBadRecords.COUNTER_REDUCE_PROCESSED_GROUPS is incremented by framework after invoking the reduce function.
getAvgMapTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.AnalyzedJob
Get the average map time
getAvgReduceTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.AnalyzedJob
Get the average reduce time
getAvgShuffleTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.AnalyzedJob
Get the average shuffle time
getBasePathInJarOut(String) - Method in class org.apache.hadoop.streaming.JarBuilder
 
getBaseRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
Deprecated.  
getBaseRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.MultipleSequenceFileOutputFormat
Deprecated.  
getBaseRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.MultipleTextOutputFormat
Deprecated.  
getBlackListedTaskTrackerCount() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of blacklisted trackers in the cluster.
getBlackListedTaskTrackers() - Method in class org.apache.hadoop.mapreduce.Cluster
Get blacklisted trackers.
getBlacklistedTrackerNames() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Get the names of task trackers in the cluster.
getBlacklistedTrackers() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Get the number of blacklisted task trackers in the cluster.
getBlackListedTrackersInfo() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Gets the list of blacklisted trackers along with reasons for blacklisting.
getBlackListReport() - Method in class org.apache.hadoop.mapred.ClusterStatus.BlackListInfo
Deprecated. Gets a descriptive report about why the tasktracker was blacklisted.
getBlacklistReport() - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
Gets a descriptive report about why the tasktracker was blacklisted.
getBlockIndex(BlockLocation[], long) - Method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated.  
getBlockIndex(BlockLocation[], long) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
getBoundingValsQuery() - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
 
getCacheArchives() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get cache archives set in the Configuration
getCacheArchives() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getCacheArchives() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getCacheFiles() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get cache files set in the Configuration
getCacheFiles() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getCacheFiles() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getCandidates() - Method in enum org.apache.hadoop.tools.rumen.JobConfPropertyNames
 
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.
getChildQueues(String) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Returns an array of queue information objects about immediate children of queue queueName.
getChildQueues(String) - Method in class org.apache.hadoop.mapreduce.Cluster
Returns immediate children of queueName.
getChildren() - Method in class org.apache.hadoop.mapred.JobQueueInfo
Deprecated.  
getChildren() - Method in class org.apache.hadoop.tools.rumen.LoggedNetworkTopology
 
getChildren() - Method in class org.apache.hadoop.tools.rumen.Node
Get the children of this node.
getClassByName(String) - Static method in class org.apache.hadoop.contrib.utils.join.DataJoinJob
 
getCleanupFinished() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of cleanup tasks that finished
getCleanupProgress() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getCleanupStarted() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of cleanup tasks started
getCleanupTaskReports(JobID) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get the information of the current state of the cleanup tasks of a job.
getClientInput() - Method in class org.apache.hadoop.streaming.PipeMapRed
Returns the DataInput from which the client output is read.
getClientOutput() - Method in class org.apache.hadoop.streaming.PipeMapRed
Returns the DataOutput to which the client input is written.
getClusterHandle() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get a handle to the Cluster
getClusterMapMB() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getClusterNick() - Method in class org.apache.hadoop.streaming.StreamJob
Deprecated. 
getClusterReduceMB() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getClusterStatus() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get status information about the Map-Reduce cluster.
getClusterStatus(boolean) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get status information about the Map-Reduce cluster.
getClusterStatus() - Method in class org.apache.hadoop.mapreduce.Cluster
Get current cluster status.
getClusterTopology() - Method in interface org.apache.hadoop.tools.rumen.ClusterStory
Get the cluster topology tree.
getClusterTopology() - Method in class org.apache.hadoop.tools.rumen.ZombieCluster
 
getCollector(String, Reporter) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Gets the output collector for a named output.
getCollector(String, String, Reporter) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Gets the output collector for a multi named output.
getColumnName(int) - Method in class org.apache.hadoop.examples.dancing.DancingLinks
Get the name of a given column as a string
getCombineInputRecords() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getCombinerClass() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the user-defined combiner class used to combine map-outputs before being sent to the reducers.
getCombinerClass() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the combiner class for the job.
getCombinerClass() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getCombinerClass() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getCombinerOutput() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.DoubleValueSum
 
getCombinerOutput() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMax
 
getCombinerOutput() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMin
 
getCombinerOutput() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueSum
 
getCombinerOutput() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMax
 
getCombinerOutput() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMin
 
getCombinerOutput() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
 
getCombinerOutput() - Method in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregator
 
getCombinerOutput() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueHistogram
 
getComparator() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Return comparator defining the ordering for RecordReaders in this composite.
getComparator() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Return comparator defining the ordering for RecordReaders in this composite.
getCompletionPollInterval(Configuration) - Static method in class org.apache.hadoop.mapreduce.Job
The interval at which waitForCompletion() should check.
getCompressMapOutput() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Are the outputs of the maps be compressed?
getCompressOutput(JobConf) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
Is the job output compressed?
getCompressOutput(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Is the job output compressed?
getComputonsPerMapInputByte() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getComputonsPerMapOutputByte() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getComputonsPerReduceInputByte() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getComputonsPerReduceOutputByte() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getConditions() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getConf() - Method in class org.apache.hadoop.examples.terasort.TeraSort.SimplePartitioner
 
getConf() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. 
getConf() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getConf() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
getConf() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.FilterBase
 
getConf() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
getConf() - Method in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
 
getConf() - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
 
getConf() - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
 
getConf() - Method in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
getConf() - Method in class org.apache.hadoop.streaming.DumpTypedBytes
 
getConf() - Method in class org.apache.hadoop.streaming.LoadTypedBytes
 
getConf() - Method in class org.apache.hadoop.streaming.StreamJob
 
getConf() - Method in class org.apache.hadoop.tools.DistCp
 
getConf() - Method in class org.apache.hadoop.tools.HadoopArchives
 
getConf() - Method in class org.apache.hadoop.tools.Logalyzer.LogComparator
 
getConf() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
getConfiguration() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Get the underlying configuration object.
getConfiguration() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Get the underlying job configuration
getConfiguration() - Method in interface org.apache.hadoop.mapreduce.JobContext
Return the configuration for the job.
getConfiguration() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getConfiguration() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getConfiguration() - Method in class org.apache.hadoop.streaming.PipeMapRed
Returns the Configuration.
getConfiguration() - Method in class org.apache.hadoop.vertica.VerticaConfiguration
 
getConfiguration() - Method in class org.apache.hadoop.vertica.VerticaInputSplit
(@inheritDoc)
getConnection() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Returns a connection object o the DB
getConnection() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
getConnection() - Method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat.DBRecordWriter
 
getConnection() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getContext() - Method in class org.apache.hadoop.streaming.PipeMapRed
 
getCounter() - Method in class org.apache.hadoop.mapred.Counters.Counter
Deprecated. What is the current value of this counter?
getCounter(Enum) - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Returns current value of the specified counter, or 0 if the counter does not exist.
getCounter(String) - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated. Returns the value of the specified counter, or 0 if the counter does not exist.
getCounter(int, String) - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated. use Counters.Group.getCounter(String) instead
getCounter(Counters, String, String) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated.  
getCounter(Enum<?>) - Method in interface org.apache.hadoop.mapred.Reporter
Get the Counters.Counter of the given group with the given name.
getCounter(String, String) - Method in interface org.apache.hadoop.mapred.Reporter
Get the Counters.Counter of the given group with the given name.
getCounter(Enum<?>) - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getCounter(String, String) - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getCounter(Enum) - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getCounter(String, String) - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getCounter(Enum<?>) - Method in class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl.DummyReporter
 
getCounter(String, String) - Method in class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl.DummyReporter
 
getCounter(Enum<?>) - Method in interface org.apache.hadoop.mapreduce.TaskAttemptContext
Get the Counter for the given counterName.
getCounter(String, String) - Method in interface org.apache.hadoop.mapreduce.TaskAttemptContext
Get the Counter for the given groupName and counterName.
getCounter(Counters, String, String) - Method in class org.apache.hadoop.mapreduce.tools.CLI
 
getCounterForName(String) - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated. Get the counter for the given name and create it if it doesn't exist.
getCounters() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Gets the counters for this job.
getCounters() - Method in class org.apache.hadoop.mapred.TaskReport
Deprecated.  
getCounters() - Method in class org.apache.hadoop.mapreduce.Job
Gets the counters for this job.
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the counters for the attempt
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
Get the counters for this task
getCountersEnabled(JobConf) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Returns if the counters for the named outputs are enabled or not.
getCountersEnabled(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
Returns if the counters for the named outputs are enabled or not.
getCountQuery() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
Returns the query for getting the total number of rows, subclasses can override this for custom behaviour.
getCredentials() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get credentials for the job.
getCredentials() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get credentials for the job.
getCredentials() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getCredentials() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getCumulativeCpuTime() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin.ProcResourceValues
Obtain the cumulative CPU time used by a current process tree.
getCurrentKey() - Method in class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Get the current key
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Get current key
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.RecordReader
Get the current key
getCurrentKey() - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Get the current key.
getCurrentKey() - Method in class org.apache.hadoop.streaming.io.OutputReader
Returns the current key.
getCurrentKey() - Method in class org.apache.hadoop.streaming.io.RawBytesOutputReader
 
getCurrentKey() - Method in class org.apache.hadoop.streaming.io.TextOutputReader
 
getCurrentKey() - Method in class org.apache.hadoop.streaming.io.TypedBytesOutputReader
 
getCurrentKey() - Method in class org.apache.hadoop.vertica.VerticaRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.vertica.VerticaStreamingRecordReader
Get the current key
getCurrentSegmentGeneration(Directory) - Static method in class org.apache.hadoop.contrib.index.lucene.LuceneUtil
Get the generation (N) of the current segments_N file in the directory.
getCurrentSegmentGeneration(String[]) - Static method in class org.apache.hadoop.contrib.index.lucene.LuceneUtil
Get the generation (N) of the current segments_N file from a list of files.
getCurrentUserResolver() - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
getCurrentValue() - Method in class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
getCurrentValue(V) - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Get the current value.
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Get the current value.
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Get current value
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.RecordReader
Get the current value.
getCurrentValue() - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Get the current value.
getCurrentValue() - Method in class org.apache.hadoop.streaming.io.OutputReader
Returns the current value.
getCurrentValue() - Method in class org.apache.hadoop.streaming.io.RawBytesOutputReader
 
getCurrentValue() - Method in class org.apache.hadoop.streaming.io.TextOutputReader
 
getCurrentValue() - Method in class org.apache.hadoop.streaming.io.TypedBytesOutputReader
 
getCurrentValue() - Method in class org.apache.hadoop.vertica.VerticaRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.vertica.VerticaStreamingRecordReader
Get the current value.
getData() - Method in class org.apache.hadoop.contrib.utils.join.TaggedMapOutput
 
getDatum() - Method in class org.apache.hadoop.tools.rumen.LoggedSingleRelativeRanking
 
getDatumAt(int) - Method in class org.apache.hadoop.tools.rumen.CDFRandomGenerator
 
getDBConf() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
getDBConf() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getDBProductName() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
getDecommissionedTaskTrackerCount() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of decommissioned trackers in the cluster.
getDefaultMaps() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get status information about the max available Maps in the cluster.
getDefaultReduces() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get status information about the max available Reduces in the cluster.
getDefaultWorkFile(TaskAttemptContext, String) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Get the default path and filename for the output format.
getDelegate() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Obtain an iterator over the child RRs apropos of the value type ultimately emitted from this join.
getDelegate() - Method in class org.apache.hadoop.mapred.join.JoinRecordReader
Deprecated. Return an iterator wrapping the JoinCollector.
getDelegate() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader
Deprecated. Return an iterator returning a single value from the tuple.
getDelegate() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Obtain an iterator over the child RRs apropos of the value type ultimately emitted from this join.
getDelegate() - Method in class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader
Return an iterator wrapping the JoinCollector.
getDelegate() - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader
Return an iterator returning a single value from the tuple.
getDelegationToken(Text) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get a delegation token for the user from the JobTracker.
getDelegationToken(Text) - Method in class org.apache.hadoop.mapreduce.Cluster
Get a delegation token for the user from the JobTracker.
getDelegationToken(Credentials, String) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
 
getDependentJobs() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
getDependingJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated.  
getDescription() - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
getDirectDependantJobs() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getDirectory() - Method in class org.apache.hadoop.contrib.index.mapred.IntermediateForm
Get the ram directory of the intermediate form.
getDirectory() - Method in class org.apache.hadoop.contrib.index.mapred.Shard
Get the directory where this shard resides.
getDisplayName() - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated. Returns localized name of the group.
getDisplayName() - Method in class org.apache.hadoop.mapreduce.Counter
Get the name of the counter.
getDisplayName() - Method in class org.apache.hadoop.mapreduce.CounterGroup
Get the display name of the group.
getDistributionPolicyClass() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Get the distribution policy class.
getDocument() - Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
Get the document.
getDocumentAnalyzerClass() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Get the analyzer class.
getDoubleValue(Object) - Method in class org.apache.hadoop.contrib.utils.join.JobBase
 
getDoubleValue(Enum) - Method in class org.apache.hadoop.vaidya.statistics.job.JobStatistics
 
getDoubleValue(Enum) - Method in interface org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface
 
getDoubleValue(Enum) - Method in class org.apache.hadoop.vaidya.statistics.job.TaskStatistics
 
getDropTable() - Method in class org.apache.hadoop.vertica.VerticaConfiguration
Return whether output table is truncated before loading
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
getElementValue(String, Element) - Static method in class org.apache.hadoop.vaidya.util.XMLUtils
 
getEnd() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit
 
getEnd() - Method in class org.apache.hadoop.vertica.VerticaInputSplit
 
getEntry(MapFile.Reader[], Partitioner<K, V>, K, V) - Static method in class org.apache.hadoop.mapred.MapFileOutputFormat
Deprecated. Get an entry from output generated by this class.
getEntry(MapFile.Reader[], Partitioner<K, V>, K, V) - Static method in class org.apache.hadoop.mapreduce.lib.output.MapFileOutputFormat
Get an entry from output generated by this class.
getError() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the error string
getError() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
Get the error
getEventId() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Returns event Id.
getExecutable(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Get the URI of the application's executable.
getFailedDueToAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
Get the attempt Id that caused this task to fail
getFailedJobList() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getFailedJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
Deprecated.  
getFailedMapAttemptCDFs() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getFailedMapperFraction() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getFailedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the total number of failed maps
getFailedReduceAttemptCDF() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getFailedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the number of failed reduces
getFieldNames() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getFieldSeparator() - Method in class org.apache.hadoop.streaming.PipeMapper
 
getFieldSeparator() - Method in class org.apache.hadoop.streaming.PipeMapRed
Returns the field separator to be used.
getFieldSeparator() - Method in class org.apache.hadoop.streaming.PipeReducer
 
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.hadoop.fs.HarFileSystem
get block locations from the underlying fs
getFileBytesRead() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getFileBytesWritten() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getFileChecksum(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
 
getFileClassPaths() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the file entries in classpath as an array of Path
getFileClassPaths() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getFileClassPaths() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getFileStatus(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
return the filestatus of files in har archive.
getFileSystem() - Method in class org.apache.hadoop.mapreduce.Cluster
Get the file system where job-specific files are stored
getFileTimestamps() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the timestamps of the files.
getFileTimestamps() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getFileTimestamps() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getFilter() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.FilteredJob
Get the current filter
getFilteredMap() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.FilteredJob
Get the map of the filtered tasks
getFinalSync(JobContext) - Static method in class org.apache.hadoop.examples.terasort.TeraOutputFormat
Does the user want a final sync at close?
getFinishedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the number of finished maps
getFinishedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the number of finished reduces
getFinishTime() - Method in class org.apache.hadoop.mapreduce.Job
Get finish time of the job.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the job finish time
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the finish time of the attempt
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
Get the finish time of this task
getFinishTime() - Method in class org.apache.hadoop.mapreduce.JobStatus
Get the finish time of the job.
getFinishTime() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getFinishTime() - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
getFinishTime() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getFirst() - Method in class org.apache.hadoop.examples.SecondarySort.IntPair
 
getFlippable() - Method in class org.apache.hadoop.examples.dancing.Pentomino.Piece
 
getFormatMinSplitSize() - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Get the lower bound on split size imposed by the format.
getFormatMinSplitSize() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFormat
 
getFs() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get a filesystem handle.
getGeneration() - Method in class org.apache.hadoop.contrib.index.mapred.Shard
Get the generation of the Lucene instance.
getGroup(String) - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Returns the named counter group, or an empty group if there is none with the specified name.
getGroup(String) - Method in class org.apache.hadoop.mapreduce.Counters
Returns the named counter group, or an empty group if there is none with the specified name.
getGroupingComparator() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the user defined RawComparator comparator for grouping keys of inputs to the reduce.
getGroupingComparator() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getGroupingComparator() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getGroupNames() - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Returns the names of all counter classes.
getGroupNames() - Method in class org.apache.hadoop.mapreduce.Counters
Returns the names of all counter classes.
getHadoopClientHome() - Method in class org.apache.hadoop.streaming.StreamJob
 
getHarHash(Path) - Static method in class org.apache.hadoop.fs.HarFileSystem
the hash of the path p inside iniside the filesystem
getHarVersion() - Method in class org.apache.hadoop.fs.HarFileSystem
 
getHdfsBytesRead() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getHdfsBytesWritten() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getHeapMegabytes() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getHistoryFile() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getHistoryUrl() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Get the url where history file is archived.
getHistoryUrl() - Method in class org.apache.hadoop.mapreduce.Job
 
getHomeDirectory() - Method in class org.apache.hadoop.fs.HarFileSystem
return the top level archive path.
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the host name
getHostName() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the HTTP port for the tracker
getId() - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
getID() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Get the job identifier.
getId() - Method in class org.apache.hadoop.mapreduce.ID
returns the int which represents the identifier
getImpactLevel() - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
getImportance() - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
getIndexInputFormatClass() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Get the index input format class.
getIndexMaxFieldLength() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Get the max field length for a Lucene instance.
getIndexMaxNumSegments() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Get the max number of segments for a Lucene instance.
getIndexShards() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Get the string representation of a number of shards.
getIndexShards(IndexUpdateConfiguration) - Static method in class org.apache.hadoop.contrib.index.mapred.Shard
 
getIndexUpdaterClass() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Get the index updater class.
getIndexUseCompoundFile() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Check whether to use the compound file format for a Lucene instance.
getInputBoundingQuery() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getInputBytes() - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
getInputBytes() - Method in class org.apache.hadoop.tools.rumen.TaskInfo
 
getInputClass() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getInputConditions() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getInputCountQuery() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getInputDataLength() - Method in class org.apache.hadoop.mapreduce.split.JobSplit.SplitMetaInfo
 
getInputDataLength() - Method in class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitMetaInfo
 
getInputDelimiter() - Method in class org.apache.hadoop.vertica.VerticaConfiguration
For streaming return the delimiter to separate values to the mapper
getInputElementDoubleValue(String, double) - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
getInputElementLongValue(String, long) - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
getInputElementStringValue(String, String) - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
getInputFieldNames() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getInputFileBasedOutputFileName(JobConf, String) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
Deprecated. Generate the outfile name based on a given anme and the input file name.
getInputFormat() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the InputFormat implementation for the map-reduce job, defaults to TextInputFormat if not specified explicity.
getInputFormatClass() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the InputFormat class for the job.
getInputFormatClass() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getInputFormatClass() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getInputOrderBy() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getInputParameters() - Method in class org.apache.hadoop.vertica.VerticaConfiguration
Return static input parameters if set
getInputPathFilter(JobConf) - Static method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. Get a PathFilter instance of the filter set for the input paths.
getInputPathFilter(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Get a PathFilter instance of the filter set for the input paths.
getInputPaths(JobConf) - Static method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. Get the list of input Paths for the map-reduce job.
getInputPaths(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Get the list of input Paths for the map-reduce job.
getInputQuery() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getInputQuery() - Method in class org.apache.hadoop.vertica.VerticaConfiguration
 
getInputRecords() - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
getInputRecords() - Method in class org.apache.hadoop.tools.rumen.TaskInfo
 
getInputRecordTerminator() - Method in class org.apache.hadoop.vertica.VerticaConfiguration
For streaming return the record terminator to separate values to the mapper
getInputSeparator() - Method in class org.apache.hadoop.streaming.PipeMapper
 
getInputSeparator() - Method in class org.apache.hadoop.streaming.PipeMapRed
Returns the input separator to be used.
getInputSeparator() - Method in class org.apache.hadoop.streaming.PipeReducer
 
getInputSplit() - Method in interface org.apache.hadoop.mapred.Reporter
Get the InputSplit object for a map.
getInputSplit() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
Get the input split for this map.
getInputSplit() - Method in interface org.apache.hadoop.mapreduce.MapContext
Get the input split for this map.
getInputSplits() - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get the input splits for the job.
getInputSplits() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
 
getInputTableName() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getInputWriterClass() - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Returns the resolved InputWriter class.
getInstance() - Static method in class org.apache.hadoop.mapreduce.Job
Creates a new Job with no particular Cluster .
getInstance(Configuration) - Static method in class org.apache.hadoop.mapreduce.Job
Creates a new Job with no particular Cluster .
getInstance(Configuration, String) - Static method in class org.apache.hadoop.mapreduce.Job
Creates a new Job with no particular Cluster and a given jobName.
getInstance(Cluster) - Static method in class org.apache.hadoop.mapreduce.Job
 
getInstance(Cluster, Configuration) - Static method in class org.apache.hadoop.mapreduce.Job
 
getInstance(Cluster, JobStatus, Configuration) - Static method in class org.apache.hadoop.mapreduce.Job
 
getIOSortMB() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Get the IO sort space in MB.
getIsCleanup() - Method in class org.apache.hadoop.mapred.TaskLogAppender
Get whether task is cleanup attempt or not.
getIsJavaMapper(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Check whether the job is using a Java Mapper.
getIsJavaRecordReader(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Check whether the job is using a Java RecordReader
getIsJavaRecordWriter(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Will the reduce use a Java RecordWriter?
getIsJavaReducer(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Check whether the job is using a Java Reducer.
getJar() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the user jar for the map-reduce job.
getJar() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the pathname of the job's jar.
getJar() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getJar() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getJarUnpackPattern() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the pattern for jar contents to unpack on the tasktracker
getJob(JobID) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get an RunningJob object to track an ongoing job.
getJob(String) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Applications should rather use JobClient.getJob(JobID).
getJob() - Method in class org.apache.hadoop.mapred.lib.CombineFileSplit
Deprecated.  
getJob(JobID) - Method in class org.apache.hadoop.mapreduce.Cluster
Get job corresponding to jobid.
getJob() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
getJobACLs() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getJobACLs() - Method in class org.apache.hadoop.mapreduce.JobStatus
Get the job acls.
getJobClient() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated.  
getJobConf() - Method in interface org.apache.hadoop.mapred.JobContext
Deprecated. Get the job Configuration
getJobConf() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated.  
getJobConf() - Method in interface org.apache.hadoop.mapred.TaskAttemptContext
Deprecated.  
getJobConf() - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get the JobConf for the job.
getJobConf() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
 
getJobConf() - Method in class org.apache.hadoop.vaidya.statistics.job.JobStatistics
 
getJobConf() - Method in interface org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface
Get job configuration (job.xml) values
getJobConfPath() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the path for the job configuration file
getJobEndNotificationURI() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the uri to be invoked in-order to send a notification after the job has completed (success/failure).
getJobExecutionStatistics() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.PostExPerformanceDiagnoser
 
getJobFile() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Get the path of the submitted job configuration.
getJobFile() - Method in class org.apache.hadoop.mapreduce.Job
Get the path of the submitted job configuration.
getJobFile() - Method in class org.apache.hadoop.mapreduce.JobStatus
Get the configuration file for the job.
getJobHistoryFile() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.PostExPerformanceDiagnoser
 
getJobHistoryUrl(JobID) - Method in class org.apache.hadoop.mapreduce.Cluster
Get the job history file path for a given job id.
getJobId() - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. use getJobID instead
getJobID() - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
getJobID() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. This method is deprecated and will be removed. Applications should rather use RunningJob.getID().
getJobID() - Method in class org.apache.hadoop.mapred.TaskAttemptID
Deprecated.  
getJobID() - Method in class org.apache.hadoop.mapred.TaskID
Deprecated.  
getJobID() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the unique ID for the job.
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the job id
getJobID() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getJobID() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
getJobID() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getJobID() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getJobID() - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
Returns the JobID object that this task attempt belongs to
getJobID() - Method in class org.apache.hadoop.mapreduce.TaskID
Returns the JobID object that this tip belongs to
getJobID() - Method in class org.apache.hadoop.tools.rumen.JobBuilder
 
getJobID() - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get the job ID
getJobID() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getJobID() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
 
getJobIDsPattern(String, Integer) - Static method in class org.apache.hadoop.mapred.JobID
Deprecated. 
getJobLocalDir() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get job-specific shared directory for use as scratch space
getJobMapMB() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getJobName() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the user-specified job name.
getJobName() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Get the name of the job.
getJobName() - Method in class org.apache.hadoop.mapreduce.Job
The user-specified job name.
getJobName() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the user-specified job name.
getJobname() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the job name
getJobName() - Method in class org.apache.hadoop.mapreduce.JobStatus
Get the user-specified job name.
getJobName() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
getJobName() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getJobName() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getJobName() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getJobPriority() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the JobPriority for this job.
getJobPriority() - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Return the priority of the job
getJobQueueName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the job queue name
getJobReduceMB() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getJobRunState(int) - Static method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Helper method to get human-readable state of the job.
getJobSetupCleanupNeeded() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get whether job-setup and job-cleanup is needed for the job
getJobSetupCleanupNeeded() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getJobSetupCleanupNeeded() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getJobsFromQueue(String) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Gets all the jobs which were added to particular Job Queue
getJobState() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Returns the current state of the Job.
getJobState() - Method in class org.apache.hadoop.mapreduce.Job
Returns the current state of the Job.
getJobState() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
getJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the job status
getJobStatuses() - Method in class org.apache.hadoop.mapreduce.QueueInfo
Get the jobs submitted to queue
getJobToken(Credentials) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
 
getJobTrackerHostPort() - Method in class org.apache.hadoop.streaming.StreamJob
 
getJobTrackerState() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Use ClusterStatus.getJobTrackerStatus() instead.
getJobTrackerState() - Method in class org.apache.hadoop.mapreduce.Cluster
Deprecated. Use Cluster.getJobTrackerStatus() instead.
getJobTrackerStatus() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Get the JobTracker's status.
getJobTrackerStatus() - Method in class org.apache.hadoop.mapreduce.Cluster
Get the JobTracker's status.
getJobtype() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getJtIdentifier() - Method in class org.apache.hadoop.mapreduce.JobID
 
getKeepCommandFile(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Does the user want to keep the command file for debugging? If this is true, pipes will write a copy of the command data to a file in the task directory named "downlink.data", which may be used to run the C++ program under the debugger.
getKeepFailedTaskFiles() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Should the temporary files for failed tasks be kept?
getKeepTaskFilesPattern() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the regular expression that is matched against the task names to see if we need to keep the files.
getKey() - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
getKeyClass() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
Deprecated.  
getKeyClass() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
The class of key that must be passed to SequenceFileRecordReader.next(Object, Object)..
getKeyClassName() - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Deprecated. Retrieve the name of the key class for this SequenceFile.
getKeyClassName() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Retrieve the name of the key class for this SequenceFile.
getKeyFieldComparatorOption() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the KeyFieldBasedComparator options
getKeyFieldComparatorOption(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
Get the KeyFieldBasedComparator options
getKeyFieldPartitionerOption() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the KeyFieldBasedPartitioner options
getKeyFieldPartitionerOption(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
Get the KeyFieldBasedPartitioner options
getLastOutput() - Method in class org.apache.hadoop.streaming.io.OutputReader
Returns the last output from the client as a String.
getLastOutput() - Method in class org.apache.hadoop.streaming.io.RawBytesOutputReader
 
getLastOutput() - Method in class org.apache.hadoop.streaming.io.TextOutputReader
 
getLastOutput() - Method in class org.apache.hadoop.streaming.io.TypedBytesOutputReader
 
getLaunchTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the job launch time
getLaunchTime() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getLayers() - Method in class org.apache.hadoop.tools.rumen.LoggedLocation
 
getLength() - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpSplit
Get the size of the split, so that the input splits can be sorted by size.
getLength() - Method in class org.apache.hadoop.examples.pi.DistSum.Machine.SummationSplit
Get the size of the split, so that the input splits can be sorted by size.
getLength() - Method in class org.apache.hadoop.mapred.FileSplit
Deprecated. The number of bytes in the file to process.
getLength() - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
getLength() - Method in interface org.apache.hadoop.mapred.InputSplit
Deprecated. Get the total number of bytes in the data of the InputSplit.
getLength() - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Deprecated. Return the aggregate length of all child InputSplits currently added.
getLength(int) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Deprecated. Get the length of ith child InputSplit.
getLength() - Method in class org.apache.hadoop.mapreduce.InputSplit
Get the size of the split, so that the input splits can be sorted by size.
getLength() - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat.DataDrivenDBInputSplit
 
getLength() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit
 
getLength() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
 
getLength(int) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns the length of the ith Path
getLength() - Method in class org.apache.hadoop.mapreduce.lib.input.FileSplit
The number of bytes in the file to process.
getLength() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
Return the aggregate length of all child InputSplits currently added.
getLength(int) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
Get the length of ith child InputSplit.
getLength() - Method in class org.apache.hadoop.vertica.VerticaInputSplit
 
getLengths() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns an array containing the lengths of the files in the split
getLevel() - Method in class org.apache.hadoop.tools.rumen.Node
Get the level of the node.
getLocalAnalysisClass() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Get the local analysis class.
getLocalCacheArchives() - Method in interface org.apache.hadoop.mapreduce.JobContext
Return the path array of the localized caches
getLocalCacheArchives() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getLocalCacheArchives() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getLocalCacheFiles() - Method in interface org.apache.hadoop.mapreduce.JobContext
Return the path array of the localized files
getLocalCacheFiles() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getLocalCacheFiles() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getLocalDirs() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated.  
getLocalPath(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Constructs a local file name.
getLocation(int) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Deprecated. getLocations from ith InputSplit.
getLocation(int) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
getLocations from ith InputSplit.
getLocation() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
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
Get the list of nodes by name where the data for the split would be local.
getLocations() - Method in class org.apache.hadoop.mapred.FileSplit
Deprecated.  
getLocations() - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
getLocations() - Method in interface org.apache.hadoop.mapred.InputSplit
Deprecated. Get the list of hostnames where the input split is located.
getLocations() - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Deprecated. Collect a set of hosts from all child InputSplits.
getLocations() - Method in class org.apache.hadoop.mapred.MultiFileSplit
Deprecated.  
getLocations() - Method in class org.apache.hadoop.mapreduce.InputSplit
Get the list of nodes by name where the data for the split would be local.
getLocations() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit
Get the list of nodes by name where the data for the split would be local.
getLocations() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns all the Paths where this input-split resides
getLocations() - Method in class org.apache.hadoop.mapreduce.lib.input.FileSplit
 
getLocations() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
Collect a set of hosts from all child InputSplits.
getLocations() - Method in class org.apache.hadoop.mapreduce.split.JobSplit.SplitMetaInfo
 
getLocations() - Method in class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitMetaInfo
 
getLocations() - Method in class org.apache.hadoop.vertica.VerticaInputSplit
Get the list of nodes by name where the data for the split would be local.
getLoggedJob() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
Get the underlining LoggedJob object read directly from the trace.
getLongValue(Object) - Method in class org.apache.hadoop.contrib.utils.join.JobBase
 
getLongValue(Enum) - Method in class org.apache.hadoop.vaidya.statistics.job.JobStatistics
 
getLongValue(Enum) - Method in interface org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface
 
getLongValue(Enum) - Method in class org.apache.hadoop.vaidya.statistics.job.TaskStatistics
 
getLowerClause() - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat.DataDrivenDBInputSplit
 
getMachineByName(String) - Method in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
getMachineByName(String) - Method in interface org.apache.hadoop.tools.rumen.ClusterStory
Get MachineNode by its host name.
getMachines() - Method in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
getMachines() - Method in interface org.apache.hadoop.tools.rumen.ClusterStory
Get all machines of the cluster.
getMachinesInRack() - Method in class org.apache.hadoop.tools.rumen.RackNode
Get the machine nodes that belong to the rack.
getMapContext(MapContext<KEYIN, VALUEIN, KEYOUT, VALUEOUT>) - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper
Get a wrapped WrappedMapper.Context for custom implementations.
getMapCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the map counters for the job
getMapDebugScript() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the map task's debug script.
getMapFinished() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of maps that finished
getMapFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the map finish time.
getMapInputBytes() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getMapInputRecords() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getMapOutputBytes() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getMapOutputCompressorClass(Class<? extends CompressionCodec>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the CompressionCodec for compressing the map outputs.
getMapOutputKeyClass() - Static method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateMapper
Get the map output key class.
getMapOutputKeyClass() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the key class for the map output data.
getMapOutputKeyClass() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the key class for the map output data.
getMapOutputKeyClass() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getMapOutputKeyClass() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getMapOutputRecords() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getMapOutputValueClass() - Static method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateMapper
Get the map output value class.
getMapOutputValueClass() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the value class for the map output data.
getMapOutputValueClass() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the value class for the map output data.
getMapOutputValueClass() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getMapOutputValueClass() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getMapper() - Method in class org.apache.hadoop.mapred.MapRunner
 
getMapperClass() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the Mapper class for the job.
getMapperClass() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the Mapper class for the job.
getMapperClass(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
Get the application's mapper class.
getMapperClass() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getMapperClass() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getMapperMaxSkipRecords(Configuration) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Get the number of acceptable skip records surrounding the bad record PER bad record in mapper.
getMapperTriesToSucceed() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getMapProgress() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getMapredJobID() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
getMapredTempDir() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Get the Map/Reduce temp directory.
getMapRunnerClass() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the MapRunnable class for the job.
getMapRuntime() - Method in class org.apache.hadoop.tools.rumen.MapTaskAttemptInfo
Get the runtime for the map phase of the map-task attempt.
getMapSlotCapacity() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the total number of map slots in the cluster.
getMapSlots() - Method in class org.apache.hadoop.tools.rumen.MachineNode
Get the number of map slots of the node.
getMapSpeculativeExecution() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Should speculative execution be used for this job for map tasks? Defaults to true.
getMapStarted() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of maps that were started
getMapTaskAttemptInfoAdjusted(int, int, int) - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get TaskAttemptInfo for a given task-attempt, considering impact of locality.
getMapTaskAttemptInfoAdjusted(int, int, int) - Method in class org.apache.hadoop.tools.rumen.ZombieJob
Get a TaskAttemptInfo with a TaskAttemptID associated with taskType, taskNumber, and taskAttemptNumber.
getMapTaskList(Enum, JobStatisticsInterface.KeyDataType) - Method in class org.apache.hadoop.vaidya.statistics.job.JobStatistics
 
getMapTaskList(Enum, JobStatisticsInterface.KeyDataType) - Method in interface org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface
 
getMapTaskReports(JobID) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get the information of the current state of the map tasks of a job.
getMapTaskReports(String) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Applications should rather use JobClient.getMapTaskReports(JobID)
getMapTasks() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Get the number of currently running map tasks in the cluster.
getMapTasks() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.AnalyzedJob
Get the map tasks list
getMapTasks() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getMaximum() - Method in class org.apache.hadoop.tools.rumen.LoggedDiscreteCDF
 
getMaximumDistance() - Method in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
getMaximumDistance() - Method in interface org.apache.hadoop.tools.rumen.ClusterStory
Get the maximum distance possible between any two nodes.
getMaxMapAttempts() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the configured number of maximum attempts that will be made to run a map task, as specified by the mapreduce.map.maxattempts property.
getMaxMapAttempts() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the configured number of maximum attempts that will be made to run a map task, as specified by the mapred.map.max.attempts property.
getMaxMapAttempts() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getMaxMapAttempts() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getMaxMapTaskFailuresPercent() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the maximum percentage of map tasks that can fail without the job being aborted.
getMaxMapTasks() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Get the maximum capacity for running map tasks in the cluster.
getMaxPhysicalMemoryForTask() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. this variable is deprecated and nolonger in use.
getMaxRAMSizeInBytes() - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Get the max ram index size in bytes.
getMaxReduceAttempts() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the configured number of maximum attempts that will be made to run a reduce task, as specified by the mapreduce.reduce.maxattempts property.
getMaxReduceAttempts() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the configured number of maximum attempts that will be made to run a reduce task, as specified by the mapred.reduce.max.attempts property.
getMaxReduceAttempts() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getMaxReduceAttempts() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getMaxReduceTaskFailuresPercent() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the maximum percentage of reduce tasks that can fail without the job being aborted.
getMaxReduceTasks() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Get the maximum capacity for running reduce tasks in the cluster.
getMaxSplitSize(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Get the maximum split size.
getMaxTaskFailuresPerTracker() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Expert: Get the maximum no.
getMaxVirtualMemoryForTask() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Use JobConf.getMemoryForMapTask() and JobConf.getMemoryForReduceTask()
getMemory() - Method in class org.apache.hadoop.tools.rumen.MachineNode
Get the available physical RAM of the node.
getMemoryForMapTask() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get memory required to run a map task of the job, in MB.
getMemoryForReduceTask() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get memory required to run a reduce task of the job, in MB.
getMemoryPerMapSlot() - Method in class org.apache.hadoop.tools.rumen.MachineNode
Get the amount of RAM reserved for each map slot.
getMemoryPerReduceSlot() - Method in class org.apache.hadoop.tools.rumen.MachineNode
Get the amount of RAM reserved for each reduce slot.
getMergeRuntime() - Method in class org.apache.hadoop.tools.rumen.ReduceTaskAttemptInfo
Get the runtime for the merge phase of the reduce task-attempt
getMessage() - Method in exception org.apache.hadoop.mapred.InvalidInputException
Get a summary message of the problems found.
getMessage() - Method in exception org.apache.hadoop.mapreduce.lib.input.InvalidInputException
Get a summary message of the problems found.
getMessage() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
getMinimum() - Method in class org.apache.hadoop.tools.rumen.LoggedDiscreteCDF
 
getMinSplitSize(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Get the minimum split size
getName() - Method in class org.apache.hadoop.examples.dancing.Pentomino.Piece
 
getName() - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated. Returns raw name of the group.
getName() - Method in class org.apache.hadoop.mapreduce.Counter
 
getName() - Method in class org.apache.hadoop.mapreduce.CounterGroup
Get the internal name of the group
getName() - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get the job name.
getName() - Method in class org.apache.hadoop.tools.rumen.LoggedNetworkTopology
 
getName() - Method in class org.apache.hadoop.tools.rumen.Node
Get the name of the node.
getName() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
 
getNamedOutputFormatClass(JobConf, String) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Returns the named output OutputFormat.
getNamedOutputKeyClass(JobConf, String) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Returns the key class for a named output.
getNamedOutputs() - Method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Returns iterator with the defined name outputs.
getNamedOutputsList(JobConf) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Returns list of channel names.
getNamedOutputValueClass(JobConf, String) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Returns the value class for a named output.
getNext() - Method in class org.apache.hadoop.tools.rumen.DefaultInputDemuxer
 
getNext() - Method in interface org.apache.hadoop.tools.rumen.InputDemuxer
Get the next pair.
getNextJob() - Method in interface org.apache.hadoop.tools.rumen.JobStoryProducer
Get the next job.
getNextJob() - Method in class org.apache.hadoop.tools.rumen.ZombieJobProducer
 
getNode() - Method in class org.apache.hadoop.mapred.join.Parser.NodeToken
Deprecated.  
getNode() - Method in class org.apache.hadoop.mapred.join.Parser.Token
Deprecated.  
getNode() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.NodeToken
 
getNode() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Token
 
getNum() - Method in class org.apache.hadoop.mapred.join.Parser.NumToken
Deprecated.  
getNum() - Method in class org.apache.hadoop.mapred.join.Parser.Token
Deprecated.  
getNum() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.NumToken
 
getNum() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Token
 
getNumberColumns() - Method in class org.apache.hadoop.examples.dancing.DancingLinks
Get the number of columns.
getNumberMaps() - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get the number of maps in the JobStory.
getNumberMaps() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
 
getNumberOfThreads(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
The number of threads in the thread pool that will run the map function.
getNumberReduces() - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get the number of reduce in the JobStory.
getNumberReduces() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
 
getNumberValues() - Method in class org.apache.hadoop.tools.rumen.LoggedDiscreteCDF
 
getNumCores() - Method in class org.apache.hadoop.tools.rumen.MachineNode
Get the number of cores of the node.
getNumExcludedNodes() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Get the number of excluded hosts in the cluster.
getNumFailedCleanups() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of failed cleanup tasks
getNumFailedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of failed maps
getNumFailedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of failed reduces
getNumFailedSetups() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of failed set up tasks
getNumFinishedCleanups() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of cleanup tasks that finished
getNumFinishedSetups() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of finished set up tasks
getNumKilledCleanups() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of killed cleanup tasks
getNumKilledMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of killed maps
getNumKilledReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of killed reduces
getNumKilledSetups() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of killed set up tasks
getNumLinesPerSplit(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
Get the number of lines per split
getNumLoggedMaps() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
Getting the number of map tasks that are actually logged in the trace.
getNumLoggedReduces() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
Getting the number of reduce tasks that are actually logged in the trace.
getNumMaps() - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
getNumMapTasks() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get configured the number of reduce tasks for this job.
getNumOfKeyFields() - Method in class org.apache.hadoop.streaming.PipeMapper
 
getNumOfKeyFields() - Method in class org.apache.hadoop.streaming.PipeMapRed
Returns the number of key fields.
getNumOfKeyFields() - Method in class org.apache.hadoop.streaming.PipeReducer
 
getNumPaths() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns the number of Paths in the split
getNumReduceTasks() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get configured the number of reduce tasks for this job.
getNumReduceTasks() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get configured the number of reduce tasks for this job.
getNumReduceTasks() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getNumReduceTasks() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getNumTasksToExecutePerJvm() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the number of tasks that a spawned JVM should execute
getOccupiedMapSlots() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get number of occupied map slots in the cluster.
getOccupiedReduceSlots() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of occupied reduce slots in the cluster.
getOffset(int) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns the start offset of the ith Path
getOp() - Method in class org.apache.hadoop.contrib.index.example.LineDocTextAndOp
Get the type of the operation.
getOp() - Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
Get the type of operation.
getOperations() - Method in class org.apache.hadoop.mapreduce.QueueAclsInfo
Get opearations allowed on queue.
getOptimizePollTimeout() - Method in class org.apache.hadoop.vertica.VerticaConfiguration
Returns poll timer for optimize loop
getOtherTasks() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getOutcome() - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get the outcome of the job execution.
getOutcome() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getOutcome() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
 
getOutputBytes() - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
getOutputBytes() - Method in class org.apache.hadoop.tools.rumen.TaskInfo
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.examples.terasort.TeraOutputFormat
 
getOutputCommitter() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the OutputCommitter implementation for the map-reduce job, defaults to FileOutputCommitter if not specified explicitly.
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat
 
getOutputCommitter() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.LazyOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.NullOutputFormat
 
getOutputCommitter() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputFormat
Get the output committer for this output format.
getOutputCommitter() - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Get the OutputCommitter for the task-attempt.
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.vertica.VerticaOutputFormat
(@inheritDoc)
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.vertica.VerticaStreamingOutput
 
getOutputCompressionType(JobConf) - Static method in class org.apache.hadoop.mapred.SequenceFileOutputFormat
Deprecated. Get the SequenceFile.CompressionType for the output SequenceFile.
getOutputCompressionType(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileOutputFormat
Get the SequenceFile.CompressionType for the output SequenceFile.
getOutputCompressorClass(JobConf, Class<? extends CompressionCodec>) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
Get the CompressionCodec for compressing the job outputs.
getOutputCompressorClass(JobContext, Class<? extends CompressionCodec>) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Get the CompressionCodec for compressing the job outputs.
getOutputDelimiter() - Method in class org.apache.hadoop.vertica.VerticaConfiguration
For streaming return the delimiter used by the reducer
getOutputFieldCount() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getOutputFieldNames() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getOutputFormat() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the OutputFormat implementation for the map-reduce job, defaults to TextOutputFormat if not specified explicity.
getOutputFormatClass() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the OutputFormat class for the job.
getOutputFormatClass() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getOutputFormatClass() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getOutputKeyClass() - Static method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateReducer
Get the reduce output key class.
getOutputKeyClass() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the key class for the job output data.
getOutputKeyClass() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the key class for the job output data.
getOutputKeyClass() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getOutputKeyClass() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getOutputKeyClass() - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Returns the resolved output key class.
getOutputKeyComparator() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the RawComparator comparator used to compare keys.
getOutputName(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Get the base output name for the output file.
getOutputPath(JobConf) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
Get the Path to the output directory for the map-reduce job.
getOutputPath(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Get the Path to the output directory for the map-reduce job.
getOutputReaderClass() - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Returns the resolved OutputReader class.
getOutputRecords() - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
getOutputRecords() - Method in class org.apache.hadoop.tools.rumen.TaskInfo
 
getOutputRecordTerminator() - Method in class org.apache.hadoop.vertica.VerticaConfiguration
For streaming return the record terminator used by the reducer
getOutputReplication(JobContext) - Static method in class org.apache.hadoop.examples.terasort.TeraSort
 
getOutputTableDef() - Method in class org.apache.hadoop.vertica.VerticaConfiguration
Return definition of columns for output table
getOutputTableName() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getOutputTableName() - Method in class org.apache.hadoop.vertica.VerticaConfiguration
Get the table that is the target of output
getOutputValueClass() - Static method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateReducer
Get the reduce output value class.
getOutputValueClass() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the value class for job outputs.
getOutputValueClass() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the value class for job outputs.
getOutputValueClass() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getOutputValueClass() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getOutputValueClass() - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Returns the resolved output value class.
getOutputValueGroupingComparator() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the user defined WritableComparable comparator for grouping keys of inputs to the reduce.
getParamsQuery() - Method in class org.apache.hadoop.vertica.VerticaConfiguration
Return the query used to retrieve parameters for the input query (if set)
getParent() - Method in class org.apache.hadoop.tools.rumen.Node
Get the parent node.
getParser(RewindableInputStream) - Static method in class org.apache.hadoop.tools.rumen.JobHistoryParserFactory
 
getPartition(Shard, IntermediateForm, int) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdatePartitioner
 
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(Text, Text, int) - Method in class org.apache.hadoop.examples.terasort.TeraSort.SimplePartitioner
 
getPartition(K2, V2, int) - Method in class org.apache.hadoop.mapred.lib.HashPartitioner
Deprecated. Use Object.hashCode() to partition.
getPartition(K2, V2, int) - Method in interface org.apache.hadoop.mapred.Partitioner
Deprecated. Get the paritition number for a given key (hence record) given the total number of partitions i.e.
getPartition(BinaryComparable, V, int) - Method in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
Use (the specified slice of the array returned by) BinaryComparable.getBytes() to partition.
getPartition(K, V, int) - Method in class org.apache.hadoop.mapreduce.lib.partition.HashPartitioner
Use Object.hashCode() to partition.
getPartition(K2, V2, int) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
 
getPartition(int, int) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
 
getPartition(K, V, int) - Method in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
getPartition(KEY, VALUE, int) - Method in class org.apache.hadoop.mapreduce.Partitioner
Get the partition number for a given key (hence record) given the total number of partitions i.e.
getPartitionerClass() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the Partitioner used to partition Mapper-outputs to be sent to the Reducers.
getPartitionerClass() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the Partitioner class for the job.
getPartitionerClass() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getPartitionerClass() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getPartitionFile(Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
Get the path to the SequenceFile storing the sorted partition keyset.
getPath() - Method in class org.apache.hadoop.mapred.FileSplit
Deprecated. The file containing this split's data.
getPath(int) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns the ith Path
getPath() - Method in class org.apache.hadoop.mapreduce.lib.input.FileSplit
The file containing this split's data.
getPathForCustomFile(JobConf, String) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
Helper function to generate a Path for a file that is unique for the task within the job output directory.
getPathForWorkFile(TaskInputOutputContext<?, ?, ?, ?>, String, String) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Helper function to generate a Path for a file that is unique for the task within the job output directory.
getPaths() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns all the Paths in the split
getPhysicalMemorySize() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin.ProcResourceValues
Obtain the physical memory size used by current process tree.
getPolicy(Configuration, JobCreator) - Static method in enum org.apache.hadoop.mapred.gridmix.JobCreator
 
getPoolSize() - Method in class org.apache.hadoop.mapred.gridmix.RandomAlgorithms.Selector
Get the remaining random number pool size.
getPos() - Method in class org.apache.hadoop.contrib.index.example.LineDocRecordReader
 
getPos() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Unsupported (returns zero in all cases).
getPos() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Request position from proxied RR.
getPos() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
Deprecated.  
getPos() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated. return the amount of data processed
getPos() - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBRecordReader
Deprecated.  
getPos() - Method in interface org.apache.hadoop.mapred.RecordReader
Returns the current position in the input.
getPos() - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Deprecated.  
getPos() - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
Deprecated.  
getPos() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
getPos() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Deprecated.  
getPos() - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
Returns the current position in the input.
getPos() - Method in class org.apache.hadoop.vertica.VerticaRecordReader
 
getPos() - Method in class org.apache.hadoop.vertica.VerticaStreamingRecordReader
 
getPreferredLocations() - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
getPrescription() - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
getPrescription() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.BalancedReducePartitioning
 
getPrescription() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.MapSideDiskSpill
 
getPrescription() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.MapsReExecutionImpact
 
getPrescription() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.ReadingHDFSFilesAsSideEffect
 
getPrescription() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.ReducesReExecutionImpact
 
getPriority() - Method in class org.apache.hadoop.mapreduce.Job
Get scheduling info of the job.
getPriority() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the priority of this job
getPriority() - Method in class org.apache.hadoop.mapreduce.JobStatus
Return the priority of the job
getPriority() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getProblems() - Method in exception org.apache.hadoop.mapred.InvalidInputException
Get the complete list of the problems reported.
getProblems() - Method in exception org.apache.hadoop.mapreduce.lib.input.InvalidInputException
Get the complete list of the problems reported.
getProfileEnabled() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get whether the task profiling is enabled.
getProfileEnabled() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get whether the task profiling is enabled.
getProfileEnabled() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getProfileEnabled() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getProfileParams() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the profiler configuration arguments.
getProfileParams() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the profiler configuration arguments.
getProfileParams() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getProfileParams() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getProfileTaskRange(boolean) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the range of maps or reduces to profile.
getProfileTaskRange(boolean) - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the range of maps or reduces to profile.
getProfileTaskRange(boolean) - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getProfileTaskRange(boolean) - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getProgress() - Method in class org.apache.hadoop.contrib.index.example.LineDocRecordReader
 
getProgress() - Method in class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
getProgress() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Report progress as the minimum of all child RR progress.
getProgress() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Request progress from proxied RR.
getProgress() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
Deprecated.  
getProgress() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated. return progress based on the amount of data processed so far.
getProgress() - Method in interface org.apache.hadoop.mapred.RecordReader
How much of the input has the RecordReader consumed i.e.
getProgress() - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Deprecated. Return the progress within the input split
getProgress() - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
Deprecated.  
getProgress() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
Return the progress within the input split
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
The current progress of the record reader through its data.
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
return progress based on the amount of data processed so far.
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Return the progress within the input split
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextRecordReader
 
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
Return the progress within the input split
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Report progress as the minimum of all child RR progress.
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Request progress from proxied RR.
getProgress() - Method in class org.apache.hadoop.mapreduce.RecordReader
The current progress of the record reader through its data.
getProgress() - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
 
getProgress() - Method in class org.apache.hadoop.vertica.VerticaRecordReader
 
getProgress() - Method in class org.apache.hadoop.vertica.VerticaStreamingRecordReader
 
getProgressible() - Method in interface org.apache.hadoop.mapred.JobContext
Deprecated. Get the progress mechanism for reporting progress.
getProgressible() - Method in interface org.apache.hadoop.mapred.TaskAttemptContext
Deprecated.  
getProgressPollInterval(Configuration) - Static method in class org.apache.hadoop.mapreduce.Job
The interval at which monitorAndPrintJob() prints status
getProperties() - Method in class org.apache.hadoop.mapreduce.QueueInfo
Get properties.
getQueue(String) - Method in class org.apache.hadoop.mapreduce.Cluster
Get queue information for the specified name.
getQueue() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getQueueAclsForCurrentUser() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Gets the Queue ACLs for current user
getQueueAclsForCurrentUser() - Method in class org.apache.hadoop.mapreduce.Cluster
Gets the Queue ACLs for current user
getQueueChildren() - Method in class org.apache.hadoop.mapreduce.QueueInfo
Get immediate children.
getQueueInfo(String) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Gets the queue information associated to a particular Job Queue
getQueueName() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Return the name of the queue to which this job is submitted.
getQueueName() - Method in class org.apache.hadoop.mapreduce.QueueAclsInfo
Get queue name.
getQueueName() - Method in class org.apache.hadoop.mapreduce.QueueInfo
Get the queue name from JobQueueInfo
getQueueName() - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get the queue where the job is submitted.
getQueueName() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
 
getQueues() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Return an array of queue information objects about all the Job Queues configured.
getQueues() - Method in class org.apache.hadoop.mapreduce.Cluster
Get all the queues in cluster.
getRackByName(String) - Method in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
getRackByName(String) - Method in interface org.apache.hadoop.tools.rumen.ClusterStory
Get RackNode by its name.
getRackNode() - Method in class org.apache.hadoop.tools.rumen.MachineNode
Get the rack node that the machine belongs to.
getRacks() - Method in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
getRacks() - Method in interface org.apache.hadoop.tools.rumen.ClusterStory
Get all racks of the cluster.
getRandomId() - Static method in class org.apache.hadoop.tools.DistCp
 
getRandomMachines(int, Random) - Method in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
getRandomMachines(int, Random) - Method in interface org.apache.hadoop.tools.rumen.ClusterStory
Select a random set of machines.
getRankingAt(int) - Method in class org.apache.hadoop.tools.rumen.CDFRandomGenerator
 
getRankings() - Method in class org.apache.hadoop.tools.rumen.LoggedDiscreteCDF
 
getReaders(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.mapred.MapFileOutputFormat
Deprecated. Open the output generated by this format.
getReaders(Configuration, Path) - Static method in class org.apache.hadoop.mapred.SequenceFileOutputFormat
Deprecated. Open the output generated by this format.
getReaders(Path, Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.output.MapFileOutputFormat
Open the output generated by this format.
getReadyJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
Deprecated.  
getReadyJobsList() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getReasonForBlacklist() - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
Gets the reason for which the tasktracker was blacklisted.
getReasonForBlackListing() - Method in class org.apache.hadoop.mapred.ClusterStatus.BlackListInfo
Deprecated. Gets the reason for which the tasktracker was blacklisted.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.contrib.index.example.LineDocInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated.  
getRecordReader(InputSplit, JobConf, Reporter) - Method in interface org.apache.hadoop.mapred.InputFormat
Deprecated. Get the RecordReader for the given InputSplit.
getRecordReader(InputSplit, JobConf, Reporter) - Method in interface org.apache.hadoop.mapred.join.ComposableInputFormat
Deprecated.  
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.join.CompositeInputFormat
Deprecated. Construct a CompositeRecordReader for the children of this InputFormat as defined in the init expression.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.KeyValueTextInputFormat
Deprecated.  
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
Deprecated. This is not implemented yet.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
Deprecated. Get the RecordReader for the given InputSplit.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.NLineInputFormat
Deprecated.  
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.MultiFileInputFormat
Deprecated.  
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat
Deprecated.  
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.SequenceFileAsTextInputFormat
Deprecated.  
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter
Deprecated. Create a record reader for the given split
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.SequenceFileInputFormat
Deprecated.  
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.TextInputFormat
Deprecated.  
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.streaming.AutoInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.streaming.StreamInputFormat
 
getRecordReaderQueue() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Return sorted list of RecordReaders for this composite.
getRecordReaderQueue() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Return sorted list of RecordReaders for this composite.
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.examples.terasort.TeraOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.FileOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.db.DBOutputFormat
Deprecated. Get the RecordWriter for the given job.
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.FilterOutputFormat
Deprecated.  
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.LazyOutputFormat
Deprecated.  
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
Deprecated. Create a composite record writer that can write key/value data to different output files
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.NullOutputFormat
Deprecated.  
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.MapFileOutputFormat
Deprecated.  
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in interface org.apache.hadoop.mapred.OutputFormat
Deprecated. Get the RecordWriter for the given job.
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
Deprecated.  
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.SequenceFileOutputFormat
Deprecated.  
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.TextOutputFormat
Deprecated.  
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat
Get the RecordWriter for the given task.
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.LazyOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.MapFileOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.NullOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.TextOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputFormat
Get the RecordWriter for the given task.
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.vertica.VerticaOutputFormat
Get the RecordWriter for the given task.
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.vertica.VerticaStreamingOutput
 
getReduceCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the reduce counters for the job
getReduceDebugScript() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the reduce task's debug Script
getReduceDurations(int) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
getReduceFinished() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of reducers that finished
getReduceInputGroups() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getReduceInputRecords() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getReduceOutputRecords() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getReduceProgress() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getReducerClass() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the Reducer class for the job.
getReducerClass() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the Reducer class for the job.
getReducerClass() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getReducerClass() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getReducerContext(ReduceContext<KEYIN, VALUEIN, KEYOUT, VALUEOUT>) - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer
A a wrapped WrappedReducer.Context for custom implementations.
getReducerMaxSkipGroups(Configuration) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Get the number of acceptable skip groups surrounding the bad group PER bad group in reducer.
getReduceRuntime() - Method in class org.apache.hadoop.tools.rumen.ReduceTaskAttemptInfo
Get the runtime for the reduce phase of the reduce task-attempt.
getReduceShuffleBytes() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getReduceSlotCapacity() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the total number of reduce slots in the cluster.
getReduceSlots() - Method in class org.apache.hadoop.tools.rumen.MachineNode
Get the number of reduce slots of the node.
getReduceSpeculativeExecution() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Should speculative execution be used for this job for reduce tasks? Defaults to true.
getReduceStarted() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of Reducers that were started
getReduceTaskList(Enum, JobStatisticsInterface.KeyDataType) - Method in class org.apache.hadoop.vaidya.statistics.job.JobStatistics
 
getReduceTaskList(Enum, JobStatisticsInterface.KeyDataType) - Method in interface org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface
 
getReduceTaskReports(JobID) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get the information of the current state of the reduce tasks of a job.
getReduceTaskReports(String) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Applications should rather use JobClient.getReduceTaskReports(JobID)
getReduceTasks() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Get the number of currently running reduce tasks in the cluster.
getReduceTasks() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.AnalyzedJob
Get the reduce tasks list
getReduceTasks() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getReferenceDetails() - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
getReferenceDetails() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.BalancedReducePartitioning
 
getReferenceDetails() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.MapSideDiskSpill
 
getReferenceDetails() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.MapsReExecutionImpact
 
getReferenceDetails() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.ReadingHDFSFilesAsSideEffect
 
getReferenceDetails() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.ReducesReExecutionImpact
 
getRelativeRanking() - Method in class org.apache.hadoop.tools.rumen.LoggedSingleRelativeRanking
 
getRelativeTime() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getReport() - Method in class org.apache.hadoop.contrib.utils.join.JobBase
log the counters
getReport() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.DoubleValueSum
 
getReport() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMax
 
getReport() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMin
 
getReport() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueSum
 
getReport() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMax
 
getReport() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMin
 
getReport() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
 
getReport() - Method in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregator
 
getReport() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueHistogram
 
getReport() - Method in class org.apache.hadoop.vaidya.JobDiagnoser
 
getReportDetails() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueHistogram
 
getReportElement(Document, Node, int) - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
getReportFile() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.PostExPerformanceDiagnoser
 
getReportItems() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueHistogram
 
getRepresentingCharacter(TaskType) - Static method in class org.apache.hadoop.mapreduce.TaskID
Gets the character representing the TaskType
getReservedMapSlots() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get number of reserved map slots in the cluster.
getReservedReduceSlots() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of reserved reduce slots in the cluster.
getResult() - Method in class org.apache.hadoop.examples.Sort
Get the last job that was run using this instance.
getResult() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getRootQueues() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Returns an array of queue information objects about root level queues configured
getRootQueues() - Method in class org.apache.hadoop.mapreduce.Cluster
Gets the root level queues.
getRotations() - Method in class org.apache.hadoop.examples.dancing.Pentomino.Piece
 
getRunningJobList() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getRunningJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
Deprecated.  
getRunningMaps() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of running map tasks in the cluster.
getRunningReduces() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of running reduce tasks in the cluster.
getRunningTaskAttempts() - Method in class org.apache.hadoop.mapred.TaskReport
Deprecated. Get the running task attempt IDs for this task
getRunState() - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
getRunState() - Method in class org.apache.hadoop.tools.rumen.TaskAttemptInfo
Get the final TaskStatus.State of the task-attempt.
getRuntime() - Method in class org.apache.hadoop.tools.rumen.MapTaskAttemptInfo
 
getRuntime() - Method in class org.apache.hadoop.tools.rumen.ReduceTaskAttemptInfo
 
getRuntime() - Method in class org.apache.hadoop.tools.rumen.TaskAttemptInfo
Get the total runtime for the task-attempt.
getSample(InputFormat<K, V>, Job) - Method in class org.apache.hadoop.mapreduce.lib.partition.InputSampler.IntervalSampler
For each split sampled, emit when the ratio of the number of records retained to the total record count is less than the specified frequency.
getSample(InputFormat<K, V>, Job) - Method in class org.apache.hadoop.mapreduce.lib.partition.InputSampler.RandomSampler
Randomize the split order, then take the specified number of keys from each split sampled, where each key is selected with the specified probability and possibly replaced by a subsequently selected key when the quota of keys from that split is satisfied.
getSample(InputFormat<K, V>, Job) - Method in interface org.apache.hadoop.mapreduce.lib.partition.InputSampler.Sampler
For a given job, collect and return a subset of the keys from the input data.
getSample(InputFormat<K, V>, Job) - Method in class org.apache.hadoop.mapreduce.lib.partition.InputSampler.SplitSampler
From each split sampled, take the first numSamples / numSplits records.
getSchedulingInfo() - Method in class org.apache.hadoop.mapreduce.Job
Get scheduling info of the job.
getSchedulingInfo() - Method in class org.apache.hadoop.mapreduce.JobStatus
Gets the Scheduling information associated to a particular Job.
getSchedulingInfo() - Method in class org.apache.hadoop.mapreduce.QueueInfo
Gets the scheduling information associated to particular job queue.
getSecond() - Method in class org.apache.hadoop.examples.SecondarySort.IntPair
 
getSecretKey(Credentials, Text) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
auxiliary method to get user's secret keys..
getSeed(String, long) - Static method in class org.apache.hadoop.tools.rumen.RandomSeedGenerator
Generates a new random seed.
getSegmentParams() - Method in class org.apache.hadoop.vertica.VerticaInputSplit
Return the parameters used for input query
getSelectQuery() - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBRecordReader
Returns the query for selecting the records, subclasses can override this for custom behaviour.
getSelectQuery() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Returns the query for selecting the records, subclasses can override this for custom behaviour.
getSelectQuery() - Method in class org.apache.hadoop.mapreduce.lib.db.OracleDBRecordReader
Returns the query for selecting the records from an Oracle DB.
getSequenceFileOutputKeyClass(JobConf) - Static method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
Deprecated. Get the key class for the SequenceFile
getSequenceFileOutputKeyClass(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
Get the key class for the SequenceFile
getSequenceFileOutputValueClass(JobConf) - Static method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
Deprecated. Get the value class for the SequenceFile
getSequenceFileOutputValueClass(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
Get the value class for the SequenceFile
getSequenceWriter(TaskAttemptContext, Class<?>, Class<?>) - Method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileOutputFormat
 
getSessionId() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. 
getSetupFinished() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of setup tasks that finished
getSetupProgress() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getSetupStarted() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of setup tasks that started
getSetupTaskReports(JobID) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get the information of the current state of the setup tasks of a job.
getSeverityLevel() - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
getShape(boolean, int) - Method in class org.apache.hadoop.examples.dancing.Pentomino.Piece
 
getShuffleFinished() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getShuffleFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the shuffle finish time.
getShuffleRuntime() - Method in class org.apache.hadoop.tools.rumen.ReduceTaskAttemptInfo
Get the runtime for the shuffle phase of the reduce task-attempt.
getSize() - Method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat.WritableValueBytes
 
getSkipOutputPath(Configuration) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Get the directory to which skipped records are written.
getSortComparator() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the RawComparator comparator used to compare keys.
getSortComparator() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getSortComparator() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getSortFinished() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getSortFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the sort finish time.
getSpeculativeExecution() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Should speculative execution be used for this job? Defaults to true.
getSpilledRecords() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getSplit() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getSplitHosts(BlockLocation[], long, long, NetworkTopology) - Method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. This function identifies and returns the hosts that contribute most for a given split.
getSplitIndex() - Method in class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitMetaInfo
 
getSplitLocation() - Method in class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitIndex
 
getSplitLocation() - Method in class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitMetaInfo
 
getSplitLocations() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
Get the split locations
getSplits(JobContext) - Method in class org.apache.hadoop.examples.BaileyBorweinPlouffe.BbpInputFormat
Logically split the set of input files for the job.
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(JobContext) - Method in class org.apache.hadoop.examples.terasort.TeraInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. Splits files returned by FileInputFormat.listStatus(JobConf) when they're too big.
getSplits(JobContext) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepInputFormat
 
getSplits(JobConf, int) - Method in interface org.apache.hadoop.mapred.InputFormat
Deprecated. Logically split the set of input files for the job.
getSplits(JobConf, int) - Method in class org.apache.hadoop.mapred.join.CompositeInputFormat
Deprecated. Build a CompositeInputSplit from the child InputFormats by assigning the ith split from each child to the ith composite split.
getSplits(JobConf, int) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
Deprecated.  
getSplits(JobConf, int) - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
Deprecated. Logically split the set of input files for the job.
getSplits(JobConf, int) - Method in class org.apache.hadoop.mapred.lib.NLineInputFormat
Deprecated. Logically splits the set of input files for the job, splits N lines of the input as one split.
getSplits(JobConf, int) - Method in class org.apache.hadoop.mapred.MultiFileInputFormat
Deprecated.  
getSplits(JobContext) - Method in class org.apache.hadoop.mapreduce.InputFormat
Logically split the set of input files for the job.
getSplits(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
Logically split the set of input files for the job.
getSplits(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
Logically split the set of input files for the job.
getSplits(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
 
getSplits(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Generate the list of files and make them into FileSplits.
getSplits(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
Logically splits the set of input files for the job, splits N lines of the input as one split.
getSplits(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
Build a CompositeInputSplit from the child InputFormats by assigning the ith split from each child to the ith composite split.
getSplits(JobContext) - Method in class org.apache.hadoop.vertica.VerticaInputFormat
Logically split the set of input files for the job.
getSplits(JobContext) - Method in class org.apache.hadoop.vertica.VerticaStreamingInput
 
getSplits(JobContext) - Static method in class org.apache.hadoop.vertica.VerticaUtil
 
getSplitsForFile(FileStatus, Configuration, int) - Static method in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
 
getSplitter(int) - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
 
getSplitter(int) - Method in class org.apache.hadoop.mapreduce.lib.db.OracleDataDrivenDBInputFormat
 
getStagingAreaDir() - Method in class org.apache.hadoop.mapreduce.Cluster
Grab the jobtracker's view of the staging directory path where job-specific files will be placed.
getStart() - Method in class org.apache.hadoop.mapred.FileSplit
Deprecated. The position of the first byte in the file to process.
getStart() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit
 
getStart() - Method in class org.apache.hadoop.mapreduce.lib.input.FileSplit
The position of the first byte in the file to process.
getStart() - Method in class org.apache.hadoop.vertica.VerticaInputSplit
 
getStartOffset() - Method in class org.apache.hadoop.mapreduce.split.JobSplit.SplitMetaInfo
 
getStartOffset() - Method in class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitIndex
 
getStartOffset() - Method in class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitMetaInfo
 
getStartOffsets() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns an array containing the start offsets of the files in the split
getStartTime() - Method in class org.apache.hadoop.mapreduce.Job
Get start time of the job.
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the start time of the attempt
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
Get the start time of this task
getStartTime() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getStartTime() - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
getStartTime() - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
getState() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated.  
getState() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
Deprecated.  
getState() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the state
getState() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getState() - Method in class org.apache.hadoop.mapreduce.QueueInfo
Return the queue state
getState(String) - Static method in enum org.apache.hadoop.mapreduce.QueueState
 
getStatement() - Method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat.DBRecordWriter
 
getStatement() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getStateName() - Method in enum org.apache.hadoop.mapreduce.QueueState
 
getStatus() - Method in class org.apache.hadoop.mapreduce.Job
 
getStatus() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getStatus() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getStatus() - Method in interface org.apache.hadoop.mapreduce.TaskAttemptContext
Get the last set status message.
getStatus() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Returns enum Status.SUCESS or Status.FAILURE.
getSteps() - Method in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
Get the number of steps
getStr() - Method in class org.apache.hadoop.mapred.join.Parser.StrToken
Deprecated.  
getStr() - Method in class org.apache.hadoop.mapred.join.Parser.Token
Deprecated.  
getStr() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.StrToken
 
getStr() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Token
 
getStringValue(Enum) - Method in class org.apache.hadoop.vaidya.statistics.job.JobStatistics
 
getStringValue(Enum) - Method in interface org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface
 
getStringValue(Enum) - Method in class org.apache.hadoop.vaidya.statistics.job.TaskStatistics
 
getSubmissionTime() - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get the job submission time.
getSubmissionTime() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
 
getSubmitTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the job submit time
getSubmitTime() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getSuccessfulJobList() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getSuccessfulJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
Deprecated.  
getSuccessfulMapAttemptCDFs() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getSuccessfulReduceAttemptCDF() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getSuccessfulTaskAttempt() - Method in class org.apache.hadoop.mapred.TaskReport
Deprecated. Get the attempt ID that took this task to completion
getSuccessThreshold() - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
getSum() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.DoubleValueSum
 
getSum() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueSum
 
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.
getSymlink() - Method in interface org.apache.hadoop.mapreduce.JobContext
This method checks to see if symlinks are to be create for the localized cache files in the current working directory
getSymlink() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getSymlink() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getSystemDir() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Grab the jobtracker system directory path where job-specific files are to be placed.
getSystemDir() - Method in class org.apache.hadoop.mapreduce.Cluster
Grab the jobtracker system directory path where job-specific files will be placed.
getTableName() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getTag() - Method in class org.apache.hadoop.contrib.utils.join.TaggedMapOutput
 
getTargetUgi(UserGroupInformation) - Method in class org.apache.hadoop.mapred.gridmix.EchoUserResolver
 
getTargetUgi(UserGroupInformation) - Method in class org.apache.hadoop.mapred.gridmix.RoundRobinUserResolver
 
getTargetUgi(UserGroupInformation) - Method in class org.apache.hadoop.mapred.gridmix.SubmitterUserResolver
 
getTaskAttemptID() - Method in interface org.apache.hadoop.mapred.TaskAttemptContext
Deprecated.  
getTaskAttemptId() - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated. Returns task id.
getTaskAttemptID() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getTaskAttemptID() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getTaskAttemptID() - Method in interface org.apache.hadoop.mapreduce.TaskAttemptContext
Get the unique name for this task attempt.
getTaskAttemptId() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Returns task id.
getTaskAttemptIDsPattern(String, Integer, Boolean, Integer, Integer) - Static method in class org.apache.hadoop.mapred.TaskAttemptID
Deprecated. 
getTaskAttemptIDsPattern(String, Integer, TaskType, Integer, Integer) - Static method in class org.apache.hadoop.mapred.TaskAttemptID
Deprecated. 
getTaskAttemptInfo(TaskType, int, int) - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get TaskAttemptInfo for a given task-attempt, without regard to impact of locality (e.g.
getTaskAttemptInfo(TaskType, int, int) - Method in class org.apache.hadoop.tools.rumen.ZombieJob
Get a TaskAttemptInfo with a TaskAttemptID associated with taskType, taskNumber, and taskAttemptNumber.
getTaskCompletionEvents(int) - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Get events indicating completion (success/failure) of component tasks.
getTaskCompletionEvents(int, int) - Method in class org.apache.hadoop.mapreduce.Job
Get events indicating completion (success/failure) of component tasks.
getTaskDiagnostics(TaskAttemptID) - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Gets the diagnostic messages for a given task attempt.
getTaskDiagnostics(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.Job
Gets the diagnostic messages for a given task attempt.
getTaskID() - Method in class org.apache.hadoop.mapred.TaskAttemptID
Deprecated.  
getTaskId() - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated. use TaskCompletionEvent.getTaskAttemptId() instead.
getTaskId() - Method in class org.apache.hadoop.mapred.TaskLogAppender
Getter/Setter methods for log4j.
getTaskID() - Method in class org.apache.hadoop.mapred.TaskReport
Deprecated. The id of the task.
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
Get the Task ID
getTaskID() - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
Returns the TaskID object that this task attempt belongs to
getTaskID() - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
getTaskIDsPattern(String, Integer, Boolean, Integer) - Static method in class org.apache.hadoop.mapred.TaskID
Deprecated. Use TaskID.getTaskIDsPattern(String, Integer, TaskType, Integer)
getTaskIDsPattern(String, Integer, TaskType, Integer) - Static method in class org.apache.hadoop.mapred.TaskID
Deprecated. 
getTaskInfo(TaskType, int) - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get TaskInfo for a given task.
getTaskInfo() - Method in class org.apache.hadoop.tools.rumen.TaskAttemptInfo
Get the TaskInfo for the given task-attempt.
getTaskInfo(TaskType, int) - Method in class org.apache.hadoop.tools.rumen.ZombieJob
 
getTaskLogURL(TaskAttemptID, String) - Static method in class org.apache.hadoop.mapreduce.tools.CLI
 
getTaskMemory() - Method in class org.apache.hadoop.tools.rumen.TaskInfo
 
getTaskOutputFilter(JobConf) - Static method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get the task output filter out of the JobConf.
getTaskOutputFilter() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. 
getTaskOutputFilter(Configuration) - Static method in class org.apache.hadoop.mapreduce.Job
Get the task output filter.
getTaskOutputPath(JobConf, String) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
Helper function to create the task's temporary output directory and return the path to the task's output file.
getTaskReports(TaskType) - Method in class org.apache.hadoop.mapreduce.Job
Get the information of the current state of the tasks of a job.
getTaskRunTime() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Returns time (in millisec) the task took to complete.
getTaskStatus() - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated. Returns enum Status.SUCESS or Status.FAILURE.
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the task status
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
Get the task status
getTaskStatus() - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
getTaskTrackerCount() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of active trackers in the cluster.
getTaskTrackerExpiryInterval() - Method in class org.apache.hadoop.mapreduce.Cluster
Get the tasktracker expiry interval for the cluster
getTaskTrackerHttp() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
http location of the tasktracker where this task ran.
getTaskTrackerName() - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
Gets the tasktracker's name.
getTaskTrackers() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Get the number of task trackers in the cluster.
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
Returns the TaskType of the TaskAttemptID
getTaskType() - Method in class org.apache.hadoop.mapreduce.TaskID
Get the type of the task
getTaskType(char) - Static method in class org.apache.hadoop.mapreduce.TaskID
Gets the TaskType corresponding to the character
getTaskType() - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
getTerm() - Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
Get the term.
getTestsConfFileIs() - Method in class org.apache.hadoop.vaidya.postexdiagnosis.PostExPerformanceDiagnoser
 
getText() - Method in class org.apache.hadoop.contrib.index.example.LineDocTextAndOp
Get the text that represents a document.
getText() - Method in class org.apache.hadoop.contrib.index.mapred.DocumentID
The text of the document id.
getThreadState() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getTitle() - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
getTotalCleanups() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of clean up tasks
getTotalCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the counters for the job
getTotalJobSubmissions() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the total number of job submissions in the cluster.
getTotalLogFileSize() - Method in class org.apache.hadoop.mapred.TaskLogAppender
 
getTotalMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get total maps
getTotalMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the total number of maps
getTotalMaps() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getTotalReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get total reduces
getTotalReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the total number of reduces
getTotalReduces() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getTotalSetups() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of set up tasks
getTrackerName() - Method in class org.apache.hadoop.mapred.ClusterStatus.BlackListInfo
Deprecated. Gets the blacklisted tasktracker's name.
getTrackerName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Get the tracker name where the attempt executed
getTrackingURL() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Get the URL where some job progress information will be displayed.
getTrackingURL() - Method in class org.apache.hadoop.mapreduce.Job
Get the URL where some job progress information will be displayed.
getTrackingUrl() - Method in class org.apache.hadoop.mapreduce.JobStatus
Get the link to the web-ui for details of the job.
getTTExpiryInterval() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. Get the tasktracker expiry interval for the cluster
getType() - Method in class org.apache.hadoop.mapred.join.Parser.Token
Deprecated.  
getType() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Token
 
getType() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritable
Get the type code embedded in the first byte.
getTypes() - Method in class org.apache.hadoop.vertica.VerticaRecord
 
getUniqueFile(TaskAttemptContext, String, String) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Generate a unique filename, based on the task id, name, and extension
getUniqueItems() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
 
getUniqueName(JobConf, String) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
Helper function to generate a name that is unique for the task.
getUpperClause() - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat.DataDrivenDBInputSplit
 
getUri() - Method in class org.apache.hadoop.fs.HarFileSystem
Returns the uri of this filesystem.
getURIs(String, String) - Method in class org.apache.hadoop.streaming.StreamJob
get the uris of all the files/caches
getUseNewMapper() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Should the framework use the new context-object code for running the mapper?
getUseNewReducer() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Should the framework use the new context-object code for running the reducer?
getUser() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the reported username for this job.
getUser() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the reported username for this job.
getUser() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getUser() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getUser() - Method in interface org.apache.hadoop.tools.rumen.JobStory
Get the user who ran the job.
getUser() - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
getUser() - Method in class org.apache.hadoop.tools.rumen.ZombieJob
 
getUsername() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Get the user name
getUsername() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getUseSimplePartitioner(JobContext) - Static method in class org.apache.hadoop.examples.terasort.TeraSort
 
getVal() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMax
 
getVal() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMin
 
getVal() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMax
 
getVal() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMin
 
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
getValue() - Method in class org.apache.hadoop.mapreduce.Counter
What is the current value of this counter?
getValue() - Method in enum org.apache.hadoop.mapreduce.JobStatus.State
 
getValue() - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
getValue() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritable
Get the typed bytes as a Java object.
getValue(Configuration) - Static method in class org.apache.hadoop.vertica.VerticaOutputFormat
 
getValue() - Method in class org.apache.hadoop.vertica.VerticaRecordWriter
 
getValueAggregatorDescriptor(String, Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
getValueClass() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
The class of value that must be passed to SequenceFileRecordReader.next(Object, Object)..
getValueClassName() - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Deprecated. Retrieve the name of the value class for this SequenceFile.
getValueClassName() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Retrieve the name of the value class for this SequenceFile.
getValues() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getValues() - Method in interface org.apache.hadoop.mapreduce.ReduceContext
Iterate through the values for the current key, reusing the same value object, which is stored in the context.
getValues() - Method in class org.apache.hadoop.vertica.VerticaRecord
 
getVersion() - Method in class org.apache.hadoop.contrib.index.mapred.Shard
Get the version number of the entire index.
getVirtualMemorySize() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin.ProcResourceValues
Obtain the virtual memory size used by a current process tree.
getWaitingJobList() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getWaitingJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
Deprecated.  
getWorkingDirectory() - Method in class org.apache.hadoop.fs.HarFileSystem
return the top level archive.
getWorkingDirectory() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Get the current working directory for the default file system.
getWorkingDirectory() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the current working directory for the default file system.
getWorkingDirectory() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getWorkingDirectory() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getWorkOutputPath(JobConf) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
Get the Path to the task's temporary output directory for the map-reduce job

Tasks' Side-Effect Files
getWorkOutputPath(TaskInputOutputContext<?, ?, ?, ?>) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Get the Path to the task's temporary output directory for the map-reduce job

Tasks' Side-Effect Files
getWorkPath() - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Get the directory that the task should write results into
go() - Method in class org.apache.hadoop.streaming.StreamJob
Deprecated. use StreamJob.run(String[]) instead.
Grep - Class in org.apache.hadoop.examples
 
Gridmix - Class in org.apache.hadoop.mapred.gridmix
Driver class for the Gridmix3 benchmark.
Gridmix() - Constructor for class org.apache.hadoop.mapred.gridmix.Gridmix
 
GRIDMIX_JOB_TYPE - Static variable in enum org.apache.hadoop.mapred.gridmix.JobCreator
 
GRIDMIX_OUT_DIR - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
Output (scratch) directory for submitted jobs.
GRIDMIX_QUE_DEP - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
The depth of the queue of job descriptions.
GRIDMIX_SLEEP_INTERVAL - Static variable in class org.apache.hadoop.mapred.gridmix.SleepJob
Interval at which to report progress, in seconds.
GRIDMIX_SLEEP_MAX_MAP_TIME - Static variable in class org.apache.hadoop.mapred.gridmix.SleepJob
 
GRIDMIX_SLEEP_MAX_REDUCE_TIME - Static variable in class org.apache.hadoop.mapred.gridmix.SleepJob
 
GRIDMIX_SUB_MUL - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
Multiplier to accelerate or decelerate job submission.
GRIDMIX_SUB_THR - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
Number of submitting threads at the client and upper bound for in-memory split data.
GRIDMIX_USR_RSV - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
Class used to resolve users in the trace to the list of target users on the cluster.
GROUP - Static variable in class org.apache.hadoop.mapreduce.lib.map.RegexMapper
 


H

Hadoop20JHParser - Class in org.apache.hadoop.tools.rumen
JobHistoryParser to parse job histories for hadoop 0.20 (META=1).
Hadoop20JHParser(InputStream) - Constructor for class org.apache.hadoop.tools.rumen.Hadoop20JHParser
 
HadoopArchives - Class in org.apache.hadoop.tools
a archive creation utility.
HadoopArchives(Configuration) - Constructor for class org.apache.hadoop.tools.HadoopArchives
 
HadoopLogsAnalyzer - Class in org.apache.hadoop.tools.rumen
Deprecated. 
HadoopLogsAnalyzer() - Constructor for class org.apache.hadoop.tools.rumen.HadoopLogsAnalyzer
Deprecated.  
HadoopStreaming - Class in org.apache.hadoop.streaming
The main entry point.
HadoopStreaming() - Constructor for class org.apache.hadoop.streaming.HadoopStreaming
 
HarFileSystem - Class in org.apache.hadoop.fs
This is an implementation of the Hadoop Archive Filesystem.
HarFileSystem() - Constructor for class org.apache.hadoop.fs.HarFileSystem
public construction of harfilesystem
HarFileSystem(FileSystem) - Constructor for class org.apache.hadoop.fs.HarFileSystem
Constructor to create a HarFileSystem with an underlying filesystem.
has(int) - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Return true if tuple has an element at the position provided.
hasChildren() - Method in class org.apache.hadoop.tools.rumen.Node
Does this node have any children?
hashCode() - Method in class org.apache.hadoop.contrib.index.mapred.DocumentID
 
hashCode() - Method in class org.apache.hadoop.contrib.index.mapred.Shard
 
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
 
hashCode() - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated.  
hashCode() - Method in class org.apache.hadoop.mapred.Counters
Deprecated.  
hashCode() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated.  
hashCode() - Method in class org.apache.hadoop.mapreduce.Counter
 
hashCode() - Method in class org.apache.hadoop.mapreduce.CounterGroup
 
hashCode() - Method in class org.apache.hadoop.mapreduce.Counters
 
hashCode() - Method in class org.apache.hadoop.mapreduce.ID
 
hashCode() - Method in class org.apache.hadoop.mapreduce.JobID
 
hashCode() - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
 
hashCode() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
 
hashCode(byte[], int, int, int) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
 
hashCode() - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
 
hashCode() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
hashCode() - Method in class org.apache.hadoop.mapreduce.TaskID
 
hashCode() - Method in class org.apache.hadoop.tools.rumen.MachineNode
 
hashCode() - Method in class org.apache.hadoop.tools.rumen.Node
 
HashingDistributionPolicy - Class in org.apache.hadoop.contrib.index.example
Choose a shard for each insert or delete based on document id hashing.
HashingDistributionPolicy() - Constructor for class org.apache.hadoop.contrib.index.example.HashingDistributionPolicy
 
HashPartitioner<K2,V2> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use HashPartitioner instead.
HashPartitioner() - Constructor for class org.apache.hadoop.mapred.lib.HashPartitioner
Deprecated.  
HashPartitioner<K,V> - Class in org.apache.hadoop.mapreduce.lib.partition
Partition keys by their Object.hashCode().
HashPartitioner() - Constructor for class org.apache.hadoop.mapreduce.lib.partition.HashPartitioner
 
hasNext() - Method in class org.apache.hadoop.contrib.utils.join.ArrayListBackedIterator
 
hasNext() - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
Deprecated. Returns true if the stream is not empty, but provides no guarantee that a call to next(K,V) will succeed.
hasNext() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Return true if it is possible that this could emit more values.
hasNext() - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
Deprecated.  
hasNext() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
Deprecated.  
hasNext() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Return true if the RR- including the k,v pair stored in this object- is exhausted.
hasNext() - Method in class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
 
hasNext() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Return true if it is possible that this could emit more values.
hasNext() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader.JoinCollector
Returns false if exhausted or if reset(K) has not been called.
hasNext() - Method in class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader.JoinDelegationIterator
 
hasNext() - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
hasNext() - Method in class org.apache.hadoop.mapreduce.lib.join.ResetableIterator.EMPTY
 
hasNext() - Method in interface org.apache.hadoop.mapreduce.lib.join.ResetableIterator
True if a call to next may return a value.
hasNext() - Method in class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
 
hasNext() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Return true if the RR- including the k,v pair stored in this object- is exhausted.
hasNext() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
 
hasNext() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterator
 
hasSimpleInputSpecs_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
HEIGHT - Static variable in class org.apache.hadoop.examples.dancing.Pentomino
 
height - Variable in class org.apache.hadoop.examples.dancing.Pentomino
 
HistoryViewer.AnalyzedJob - Class in org.apache.hadoop.mapreduce.jobhistory
Utility class used while analyzing the job.
HistoryViewer.AnalyzedJob(JobHistoryParser.JobInfo) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.AnalyzedJob
Generate analysis information for the parsed job
HistoryViewer.FilteredJob - Class in org.apache.hadoop.mapreduce.jobhistory
Utility to filter out events based on the task status
HistoryViewer.FilteredJob(JobHistoryParser.JobInfo, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.FilteredJob
Apply the filter (status) on the parsed job and generate summary
HistoryViewer.SummarizedJob - Class in org.apache.hadoop.mapreduce.jobhistory
Utility class used the summarize the job.
HistoryViewer.SummarizedJob(JobHistoryParser.JobInfo) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Create summary information for the parsed job
HOSTNAMES_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Host names to connect to, selected from at random

I

ID - Class in org.apache.hadoop.mapred
Deprecated. 
ID(int) - Constructor for class org.apache.hadoop.mapred.ID
Deprecated. constructs an ID object from the given int
ID() - Constructor for class org.apache.hadoop.mapred.ID
Deprecated.  
id() - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
Deprecated. Return the position in the collector this class occupies.
id() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Return the position in the collector this class occupies.
id - Variable in class org.apache.hadoop.mapred.join.Parser.Node
Deprecated.  
id() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Return the position in the collector this class occupies.
ID - Class in org.apache.hadoop.mapreduce
A general identifier, which internally stores the id as an integer.
ID(int) - Constructor for class org.apache.hadoop.mapreduce.ID
constructs an ID object from the given int
ID() - Constructor for class org.apache.hadoop.mapreduce.ID
 
id - Variable in class org.apache.hadoop.mapreduce.ID
 
id() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Return the position in the collector this class occupies.
id - Variable in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
id() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Return the position in the collector this class occupies.
ident - Variable in class org.apache.hadoop.mapred.join.Parser.Node
Deprecated.  
ident - Variable in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
IdentifierResolver - Class in org.apache.hadoop.streaming.io
This class is used to resolve a string identifier into the required IO classes.
IdentifierResolver() - Constructor for class org.apache.hadoop.streaming.io.IdentifierResolver
 
IdentityLocalAnalysis - Class in org.apache.hadoop.contrib.index.example
Identity local analysis maps inputs directly into outputs.
IdentityLocalAnalysis() - Constructor for class org.apache.hadoop.contrib.index.example.IdentityLocalAnalysis
 
IdentityMapper<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use Mapper instead.
IdentityMapper() - Constructor for class org.apache.hadoop.mapred.lib.IdentityMapper
Deprecated.  
IdentityReducer<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use Reducer instead.
IdentityReducer() - Constructor for class org.apache.hadoop.mapred.lib.IdentityReducer
Deprecated.  
idFormat - Static variable in class org.apache.hadoop.mapreduce.JobID
 
idFormat - Static variable in class org.apache.hadoop.mapreduce.TaskID
 
IDistributionPolicy - Interface in org.apache.hadoop.contrib.index.mapred
A distribution policy decides, given a document with a document id, which one shard the request should be sent to if the request is an insert, and which shard(s) the request should be sent to if the request is a delete.
idWithinJob() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
idx - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
idx - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
IIndexUpdater - Interface in org.apache.hadoop.contrib.index.mapred
A class implements an index updater interface should create a Map/Reduce job configuration and run the Map/Reduce job to analyze documents and update Lucene instances in parallel.
ILocalAnalysis<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Interface in org.apache.hadoop.contrib.index.mapred
Application specific local analysis.
incorporateCounters(JhCounters) - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
incorporateCounters(JhCounters) - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
incrAllCounters(Counters) - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Increments multiple counters by their amounts in another Counters instance.
incrAllCounters(CounterGroup) - Method in class org.apache.hadoop.mapreduce.CounterGroup
 
incrAllCounters(Counters) - Method in class org.apache.hadoop.mapreduce.Counters
Increments multiple counters by their amounts in another Counters instance.
incrCounter(Enum, long) - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Increments the specified counter by the specified amount, creating it if it didn't already exist.
incrCounter(String, String, long) - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Increments the specified counter by the specified amount, creating it if it didn't already exist.
incrCounter(Enum<?>, long) - Method in interface org.apache.hadoop.mapred.Reporter
Increments the counter identified by the key, which can be of any Enum type, by the specified amount.
incrCounter(String, String, long) - Method in interface org.apache.hadoop.mapred.Reporter
Increments the counter identified by the group and counter name by the specified amount.
increment(long) - Method in class org.apache.hadoop.mapreduce.Counter
Increment this counter by the given value
IndexUpdateCombiner - Class in org.apache.hadoop.contrib.index.mapred
This combiner combines multiple intermediate forms into one intermediate form.
IndexUpdateCombiner() - Constructor for class org.apache.hadoop.contrib.index.mapred.IndexUpdateCombiner
 
IndexUpdateConfiguration - Class in org.apache.hadoop.contrib.index.mapred
This class provides the getters and the setters to a number of parameters.
IndexUpdateConfiguration(Configuration) - Constructor for class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Constructor
IndexUpdateMapper<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.contrib.index.mapred
This class applies local analysis on a key-value pair and then convert the result docid-operation pair to a shard-and-intermediate form pair.
IndexUpdateMapper() - Constructor for class org.apache.hadoop.contrib.index.mapred.IndexUpdateMapper
 
IndexUpdateOutputFormat - Class in org.apache.hadoop.contrib.index.mapred
The record writer of this output format simply puts a message in an output path when a shard update is done.
IndexUpdateOutputFormat() - Constructor for class org.apache.hadoop.contrib.index.mapred.IndexUpdateOutputFormat
 
IndexUpdatePartitioner - Class in org.apache.hadoop.contrib.index.mapred
This partitioner class puts the values of the same key - in this case the same shard - in the same partition.
IndexUpdatePartitioner() - Constructor for class org.apache.hadoop.contrib.index.mapred.IndexUpdatePartitioner
 
IndexUpdater - Class in org.apache.hadoop.contrib.index.mapred
An implementation of an index updater interface which creates a Map/Reduce job configuration and run the Map/Reduce job to analyze documents and update Lucene instances in parallel.
IndexUpdater() - Constructor for class org.apache.hadoop.contrib.index.mapred.IndexUpdater
 
IndexUpdateReducer - Class in org.apache.hadoop.contrib.index.mapred
This reducer applies to a shard the changes for it.
IndexUpdateReducer() - Constructor for class org.apache.hadoop.contrib.index.mapred.IndexUpdateReducer
 
init(Shard[]) - Method in class org.apache.hadoop.contrib.index.example.HashingDistributionPolicy
 
init(Shard[]) - Method in class org.apache.hadoop.contrib.index.example.RoundRobinDistributionPolicy
 
init(Shard[]) - Method in interface org.apache.hadoop.contrib.index.mapred.IDistributionPolicy
Initialization.
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
init(JobConf) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Connect to the default JobTracker.
init() - Method in class org.apache.hadoop.streaming.StreamJob
 
init() - Method in class org.apache.hadoop.streaming.StreamXmlRecordReader
 
init(Path, Configuration) - Method in class org.apache.hadoop.tools.rumen.DefaultOutputter
 
init(Path, Configuration) - Method in interface org.apache.hadoop.tools.rumen.Outputter
Initialize the Outputter to a specific path.
initGlobals(JobStatistics, Element) - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.HarFileSystem
Initialize a Har filesystem per har archive.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.RecordReader
Called once at initialization.
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.InputWriter
Initializes the InputWriter.
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.OutputReader
Initializes the OutputReader.
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.RawBytesInputWriter
 
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.RawBytesOutputReader
 
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.TextInputWriter
 
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.TextOutputReader
 
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.TypedBytesInputWriter
 
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.TypedBytesOutputReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.vertica.VerticaRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.vertica.VerticaStreamingRecordReader
Called once at initialization.
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.
initializeTables(LoggedDiscreteCDF) - Method in class org.apache.hadoop.tools.rumen.CDFRandomGenerator
 
initNextRecordReader() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated. Get the record reader for the next chunk in this CombineFileSplit.
initNextRecordReader() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
Get the record reader for the next chunk in this CombineFileSplit.
InnerJoinRecordReader<K extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.hadoop.mapred.join
Deprecated. Use InnerJoinRecordReader instead.
InnerJoinRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>> - Class in org.apache.hadoop.mapreduce.lib.join
Full inner join.
INPUT_BOUNDING_QUERY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Input query to get the max and min values of the jdbc.input.query
INPUT_CLASS_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. Class name implementing DBWritable which will hold input tuples
INPUT_CLASS_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Class name implementing DBWritable which will hold input tuples
INPUT_CONDITIONS_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. WHERE clause in the input SELECT statement
INPUT_CONDITIONS_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
WHERE clause in the input SELECT statement
INPUT_COUNT_QUERY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. Input query to get the count of records
INPUT_COUNT_QUERY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Input query to get the count of records
INPUT_DELIMITER_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Optional input delimiter for streaming
INPUT_DIR - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
INPUT_FIELD_NAMES_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. Field names in the Input table
INPUT_FIELD_NAMES_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Field names in the Input table
INPUT_FORMAT - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
INPUT_ORDER_BY_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. ORDER BY clause in the input SELECT statement
INPUT_ORDER_BY_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
ORDER BY clause in the input SELECT statement
INPUT_QUERY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. Whole input query, exluding LIMIT...OFFSET
INPUT_QUERY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Whole input query, exluding LIMIT...OFFSET
INPUT_TABLE_NAME_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. Input table name
INPUT_TABLE_NAME_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Input table name
INPUT_TERMINATOR_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Optional input terminator for streaming
InputDemuxer - Interface in org.apache.hadoop.tools.rumen
InputDemuxer dem-ultiplexes the input files into individual input streams.
inputFile - Variable in class org.apache.hadoop.contrib.utils.join.DataJoinMapperBase
 
inputFile - Variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
InputFormat<K,V> - Interface in org.apache.hadoop.mapred
Deprecated. Use InputFormat instead.
InputFormat<K,V> - Class in org.apache.hadoop.mapreduce
InputFormat describes the input-specification for a Map-Reduce job.
InputFormat() - Constructor for class org.apache.hadoop.mapreduce.InputFormat
 
inputFormatSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
InputSampler<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use InputSampler
InputSampler(JobConf) - Constructor for class org.apache.hadoop.mapred.lib.InputSampler
Deprecated.  
InputSampler<K,V> - Class in org.apache.hadoop.mapreduce.lib.partition
Utility for collecting samples and writing a partition file for TotalOrderPartitioner.
InputSampler(Configuration) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler
 
InputSampler.IntervalSampler<K,V> - Class in org.apache.hadoop.mapreduce.lib.partition
Sample from s splits at regular intervals.
InputSampler.IntervalSampler(double) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler.IntervalSampler
Create a new IntervalSampler sampling all splits.
InputSampler.IntervalSampler(double, int) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler.IntervalSampler
Create a new IntervalSampler.
InputSampler.RandomSampler<K,V> - Class in org.apache.hadoop.mapreduce.lib.partition
Sample from random points in the input.
InputSampler.RandomSampler(double, int) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler.RandomSampler
Create a new RandomSampler sampling all splits.
InputSampler.RandomSampler(double, int, int) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler.RandomSampler
Create a new RandomSampler.
InputSampler.Sampler<K,V> - Interface in org.apache.hadoop.mapreduce.lib.partition
Interface to sample using an InputFormat.
InputSampler.SplitSampler<K,V> - Class in org.apache.hadoop.mapreduce.lib.partition
Samples the first n records from s splits.
InputSampler.SplitSampler(int) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler.SplitSampler
Create a SplitSampler sampling all splits.
InputSampler.SplitSampler(int, int) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler.SplitSampler
Create a new SplitSampler.
inputSpecs_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
InputSplit - Interface in org.apache.hadoop.mapred
Deprecated. Use InputSplit instead.
InputSplit - Class in org.apache.hadoop.mapreduce
InputSplit represents the data to be processed by an individual Mapper.
InputSplit() - Constructor for class org.apache.hadoop.mapreduce.InputSplit
 
inputTag - Variable in class org.apache.hadoop.contrib.utils.join.DataJoinMapperBase
 
InputWriter<K,V> - Class in org.apache.hadoop.streaming.io
Abstract base for classes that write the client's input.
InputWriter() - Constructor for class org.apache.hadoop.streaming.io.InputWriter
 
inReaderSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
INSERT - Static variable in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp.Op
 
IntegerSplitter - Class in org.apache.hadoop.mapreduce.lib.db
Implement DBSplitter over integer values.
IntegerSplitter() - Constructor for class org.apache.hadoop.mapreduce.lib.db.IntegerSplitter
 
IntermediateForm - Class in org.apache.hadoop.contrib.index.mapred
An intermediate form for one or more parsed Lucene documents and/or delete terms.
IntermediateForm() - Constructor for class org.apache.hadoop.contrib.index.mapred.IntermediateForm
Constructor
INTERPRETOR - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
IntSumReducer<Key> - Class in org.apache.hadoop.mapreduce.lib.reduce
 
IntSumReducer() - Constructor for class org.apache.hadoop.mapreduce.lib.reduce.IntSumReducer
 
InvalidFileTypeException - Exception in org.apache.hadoop.mapred
Used when file type differs from the desired file type.
InvalidFileTypeException() - Constructor for exception org.apache.hadoop.mapred.InvalidFileTypeException
 
InvalidFileTypeException(String) - Constructor for exception org.apache.hadoop.mapred.InvalidFileTypeException
 
InvalidInputException - Exception in org.apache.hadoop.mapred
This class wraps a list of problems with the input, so that the user can get a list of problems together instead of finding and fixing them one by one.
InvalidInputException(List<IOException>) - Constructor for exception org.apache.hadoop.mapred.InvalidInputException
Create the exception with the given list.
InvalidInputException - Exception in org.apache.hadoop.mapreduce.lib.input
This class wraps a list of problems with the input, so that the user can get a list of problems together instead of finding and fixing them one by one.
InvalidInputException(List<IOException>) - Constructor for exception org.apache.hadoop.mapreduce.lib.input.InvalidInputException
Create the exception with the given list.
InvalidJobConfException - Exception in org.apache.hadoop.mapred
This exception is thrown when jobconf misses some mendatory attributes or value of some attributes is invalid.
InvalidJobConfException() - Constructor for exception org.apache.hadoop.mapred.InvalidJobConfException
 
InvalidJobConfException(String) - Constructor for exception org.apache.hadoop.mapred.InvalidJobConfException
 
InverseMapper<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use InverseMapper instead.
InverseMapper() - Constructor for class org.apache.hadoop.mapred.lib.InverseMapper
Deprecated.  
InverseMapper<K,V> - Class in org.apache.hadoop.mapreduce.lib.map
A Mapper that swaps keys and values.
InverseMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.map.InverseMapper
 
ioSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
IS_JAVA_MAP - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
IS_JAVA_REDUCE - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
IS_JAVA_RR - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
IS_JAVA_RW - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
isBlacklisted() - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
Whether tracker is blacklisted
isComplete() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Check if the job is finished or not.
isComplete() - Method in class org.apache.hadoop.mapreduce.Job
Check if the job is finished or not.
isCompleted() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
isEvaluated() - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
isJobComplete() - Method in class org.apache.hadoop.mapreduce.JobStatus
Returns true if the status is for a completed job.
isLocalHadoop() - Method in class org.apache.hadoop.streaming.StreamJob
 
isMapTask() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
isMultiNamedOutput(JobConf, String) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Returns if a named output is multiple.
IsolationRunner - Class in org.apache.hadoop.mapred
IsolationRunner is intended to facilitate debugging by re-running a specific task, given left-over task files for a (typically failed) past job.
IsolationRunner() - Constructor for class org.apache.hadoop.mapred.IsolationRunner
 
isReady() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
isRetired() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Check whether the job has been removed from JobTracker memory and retired.
isRetired() - Method in class org.apache.hadoop.mapreduce.Job
 
isRetired() - Method in class org.apache.hadoop.mapreduce.JobStatus
Check whether the job has retired.
isSegmentsFile(String) - Static method in class org.apache.hadoop.contrib.index.lucene.LuceneUtil
Check if the file is a segments_N file
isSegmentsGenFile(String) - Static method in class org.apache.hadoop.contrib.index.lucene.LuceneUtil
Check if the file is the segments.gen file
isSplitable(FileSystem, Path) - Method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. Is the given filename splitable? Usually, true, but if the file is stream compressed, it will not be.
isSplitable(FileSystem, Path) - Method in class org.apache.hadoop.mapred.KeyValueTextInputFormat
Deprecated.  
isSplitable(FileSystem, Path) - Method in class org.apache.hadoop.mapred.TextInputFormat
Deprecated.  
isSplitable(JobContext, Path) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
 
isSplitable(JobContext, Path) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Is the given filename splitable? Usually, true, but if the file is stream compressed, it will not be.
isSplitable(JobContext, Path) - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueTextInputFormat
 
isSplitable(JobContext, Path) - Method in class org.apache.hadoop.mapreduce.lib.input.TextInputFormat
 
isSuccessful() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Check if the job completed successfully.
isSuccessful() - Method in class org.apache.hadoop.mapreduce.Job
Check if the job completed successfully.
istestPassed() - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
iterator() - Method in class org.apache.hadoop.examples.pi.math.Bellard.Sum
iterator() - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated.  
iterator() - Method in class org.apache.hadoop.mapred.Counters
Deprecated.  
iterator() - Method in class org.apache.hadoop.mapreduce.CounterGroup
 
iterator() - Method in class org.apache.hadoop.mapreduce.Counters
 
iterator() - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Return an iterator over the elements in this tuple.
iterator() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterable
 

J

jar_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
JarBuilder - Class in org.apache.hadoop.streaming
This class is the main class for generating job.jar for Hadoop Streaming jobs.
JarBuilder() - Constructor for class org.apache.hadoop.streaming.JarBuilder
 
jc - Variable in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated.  
jc - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
jc - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
jc_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
job - Variable in class org.apache.hadoop.contrib.utils.join.DataJoinMapperBase
 
job - Variable in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
Job - Class in org.apache.hadoop.mapred.jobcontrol
Deprecated. Use ControlledJob instead.
Job(JobConf, ArrayList<?>) - Constructor for class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated. Construct a job.
Job(JobConf) - Constructor for class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated.  
Job - Class in org.apache.hadoop.mapreduce
The job submitter's view of the Job.
Job() - Constructor for class org.apache.hadoop.mapreduce.Job
Deprecated. 
Job(Configuration) - Constructor for class org.apache.hadoop.mapreduce.Job
Deprecated. 
Job(Configuration, String) - Constructor for class org.apache.hadoop.mapreduce.Job
Deprecated. 
JOB - Static variable in class org.apache.hadoop.mapreduce.JobID
 
Job.JobState - Enum in org.apache.hadoop.mapreduce
 
Job.TaskStatusFilter - Enum in org.apache.hadoop.mapreduce
 
Job20LineHistoryEventEmitter - Class in org.apache.hadoop.tools.rumen
 
JOB_TOKEN_HDFS_FILE - Static variable in class org.apache.hadoop.mapreduce.security.TokenCache
file name used on HDFS for generated job token
JOB_TOKENS_FILENAME - Static variable in class org.apache.hadoop.mapreduce.security.TokenCache
conf setting for job tokens cache file name
JobBase - Class in org.apache.hadoop.contrib.utils.join
A common base implementing some statics collecting mechanisms that are commonly used in a typical map/reduce job.
JobBase() - Constructor for class org.apache.hadoop.contrib.utils.join.JobBase
 
JobBuilder - Class in org.apache.hadoop.tools.rumen
JobBuilder builds one job.
JobBuilder(String) - Constructor for class org.apache.hadoop.tools.rumen.JobBuilder
 
JobClient - Class in org.apache.hadoop.mapred
Deprecated. Use Job and Cluster instead
JobClient() - Constructor for class org.apache.hadoop.mapred.JobClient
Deprecated. Create a job client.
JobClient(JobConf) - Constructor for class org.apache.hadoop.mapred.JobClient
Deprecated. Build a job client with the given JobConf, and connect to the default JobTracker.
JobClient(Configuration) - Constructor for class org.apache.hadoop.mapred.JobClient
Deprecated. Build a job client with the given Configuration, and connect to the default JobTracker.
JobClient(InetSocketAddress, Configuration) - Constructor for class org.apache.hadoop.mapred.JobClient
Deprecated. Build a job client, connect to the indicated job tracker.
JobClient.TaskStatusFilter - Enum in org.apache.hadoop.mapred
Deprecated.  
JobConf - Class in org.apache.hadoop.mapred
Deprecated. Use Configuration instead
JobConf() - Constructor for class org.apache.hadoop.mapred.JobConf
Deprecated. Construct a map/reduce job configuration.
JobConf(Class) - Constructor for class org.apache.hadoop.mapred.JobConf
Deprecated. Construct a map/reduce job configuration.
JobConf(Configuration) - Constructor for class org.apache.hadoop.mapred.JobConf
Deprecated. Construct a map/reduce job configuration.
JobConf(Configuration, Class) - Constructor for class org.apache.hadoop.mapred.JobConf
Deprecated. Construct a map/reduce job configuration.
JobConf(String) - Constructor for class org.apache.hadoop.mapred.JobConf
Deprecated. Construct a map/reduce configuration.
JobConf(Path) - Constructor for class org.apache.hadoop.mapred.JobConf
Deprecated. Construct a map/reduce configuration.
JobConf(boolean) - Constructor for class org.apache.hadoop.mapred.JobConf
Deprecated. A new map/reduce configuration where the behavior of reading from the default resources can be turned off.
jobConf_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
JobConfigurable - Interface in org.apache.hadoop.mapred
Deprecated. 
JobConfigurationParser - Class in org.apache.hadoop.tools.rumen
JobConfigurationParser parses the job configuration xml file, and extracts various framework specific properties.
JobConfigurationParser(List<String>) - Constructor for class org.apache.hadoop.tools.rumen.JobConfigurationParser
Constructor
JobConfPropertyNames - Enum in org.apache.hadoop.tools.rumen
 
JobContext - Interface in org.apache.hadoop.mapred
Deprecated. Use JobContext instead.
JobContext - Interface in org.apache.hadoop.mapreduce
A read-only view of the job that is provided to the tasks while they are running.
JobControl - Class in org.apache.hadoop.mapred.jobcontrol
Deprecated. Use JobControl instead
JobControl(String) - Constructor for class org.apache.hadoop.mapred.jobcontrol.JobControl
Deprecated. Construct a job control for a group of jobs.
JobControl - Class in org.apache.hadoop.mapreduce.lib.jobcontrol
This class encapsulates a set of MapReduce jobs and its dependency.
JobControl(String) - Constructor for class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
Construct a job control for a group of jobs.
JobControl.ThreadState - Enum in org.apache.hadoop.mapreduce.lib.jobcontrol
 
JobCounter - Enum in org.apache.hadoop.mapreduce
 
JobCreator - Enum in org.apache.hadoop.mapred.gridmix
 
JobDiagnoser - Class in org.apache.hadoop.vaidya
This is a base driver class for job diagnostics.
JobDiagnoser() - Constructor for class org.apache.hadoop.vaidya.JobDiagnoser
Constructor.
JobHistoryParser - Interface in org.apache.hadoop.tools.rumen
JobHistoryParser defines the interface of a Job History file parser.
JobHistoryParser.JobInfo - Class in org.apache.hadoop.mapreduce.jobhistory
The class where job information is aggregated into after parsing
JobHistoryParser.JobInfo() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Create a job info object where job information will be stored after a parse
JobHistoryParser.TaskAttemptInfo - Class in org.apache.hadoop.mapreduce.jobhistory
Task Attempt Information is aggregated in this class after parsing
JobHistoryParser.TaskAttemptInfo() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Create a Task Attempt Info which will store attempt level information on a history parse.
JobHistoryParser.TaskInfo - Class in org.apache.hadoop.mapreduce.jobhistory
TaskInformation is aggregated in this class after parsing
JobHistoryParser.TaskInfo() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
 
JobHistoryParserFactory - Class in org.apache.hadoop.tools.rumen
JobHistoryParserFactory is a singleton class that attempts to determine the version of job history and return a proper parser.
JobHistoryParserFactory() - Constructor for class org.apache.hadoop.tools.rumen.JobHistoryParserFactory
 
JobHistoryParserFactory.VersionDetector - Enum in org.apache.hadoop.tools.rumen
 
JobID - Class in org.apache.hadoop.mapred
Deprecated. 
JobID(String, int) - Constructor for class org.apache.hadoop.mapred.JobID
Deprecated. Constructs a JobID object
JobID() - Constructor for class org.apache.hadoop.mapred.JobID
Deprecated.  
JobID - Class in org.apache.hadoop.mapreduce
JobID represents the immutable and unique identifier for the job.
JobID(String, int) - Constructor for class org.apache.hadoop.mapreduce.JobID
Constructs a JobID object
JobID() - Constructor for class org.apache.hadoop.mapreduce.JobID
 
jobId_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
JOBID_REGEX - Static variable in class org.apache.hadoop.mapreduce.JobID
 
jobInfo() - Method in class org.apache.hadoop.streaming.StreamJob
 
JobPriority - Enum in org.apache.hadoop.mapred
Deprecated. Use JobPriority instead
JobPriority - Enum in org.apache.hadoop.mapreduce
Used to describe the priority of the running job.
JobQueueInfo - Class in org.apache.hadoop.mapred
Deprecated. Use QueueInfo instead
JobQueueInfo() - Constructor for class org.apache.hadoop.mapred.JobQueueInfo
Deprecated. Default constructor for Job Queue Info.
JobQueueInfo(String, String) - Constructor for class org.apache.hadoop.mapred.JobQueueInfo
Deprecated. Construct a new JobQueueInfo object using the queue name and the scheduling information passed.
JobSplit.SplitMetaInfo - Class in org.apache.hadoop.mapreduce.split
This represents the meta information about the task split.
JobSplit.SplitMetaInfo() - Constructor for class org.apache.hadoop.mapreduce.split.JobSplit.SplitMetaInfo
 
JobSplit.SplitMetaInfo(String[], long, long) - Constructor for class org.apache.hadoop.mapreduce.split.JobSplit.SplitMetaInfo
 
JobSplit.SplitMetaInfo(InputSplit, long) - Constructor for class org.apache.hadoop.mapreduce.split.JobSplit.SplitMetaInfo
 
JobSplit.TaskSplitIndex - Class in org.apache.hadoop.mapreduce.split
This represents the meta information about the task split that the task gets
JobSplit.TaskSplitIndex() - Constructor for class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitIndex
 
JobSplit.TaskSplitIndex(String, long) - Constructor for class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitIndex
 
JobSplit.TaskSplitMetaInfo - Class in org.apache.hadoop.mapreduce.split
This represents the meta information about the task split that the JobTracker creates
JobSplit.TaskSplitMetaInfo() - Constructor for class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitMetaInfo
 
JobSplit.TaskSplitMetaInfo(JobSplit.TaskSplitIndex, String[], long) - Constructor for class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitMetaInfo
 
JobSplit.TaskSplitMetaInfo(InputSplit, long) - Constructor for class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitMetaInfo
 
JobSplit.TaskSplitMetaInfo(String[], long, long) - Constructor for class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitMetaInfo
 
JobStatistics - Class in org.apache.hadoop.vaidya.statistics.job
 
JobStatistics(JobConf, JobHistoryParser.JobInfo) - Constructor for class org.apache.hadoop.vaidya.statistics.job.JobStatistics
 
JobStatisticsInterface - Interface in org.apache.hadoop.vaidya.statistics.job
 
JobStatisticsInterface.JobKeys - Enum in org.apache.hadoop.vaidya.statistics.job
Job Keys
JobStatisticsInterface.KeyDataType - Enum in org.apache.hadoop.vaidya.statistics.job
 
JobStatisticsInterface.MapTaskKeys - Enum in org.apache.hadoop.vaidya.statistics.job
Map Task Keys
JobStatisticsInterface.ReduceTaskKeys - Enum in org.apache.hadoop.vaidya.statistics.job
Reduce Task Keys
JobStatus - Class in org.apache.hadoop.mapred
Deprecated. Use JobStatus instead
JobStatus() - Constructor for class org.apache.hadoop.mapred.JobStatus
Deprecated.  
JobStatus(JobID, float, float, float, int, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Deprecated. Create a job status object for a given jobid.
JobStatus(JobID, float, float, int, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Deprecated. Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, int, JobPriority, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Deprecated. Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, int, JobPriority, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Deprecated. Create a job status object for a given jobid.
JobStatus - Class in org.apache.hadoop.mapreduce
Describes the current status of a job.
JobStatus() - Constructor for class org.apache.hadoop.mapreduce.JobStatus
 
JobStatus(JobID, float, float, float, float, JobStatus.State, JobPriority, String, String, String, String) - Constructor for class org.apache.hadoop.mapreduce.JobStatus
Create a job status object for a given jobid.
JobStatus.State - Enum in org.apache.hadoop.mapreduce
Current state of the job
jobsToComplete() - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Get the jobs that are not completed and not failed.
JobStory - Interface in org.apache.hadoop.tools.rumen
JobStory represents the runtime information available for a completed Map-Reduce job.
JobStoryProducer - Interface in org.apache.hadoop.tools.rumen
JobStoryProducer produces the sequence of JobStory's.
jobSubmit(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Submit a job to the Map-Reduce framework.
JobTraceReader - Class in org.apache.hadoop.tools.rumen
Reading JSON-encoded job traces and produce LoggedJob instances.
JobTraceReader(Path, Configuration) - Constructor for class org.apache.hadoop.tools.rumen.JobTraceReader
Constructor.
JobTraceReader(InputStream) - Constructor for class org.apache.hadoop.tools.rumen.JobTraceReader
Constructor.
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
 
join(long) - Method in class org.apache.hadoop.mapred.gridmix.Statistics
Wait until the service completes.
JOIN_COMPARATOR - Static variable in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
 
JOIN_EXPR - Static variable in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
 
JoinRecordReader<K extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.hadoop.mapred.join
Deprecated. Use JoinRecordReader instead
JoinRecordReader(int, JobConf, int, Class<? extends WritableComparator>) - Constructor for class org.apache.hadoop.mapred.join.JoinRecordReader
Deprecated.  
JoinRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>> - Class in org.apache.hadoop.mapreduce.lib.join
Base class for Composite joins returning Tuples of arbitrary Writables.
JoinRecordReader(int, Configuration, int, Class<? extends WritableComparator>) - Constructor for class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader
 
JoinRecordReader.JoinDelegationIterator - Class in org.apache.hadoop.mapred.join
Deprecated. Since the JoinCollector is effecting our operation, we need only provide an iterator proxy wrapping its operation.
JoinRecordReader.JoinDelegationIterator() - Constructor for class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
Deprecated.  
JoinRecordReader.JoinDelegationIterator - Class in org.apache.hadoop.mapreduce.lib.join
Since the JoinCollector is effecting our operation, we need only provide an iterator proxy wrapping its operation.
JoinRecordReader.JoinDelegationIterator() - Constructor for class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader.JoinDelegationIterator
 
JsonObjectMapperWriter<T> - Class in org.apache.hadoop.tools.rumen
Simple wrapper around JsonGenerator to write objects in JSON format.
JsonObjectMapperWriter(OutputStream, boolean) - Constructor for class org.apache.hadoop.tools.rumen.JsonObjectMapperWriter
 

K

key() - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
Deprecated. Return the key this RecordReader would supply on a call to next(K,V)
key(K) - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
Deprecated. Clone the key at the head of this RecordReader into the object provided.
key() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Return the key for the current join or the value at the top of the RecordReader heap.
key(K) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Clone the key at the top of this RR into the given object.
key() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Return the key at the head of this RR.
key(K) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Clone the key at the head of this RR into the object supplied.
key() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader.JoinCollector
Return the key associated with this collection.
key - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
key() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Return the key for the current join or the value at the top of the RecordReader heap.
key(K) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Clone the key at the top of this RR into the given object.
key() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Return the key at the head of this RR.
key(K) - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Clone the key at the head of this RR into the object supplied.
KEY_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
 
KEY_VALUE_SEPERATOR - Static variable in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
keyclass - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
KeyFieldBasedComparator<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use KeyFieldBasedComparator instead
KeyFieldBasedComparator() - Constructor for class org.apache.hadoop.mapred.lib.KeyFieldBasedComparator
Deprecated.  
KeyFieldBasedComparator<K,V> - Class in org.apache.hadoop.mapreduce.lib.partition
This comparator implementation provides a subset of the features provided by the Unix/GNU Sort.
KeyFieldBasedComparator() - Constructor for class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
 
KeyFieldBasedPartitioner<K2,V2> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use KeyFieldBasedPartitioner instead
KeyFieldBasedPartitioner() - Constructor for class org.apache.hadoop.mapred.lib.KeyFieldBasedPartitioner
Deprecated.  
KeyFieldBasedPartitioner<K2,V2> - Class in org.apache.hadoop.mapreduce.lib.partition
Defines a way to partition keys based on certain key fields (also see KeyFieldBasedComparator.
KeyFieldBasedPartitioner() - Constructor for class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
 
KeyValueLineRecordReader - Class in org.apache.hadoop.mapred
Deprecated. Use KeyValueLineRecordReader instead
KeyValueLineRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.mapred.KeyValueLineRecordReader
Deprecated.  
KeyValueLineRecordReader - Class in org.apache.hadoop.mapreduce.lib.input
This class treats a line in the input as a key/value pair separated by a separator character.
KeyValueLineRecordReader(Configuration) - Constructor for class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
KeyValueTextInputFormat - Class in org.apache.hadoop.mapred
Deprecated. Use KeyValueTextInputFormat instead
KeyValueTextInputFormat() - Constructor for class org.apache.hadoop.mapred.KeyValueTextInputFormat
Deprecated.  
KeyValueTextInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
An InputFormat for plain text files.
KeyValueTextInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.KeyValueTextInputFormat
 
kids - Variable in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated.  
kids - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
KILLED - Static variable in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
killJob() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Kill the running job.
killJob() - Method in class org.apache.hadoop.mapreduce.Job
Kill the running job.
killJob() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
killTask(TaskAttemptID, boolean) - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Kill indicated task attempt.
killTask(String, boolean) - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Applications should rather use RunningJob.killTask(TaskAttemptID, boolean)
killTask(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.Job
Kill indicated task attempt.

L

largestNumOfValues - Variable in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
lazyOutput_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
LazyOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use LazyOutputFormat instead.
LazyOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.LazyOutputFormat
Deprecated.  
LazyOutputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.output
A Convenience class that creates output lazily.
LazyOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.LazyOutputFormat
 
LEFT_OFFSET_PROPERTY_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
 
limit - Variable in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
Ending value
LineDocInputFormat - Class in org.apache.hadoop.contrib.index.example
An InputFormat for LineDoc for plain text files where each line is a doc.
LineDocInputFormat() - Constructor for class org.apache.hadoop.contrib.index.example.LineDocInputFormat
 
LineDocLocalAnalysis - Class in org.apache.hadoop.contrib.index.example
Convert LineDocTextAndOp to DocumentAndOp as required by ILocalAnalysis.
LineDocLocalAnalysis() - Constructor for class org.apache.hadoop.contrib.index.example.LineDocLocalAnalysis
 
LineDocRecordReader - Class in org.apache.hadoop.contrib.index.example
A simple RecordReader for LineDoc for plain text files where each line is a doc.
LineDocRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.contrib.index.example.LineDocRecordReader
Constructor
LineDocTextAndOp - Class in org.apache.hadoop.contrib.index.example
This class represents an operation.
LineDocTextAndOp() - Constructor for class org.apache.hadoop.contrib.index.example.LineDocTextAndOp
Constructor
LineRecordReader.LineReader - Class in org.apache.hadoop.mapred
Deprecated. Use LineReader instead.
LineRecordReader.LineReader(InputStream, Configuration) - Constructor for class org.apache.hadoop.mapred.LineRecordReader.LineReader
Deprecated.  
LINES_PER_MAP - Static variable in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
 
LINK_URI - Static variable in class org.apache.hadoop.streaming.StreamJob
 
list() - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
listJobConfProperties() - Method in class org.apache.hadoop.streaming.StreamJob
Prints out the jobconf properties on stdout when verbose is specified.
listStatus(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
liststatus returns the children of a directory after looking up the index files.
listStatus(JobConf) - Method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. List input directories.
listStatus(JobConf) - Method in class org.apache.hadoop.mapred.SequenceFileInputFormat
Deprecated.  
listStatus(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
List input directories.
listStatus(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFormat
 
loadTokens(String, JobConf) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
load job token from a file
LoadTypedBytes - Class in org.apache.hadoop.streaming
Utility program that reads typed bytes from standard input and stores them in a sequence file for which the path is given as an argument.
LoadTypedBytes(Configuration) - Constructor for class org.apache.hadoop.streaming.LoadTypedBytes
 
LoadTypedBytes() - Constructor for class org.apache.hadoop.streaming.LoadTypedBytes
 
localHadoop_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
LOG - Static variable in class org.apache.hadoop.contrib.index.main.UpdateIndex
 
LOG - Static variable in class org.apache.hadoop.contrib.index.mapred.IndexUpdater
 
LOG - Static variable in class org.apache.hadoop.contrib.utils.join.JobBase
 
log(Log) - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Logs the current counter values.
LOG - Static variable in class org.apache.hadoop.mapred.FileInputFormat
Deprecated.  
LOG - Static variable in class org.apache.hadoop.mapred.FileOutputCommitter
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.EchoUserResolver
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.RoundRobinUserResolver
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.SerialJobFactory
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.SleepJob
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.Statistics
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.SubmitterUserResolver
 
LOG - Static variable in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
Deprecated.  
LOG - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
LOG - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionMapper
 
LOG - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionReducer
 
LOG - Static variable in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
 
LOG - Static variable in class org.apache.hadoop.streaming.PipeMapRed
 
LOG - Static variable in class org.apache.hadoop.streaming.StreamBaseRecordReader
 
LOG - Static variable in class org.apache.hadoop.streaming.StreamJob
 
LOG - Static variable in class org.apache.hadoop.tools.DistCp
 
Logalyzer - Class in org.apache.hadoop.tools
Logalyzer: A utility tool for archiving and analyzing hadoop logs.
Logalyzer() - Constructor for class org.apache.hadoop.tools.Logalyzer
 
Logalyzer.LogComparator - Class in org.apache.hadoop.tools
A WritableComparator optimized for UTF8 keys of the logs.
Logalyzer.LogComparator() - Constructor for class org.apache.hadoop.tools.Logalyzer.LogComparator
 
Logalyzer.LogRegexMapper<K extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.hadoop.tools
A Mapper that extracts text matching a regular expression.
Logalyzer.LogRegexMapper() - Constructor for class org.apache.hadoop.tools.Logalyzer.LogRegexMapper
 
LoggedDiscreteCDF - Class in org.apache.hadoop.tools.rumen
A LoggedDiscreteCDF is a discrete approximation of a cumulative distribution function, with this class set up to meet the requirements of the Jackson JSON parser/generator.
LoggedDiscreteCDF() - Constructor for class org.apache.hadoop.tools.rumen.LoggedDiscreteCDF
 
LoggedJob - Class in org.apache.hadoop.tools.rumen
A LoggedDiscreteCDF is a representation of an hadoop job, with the details of this class set up to meet the requirements of the Jackson JSON parser/generator.
LoggedJob.JobPriority - Enum in org.apache.hadoop.tools.rumen
 
LoggedJob.JobType - Enum in org.apache.hadoop.tools.rumen
 
LoggedLocation - Class in org.apache.hadoop.tools.rumen
A LoggedLocation is a representation of a point in an hierarchical network, represented as a series of membership names, broadest first.
LoggedLocation() - Constructor for class org.apache.hadoop.tools.rumen.LoggedLocation
 
LoggedNetworkTopology - Class in org.apache.hadoop.tools.rumen
A LoggedNetworkTopology represents a tree that in turn represents a hierarchy of hosts.
LoggedNetworkTopology() - Constructor for class org.apache.hadoop.tools.rumen.LoggedNetworkTopology
 
LoggedSingleRelativeRanking - Class in org.apache.hadoop.tools.rumen
A LoggedSingleRelativeRanking represents an X-Y coordinate of a single point in a discrete CDF.
LoggedSingleRelativeRanking() - Constructor for class org.apache.hadoop.tools.rumen.LoggedSingleRelativeRanking
 
LoggedTask - Class in org.apache.hadoop.tools.rumen
A LoggedTask represents a [hadoop] task that is part of a hadoop job.
LoggedTaskAttempt - Class in org.apache.hadoop.tools.rumen
A LoggedTaskAttempt represents an attempt to run an hadoop task in a hadoop job.
logSpec() - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
Deprecated.  
logSpec() - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
long2string(long) - Static method in class org.apache.hadoop.examples.pi.Util
Covert a long to a String in comma separated number format.
LONG_VALUE_MAX - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
Deprecated.  
LONG_VALUE_MAX - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
LONG_VALUE_MIN - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
Deprecated.  
LONG_VALUE_MIN - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
LONG_VALUE_SUM - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
Deprecated.  
LONG_VALUE_SUM - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
LongSumReducer<K> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use LongSumReducer instead.
LongSumReducer() - Constructor for class org.apache.hadoop.mapred.lib.LongSumReducer
Deprecated.  
LongSumReducer<KEY> - Class in org.apache.hadoop.mapreduce.lib.reduce
 
LongSumReducer() - Constructor for class org.apache.hadoop.mapreduce.lib.reduce.LongSumReducer
 
LongValueMax - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use LongValueMax instead
LongValueMax() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.LongValueMax
Deprecated.  
LongValueMax - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements a value aggregator that maintain the maximum of a sequence of long values.
LongValueMax() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMax
the default constructor
LongValueMin - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use LongValueMin instead
LongValueMin() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.LongValueMin
Deprecated.  
LongValueMin - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements a value aggregator that maintain the minimum of a sequence of long values.
LongValueMin() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMin
the default constructor
LongValueSum - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use LongValueSum instead
LongValueSum() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.LongValueSum
Deprecated.  
LongValueSum - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements a value aggregator that sums up a sequence of long values.
LongValueSum() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.LongValueSum
the default constructor
LuceneUtil - Class in org.apache.hadoop.contrib.index.lucene
This class copies some methods from Lucene's SegmentInfos since that class is not public.
LuceneUtil() - Constructor for class org.apache.hadoop.contrib.index.lucene.LuceneUtil
 

M

MachineNode - Class in org.apache.hadoop.tools.rumen
MachineNode represents the configuration of a cluster node.
MachineNode.Builder - Class in org.apache.hadoop.tools.rumen
Builder for a NodeInfo object
MachineNode.Builder(String, int) - Constructor for class org.apache.hadoop.tools.rumen.MachineNode.Builder
Start building a new NodeInfo object.
machineNodes - Variable in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
main(String[]) - Static method in class org.apache.hadoop.contrib.index.main.UpdateIndex
The main() method
main(String[]) - Static method in class org.apache.hadoop.contrib.utils.join.DataJoinJob
 
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.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.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.TeraSort
 
main(String[]) - Static method in class org.apache.hadoop.examples.terasort.TeraValidate
 
main(String[]) - Static method in class org.apache.hadoop.examples.WordCount
 
main(String[]) - Static method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
main(String[]) - Static method in class org.apache.hadoop.mapred.IsolationRunner
Run a single task.
main(String[]) - Static method in class org.apache.hadoop.mapred.JobClient
Deprecated.  
main(String[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
Deprecated. create and run an Aggregate based map/reduce job.
main(String[]) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Submit a pipes job based on the command line arguments.
main(String[]) - Static method in class org.apache.hadoop.mapred.tools.MRAdmin
 
main(String[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
create and run an Aggregate based map/reduce job.
main(String[]) - Static method in class org.apache.hadoop.mapreduce.lib.partition.InputSampler
 
main(String[]) - Static method in class org.apache.hadoop.mapreduce.tools.CLI
 
main(String[]) - Static method in class org.apache.hadoop.streaming.DumpTypedBytes
 
main(String[]) - Static method in class org.apache.hadoop.streaming.HadoopStreaming
 
main(String[]) - Static method in class org.apache.hadoop.streaming.JarBuilder
Test program
main(String[]) - Static method in class org.apache.hadoop.streaming.LoadTypedBytes
 
main(String[]) - Static method in class org.apache.hadoop.tools.DistCh
 
main(String[]) - Static method in class org.apache.hadoop.tools.DistCp
 
main(String[]) - Static method in class org.apache.hadoop.tools.HadoopArchives
the main functions
main(String[]) - Static method in class org.apache.hadoop.tools.Logalyzer
 
main(String[]) - Static method in class org.apache.hadoop.tools.rumen.Folder
 
main(String[]) - Static method in class org.apache.hadoop.tools.rumen.HadoopLogsAnalyzer
Deprecated.  
main(String[]) - Static method in class org.apache.hadoop.tools.rumen.TraceBuilder
 
main(String[]) - Static method in class org.apache.hadoop.vaidya.postexdiagnosis.PostExPerformanceDiagnoser
 
makeCompactString() - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Convert a counters object into a single line that is easy to parse.
makeEscapedCompactString() - Method in class org.apache.hadoop.mapred.Counters.Counter
Deprecated. Returns the compact stringified version of the counter in the format [(actual-name)(display-name)(value)]
makeEscapedCompactString() - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated. Returns the compact stringified version of the group in the format {(actual-name)(display-name)(value)[][][]} where [] are compact strings for the counters within.
makeEscapedCompactString() - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Represent the counter in a textual format that can be converted back to its object form
makeLock(String) - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
makeQualified(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
 
makeSplit(Path, long, long, String[]) - Method in class org.apache.hadoop.examples.terasort.TeraInputFormat
 
makeSplit(Path, long, long, String[]) - Method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. A factory that makes the split for this class.
makeSplit(Path, long, long, String[]) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
A factory that makes the split for this class.
map(DocumentID, DocumentAndOp, OutputCollector<DocumentID, DocumentAndOp>, Reporter) - Method in class org.apache.hadoop.contrib.index.example.IdentityLocalAnalysis
 
map(DocumentID, LineDocTextAndOp, OutputCollector<DocumentID, DocumentAndOp>, Reporter) - Method in class org.apache.hadoop.contrib.index.example.LineDocLocalAnalysis
 
map(K, V, OutputCollector<Shard, IntermediateForm>, Reporter) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateMapper
Map a key-value pair to a shard-and-intermediate form pair.
map(Object, Object, OutputCollector, Reporter) - Method in class org.apache.hadoop.contrib.utils.join.DataJoinMapperBase
 
map(Object, Object, OutputCollector, Reporter) - Method in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
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(LongWritable, NullWritable, Mapper<LongWritable, NullWritable, Text, Text>.Context) - Method in class org.apache.hadoop.examples.terasort.TeraGen.SortGenMapper
 
map(Object, Text, Mapper<Object, Text, Text, IntWritable>.Context) - Method in class org.apache.hadoop.examples.WordCount.TokenizerMapper
 
map(LongWritable, LongWritable, Mapper<LongWritable, LongWritable, GridmixKey, NullWritable>.Context) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepMapper
 
map(K1, V1, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Deprecated. Do nothing.
map(K1, V1, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorMapper
Deprecated. the map function.
map(K1, V1, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorReducer
Deprecated. Do nothing.
map(Object, Object, OutputCollector, Reporter) - Method in class org.apache.hadoop.mapred.lib.ChainMapper
Deprecated. Chains the map(...) methods of the Mappers in the chain.
map(K, V, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
Deprecated. The identify function.
map(K, V, OutputCollector<K, V>, Reporter) - Method in class org.apache.hadoop.mapred.lib.IdentityMapper
Deprecated. The identify function.
map(K, V, OutputCollector<V, K>, Reporter) - Method in class org.apache.hadoop.mapred.lib.InverseMapper
Deprecated. The inverse function.
map(K, Text, OutputCollector<Text, LongWritable>, Reporter) - Method in class org.apache.hadoop.mapred.lib.RegexMapper
Deprecated.  
map(K, Text, OutputCollector<Text, LongWritable>, Reporter) - Method in class org.apache.hadoop.mapred.lib.TokenCountMapper
Deprecated.  
map(K1, V1, OutputCollector<K2, V2>, Reporter) - Method in interface org.apache.hadoop.mapred.Mapper
Deprecated. Maps a single input key/value pair into an intermediate key/value pair.
map(K1, V1, Mapper<K1, V1, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorMapper
the map function.
map(K, V, Mapper<K, V, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionMapper
The identify function.
map(K, V, Mapper<K, V, V, K>.Context) - Method in class org.apache.hadoop.mapreduce.lib.map.InverseMapper
The inverse function.
map(K, Text, Mapper<K, Text, Text, LongWritable>.Context) - Method in class org.apache.hadoop.mapreduce.lib.map.RegexMapper
 
map(Object, Text, Mapper<Object, Text, Text, IntWritable>.Context) - Method in class org.apache.hadoop.mapreduce.lib.map.TokenCounterMapper
 
map(KEYIN, VALUEIN, Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Mapper
Called once for each key/value pair in the input split.
map(Object, Object, OutputCollector, Reporter) - Method in class org.apache.hadoop.streaming.PipeMapper
 
map(K, Text, OutputCollector<Text, LongWritable>, Reporter) - Method in class org.apache.hadoop.tools.Logalyzer.LogRegexMapper
 
MAP_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
 
MAP_OUTPUT_KEY_VALUE_SPEC - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
MapAttempt20LineHistoryEventEmitter - Class in org.apache.hadoop.tools.rumen
 
MapAttempt20LineHistoryEventEmitter() - Constructor for class org.apache.hadoop.tools.rumen.MapAttempt20LineHistoryEventEmitter
 
mapCmd_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
mapContext - Variable in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
MapContext<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Interface in org.apache.hadoop.mapreduce
The context that is given to the Mapper.
mapDebugSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
MapFileOutputFormat - Class in org.apache.hadoop.mapred
Deprecated. Use MapFileOutputFormat instead
MapFileOutputFormat() - Constructor for class org.apache.hadoop.mapred.MapFileOutputFormat
Deprecated.  
MapFileOutputFormat - Class in org.apache.hadoop.mapreduce.lib.output
An OutputFormat that writes MapFiles.
MapFileOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.MapFileOutputFormat
 
Mapper<K1,V1,K2,V2> - Interface in org.apache.hadoop.mapred
Deprecated. Use Mapper instead.
Mapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce
Maps input key/value pairs to a set of intermediate key/value pairs.
Mapper() - Constructor for class org.apache.hadoop.mapreduce.Mapper
 
Mapper.Context - Class in org.apache.hadoop.mapreduce
The Context passed on to the Mapper implementations.
Mapper.Context() - Constructor for class org.apache.hadoop.mapreduce.Mapper.Context
 
mapProgress() - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
mapProgress() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Get the progress of the job's map-tasks, as a float between 0.0 and 1.0.
mapProgress() - Method in class org.apache.hadoop.mapreduce.Job
Get the progress of the job's map-tasks, as a float between 0.0 and 1.0.
MAPRED_LOCAL_DIR_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Property name for the configuration property mapreduce.cluster.local.dir
MAPRED_MAP_TASK_ENV - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Configuration key to set the maximum virutal memory available to the map tasks.
MAPRED_MAP_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Configuration key to set the java command line options for the map tasks.
MAPRED_MAP_TASK_LOG_LEVEL - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Configuration key to set the logging Level for the map task.
MAPRED_MAP_TASK_ULIMIT - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Configuration key to set the maximum virutal memory available to the map tasks (in kilo-bytes).
MAPRED_REDUCE_TASK_ENV - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Configuration key to set the maximum virutal memory available to the reduce tasks.
MAPRED_REDUCE_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Configuration key to set the java command line options for the reduce tasks.
MAPRED_REDUCE_TASK_LOG_LEVEL - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Configuration key to set the logging Level for the reduce task.
MAPRED_REDUCE_TASK_ULIMIT - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Configuration key to set the maximum virutal memory available to the reduce tasks (in kilo-bytes).
MAPRED_TASK_DEFAULT_MAXVMEM_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.  
MAPRED_TASK_ENV - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Use JobConf.MAPRED_MAP_TASK_ENV or JobConf.MAPRED_REDUCE_TASK_ENV
MAPRED_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Use JobConf.MAPRED_MAP_TASK_JAVA_OPTS or JobConf.MAPRED_REDUCE_TASK_JAVA_OPTS
MAPRED_TASK_MAXPMEM_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.  
MAPRED_TASK_MAXVMEM_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Use JobConf.MAPRED_JOB_MAP_MEMORY_MB_PROPERTY and JobConf.MAPRED_JOB_REDUCE_MEMORY_MB_PROPERTY
MAPRED_TASK_ULIMIT - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Use JobConf.MAPRED_MAP_TASK_ULIMIT or JobConf.MAPRED_REDUCE_TASK_ULIMIT
mapRedFinished() - Method in class org.apache.hadoop.streaming.PipeMapRed
 
MapReduceBase - Class in org.apache.hadoop.mapred
Deprecated. 
MapReduceBase() - Constructor for class org.apache.hadoop.mapred.MapReduceBase
Deprecated.  
MapRunnable<K1,V1,K2,V2> - Interface in org.apache.hadoop.mapred
Deprecated. Use Mapper instead.
MapRunner<K1,V1,K2,V2> - Class in org.apache.hadoop.mapred
Default MapRunnable implementation.
MapRunner() - Constructor for class org.apache.hadoop.mapred.MapRunner
 
MAPS_PER_HOST - Static variable in class org.apache.hadoop.examples.RandomTextWriter
 
MAPS_PER_HOST - Static variable in class org.apache.hadoop.examples.RandomWriter
 
MapSideDiskSpill - Class in org.apache.hadoop.vaidya.postexdiagnosis.tests
 
MapSideDiskSpill() - Constructor for class org.apache.hadoop.vaidya.postexdiagnosis.tests.MapSideDiskSpill
 
MapsReExecutionImpact - Class in org.apache.hadoop.vaidya.postexdiagnosis.tests
 
MapsReExecutionImpact() - Constructor for class org.apache.hadoop.vaidya.postexdiagnosis.tests.MapsReExecutionImpact
 
MapTaskAttemptInfo - Class in org.apache.hadoop.tools.rumen
MapTaskAttemptInfo represents the information with regard to a map task attempt.
MapTaskAttemptInfo(TaskStatus.State, TaskInfo, long) - Constructor for class org.apache.hadoop.tools.rumen.MapTaskAttemptInfo
 
MapTaskStatistics - Class in org.apache.hadoop.vaidya.statistics.job
 
MapTaskStatistics() - Constructor for class org.apache.hadoop.vaidya.statistics.job.MapTaskStatistics
 
mark() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
 
mark() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterator
 
MarkableIterator<VALUE> - Class in org.apache.hadoop.mapreduce
MarkableIterator is a wrapper iterator class that implements the MarkableIteratorInterface.
MarkableIterator(Iterator<VALUE>) - Constructor for class org.apache.hadoop.mapreduce.MarkableIterator
Create a new iterator layered on the input iterator
MAX_KEY - Static variable in class org.apache.hadoop.examples.RandomTextWriter
 
MAX_KEY - Static variable in class org.apache.hadoop.examples.RandomWriter
 
MAX_NUM_UNIQUE_VALUES - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
 
MAX_TRIE_DEPTH - Static variable in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
MAX_VALUE - Static variable in class org.apache.hadoop.examples.RandomTextWriter
 
MAX_VALUE - Static variable in class org.apache.hadoop.examples.RandomWriter
 
maximumDistance - Variable in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
MD5_LEN - Static variable in class org.apache.hadoop.mapred.SequenceFileInputFilter.MD5Filter
Deprecated.  
MD5_LEN - Static variable in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.MD5Filter
 
merge(List, List, String) - Method in class org.apache.hadoop.streaming.JarBuilder
 
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
 
minRecWrittenToEnableSkip_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
mkdirs(Path, FsPermission) - Method in class org.apache.hadoop.fs.HarFileSystem
not implemented.
mNodeMap - Variable in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
mNodesFlattened - Variable in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
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
 
monitorAndPrintJob(JobConf, RunningJob) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Monitor a job and print status in real-time as progress is made and tasks fail.
monitorAndPrintJob() - Method in class org.apache.hadoop.mapreduce.Job
Monitor a job and print status in real-time as progress is made and tasks fail.
MRAdmin - Class in org.apache.hadoop.mapred.tools
Administrative access to Hadoop Map-Reduce.
MRAdmin() - Constructor for class org.apache.hadoop.mapred.tools.MRAdmin
 
MRAdmin(Configuration) - Constructor for class org.apache.hadoop.mapred.tools.MRAdmin
 
msg(String) - Method in class org.apache.hadoop.streaming.StreamJob
 
MultiFileInputFormat<K,V> - Class in org.apache.hadoop.mapred
Deprecated. Use CombineFileInputFormat instead
MultiFileInputFormat() - Constructor for class org.apache.hadoop.mapred.MultiFileInputFormat
Deprecated.  
MultiFileSplit - Class in org.apache.hadoop.mapred
Deprecated. Use CombineFileSplit instead
MultiFileSplit(JobConf, Path[], long[]) - Constructor for class org.apache.hadoop.mapred.MultiFileSplit
Deprecated.  
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 MultiFileWordCount.MapClass.
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
 
MultiFilterRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.join
Deprecated. Use MultiFilterRecordReader instead
MultiFilterRecordReader(int, JobConf, int, Class<? extends WritableComparator>) - Constructor for class org.apache.hadoop.mapred.join.MultiFilterRecordReader
Deprecated.  
MultiFilterRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.join
Base class for Composite join returning values derived from multiple sources, but generally not tuples.
MultiFilterRecordReader(int, Configuration, int, Class<? extends WritableComparator>) - Constructor for class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader
 
MultiFilterRecordReader.MultiFilterDelegationIterator - Class in org.apache.hadoop.mapred.join
Deprecated. Proxy the JoinCollector, but include callback to emit.
MultiFilterRecordReader.MultiFilterDelegationIterator() - Constructor for class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
Deprecated.  
MultiFilterRecordReader.MultiFilterDelegationIterator - Class in org.apache.hadoop.mapreduce.lib.join
Proxy the JoinCollector, but include callback to emit.
MultiFilterRecordReader.MultiFilterDelegationIterator() - Constructor for class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
MultipleInputs - Class in org.apache.hadoop.mapred.lib
Deprecated. Use MultipleInputs instead
MultipleInputs() - Constructor for class org.apache.hadoop.mapred.lib.MultipleInputs
Deprecated.  
MultipleInputs - Class in org.apache.hadoop.mapreduce.lib.input
This class supports MapReduce jobs that have multiple input paths with a different InputFormat and Mapper for each path
MultipleInputs() - Constructor for class org.apache.hadoop.mapreduce.lib.input.MultipleInputs
 
MultipleOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use MultipleOutputs instead
MultipleOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.MultipleOutputFormat
Deprecated.  
MultipleOutputs - Class in org.apache.hadoop.mapred.lib
Deprecated. Use MultipleOutputs instead
MultipleOutputs(JobConf) - Constructor for class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Creates and initializes multiple named outputs support, it should be instantiated in the Mapper/Reducer configure method.
MultipleOutputs<KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce.lib.output
The MultipleOutputs class simplifies writing output data to multiple outputs
MultipleOutputs(TaskInputOutputContext<?, ?, KEYOUT, VALUEOUT>) - Constructor for class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
Creates and initializes multiple outputs support, it should be instantiated in the Mapper/Reducer setup method.
MultipleSequenceFileOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use MultipleOutputs instead
MultipleSequenceFileOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.MultipleSequenceFileOutputFormat
Deprecated.  
MultipleTextOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use MultipleOutputs instead
MultipleTextOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.MultipleTextOutputFormat
Deprecated.  
MultithreadedMapper<K1,V1,K2,V2> - Class in org.apache.hadoop.mapreduce.lib.map
Multithreaded implementation for @link org.apache.hadoop.mapreduce.Mapper.
MultithreadedMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
 
MultithreadedMapRunner<K1,V1,K2,V2> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use MultithreadedMapper instead.
MultithreadedMapRunner() - Constructor for class org.apache.hadoop.mapred.lib.MultithreadedMapRunner
Deprecated.  
MySQLDataDrivenDBRecordReader<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A RecordReader that reads records from a MySQL table via DataDrivenDBRecordReader
MySQLDataDrivenDBRecordReader(DBInputFormat.DBInputSplit, Class<T>, Configuration, Connection, DBConfiguration, String, String[], String) - Constructor for class org.apache.hadoop.mapreduce.lib.db.MySQLDataDrivenDBRecordReader
 
MySQLDBRecordReader<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A RecordReader that reads records from a MySQL table.
MySQLDBRecordReader(DBInputFormat.DBInputSplit, Class<T>, Configuration, Connection, DBConfiguration, String, String[], String) - Constructor for class org.apache.hadoop.mapreduce.lib.db.MySQLDBRecordReader
 

N

N - Variable in class org.apache.hadoop.examples.pi.math.Summation
Variable n in the summation.
NATURAL_ORDER - Static variable in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
needsTargetUsersList() - Method in class org.apache.hadoop.mapred.gridmix.EchoUserResolver
Indicates whether this user resolver needs a list of target users to be provided.
needsTargetUsersList() - Method in class org.apache.hadoop.mapred.gridmix.RoundRobinUserResolver
Indicates whether this user resolver needs a list of target users to be provided.
needsTargetUsersList() - Method in class org.apache.hadoop.mapred.gridmix.SubmitterUserResolver
Indicates whether this user resolver needs a list of target users to be provided.
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. Check whether task needs a commit
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. This method implements the new interface by calling the old method.
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Did this task write any files in the work directory?
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
Check whether task needs a commit
next(DocumentID, LineDocTextAndOp) - Method in class org.apache.hadoop.contrib.index.example.LineDocRecordReader
 
next() - Method in class org.apache.hadoop.contrib.utils.join.ArrayListBackedIterator
 
next() - Method in class org.apache.hadoop.mapred.gridmix.RandomAlgorithms.Selector
Select the next random number.
next(TupleWritable) - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
Deprecated.  
next(K, TupleWritable) - Method in class org.apache.hadoop.mapred.join.JoinRecordReader
Deprecated. Emit the next set of key, value pairs as defined by the child RecordReaders and operation associated with this composite RR.
next(V) - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
Deprecated.  
next(K, V) - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader
Deprecated. Reads the next key/value pair from the input for processing.
next() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Read the next k,v pair into the head of this object; return true iff the RR and this are exhausted.
next(K, U) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Write key-value pair at the head of this stream to the objects provided; get next key-value pair from proxied RR.
next(Text, Text) - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
Deprecated. Read key/value pair in a line.
next(K, V) - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
next(LongWritable, T) - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBRecordReader
Deprecated. Reads the next key/value pair from the input for processing.
next(K, V) - Method in interface org.apache.hadoop.mapred.RecordReader
Reads the next key/value pair from the input for processing.
next(BytesWritable, BytesWritable) - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Deprecated. Read raw bytes from a SequenceFile.
next(Text, Text) - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
Deprecated. Read key/value pair in a line.
next(K, V) - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
next(K) - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
next(LongWritable, T) - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Deprecated. Use DBRecordReader.nextKeyValue()
next(X) - Method in class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
 
next(TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader.JoinCollector
Populate Tuple from iterators.
next(TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader.JoinDelegationIterator
 
next(V) - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
next(U) - Method in class org.apache.hadoop.mapreduce.lib.join.ResetableIterator.EMPTY
 
next(T) - Method in interface org.apache.hadoop.mapreduce.lib.join.ResetableIterator
Assign next value to actual.
next(X) - Method in class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
 
next() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
 
next() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterator
 
next(Text, Text) - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
Read a record.
next(Text, Text) - Method in class org.apache.hadoop.streaming.StreamXmlRecordReader
 
next() - Method in class org.apache.hadoop.vertica.VerticaRecord
 
next(LongWritable, VerticaRecord) - Method in class org.apache.hadoop.vertica.VerticaRecordReader
 
nextEvent() - Method in class org.apache.hadoop.tools.rumen.CurrentJHParser
 
nextEvent() - Method in class org.apache.hadoop.tools.rumen.Hadoop20JHParser
 
nextEvent() - Method in interface org.apache.hadoop.tools.rumen.JobHistoryParser
Get the next HistoryEvent
nextKey() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
nextKey() - Method in interface org.apache.hadoop.mapreduce.ReduceContext
Start processing next unique key.
nextKeyValue() - Method in class org.apache.hadoop.examples.MultiFileWordCount.CombineFileLineRecordReader
 
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Read the next key, value pair.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
Read key/value pair in a line.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Read raw bytes from a SequenceFile.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextRecordReader
Read key/value pair in a line.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
 
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader
Emit the next set of key, value pairs as defined by the child RecordReaders and operation associated with this composite RR.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader
Read the next key, value pair.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Read the next k,v pair into the head of this object; return true iff the RR and this are exhausted.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.RecordReader
Read the next key, value pair.
nextKeyValue() - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Advance to the next key, value pair, returning null if at end.
nextKeyValue() - Method in class org.apache.hadoop.vertica.VerticaRecordReader
 
nextKeyValue() - Method in class org.apache.hadoop.vertica.VerticaStreamingRecordReader
Read the next key, value pair.
NLineInputFormat - Class in org.apache.hadoop.mapred.lib
Deprecated. Use NLineInputFormat instead
NLineInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.NLineInputFormat
Deprecated.  
NLineInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
NLineInputFormat which splits N lines of input as one split.
NLineInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
 
Node - Class in org.apache.hadoop.tools.rumen
Node represents a node in the cluster topology.
Node(String, int) - Constructor for class org.apache.hadoop.tools.rumen.Node
 
normalizeMemoryConfigValue(long) - Static method in class org.apache.hadoop.mapred.JobConf
Deprecated. Normalize the negative values in configuration
normalizePath(String) - Static method in class org.apache.hadoop.contrib.index.mapred.Shard
 
NULL - Static variable in interface org.apache.hadoop.mapred.Reporter
A constant of Reporter type that does nothing.
NullOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use NullOutputFormat instead.
NullOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.NullOutputFormat
Deprecated.  
NullOutputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.output
Consume all outputs and put them in /dev/null.
NullOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.NullOutputFormat
 
NUM_INPUT_FILES - Static variable in class org.apache.hadoop.mapred.FileInputFormat
Deprecated.  
NUM_INPUT_FILES - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
NUM_OF_VALUES_FIELD - Static variable in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
NUM_ROWS - Static variable in class org.apache.hadoop.examples.terasort.TeraGen
 
NUM_THREADS - Static variable in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
 
numOfValues - Variable in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
numReduceTasksSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 

O

obtainTokensForNamenodes(Credentials, Path[], Configuration) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
Convenience method to obtain delegation tokens from namenodes corresponding to the paths passed.
ONE - Static variable in interface org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorDescriptor
Deprecated.  
ONE - Static variable in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorDescriptor
 
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
 
open(Path, int) - Method in class org.apache.hadoop.fs.HarFileSystem
Returns a har input stream which fakes end of file.
openInput(String) - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
openInput(String, int) - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
optimize(Configuration) - Static method in class org.apache.hadoop.vertica.VerticaOutputFormat
Optionally called at the end of a job to optimize any newly created and loaded tables.
OPTIMIZE_POLL_TIMER - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
 
OPTIMIZE_POLL_TIMER_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Override the sleep timer for optimize to poll when new projetions have refreshed
OracleDataDrivenDBInputFormat<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A InputFormat that reads input data from an SQL table in an Oracle db.
OracleDataDrivenDBInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.db.OracleDataDrivenDBInputFormat
 
OracleDataDrivenDBRecordReader<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A RecordReader that reads records from a Oracle table via DataDrivenDBRecordReader
OracleDataDrivenDBRecordReader(DBInputFormat.DBInputSplit, Class<T>, Configuration, Connection, DBConfiguration, String, String[], String) - Constructor for class org.apache.hadoop.mapreduce.lib.db.OracleDataDrivenDBRecordReader
 
OracleDateSplitter - Class in org.apache.hadoop.mapreduce.lib.db
Implement DBSplitter over date/time values returned by an Oracle db.
OracleDateSplitter() - Constructor for class org.apache.hadoop.mapreduce.lib.db.OracleDateSplitter
 
OracleDBRecordReader<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A RecordReader that reads records from an Oracle SQL table.
OracleDBRecordReader(DBInputFormat.DBInputSplit, Class<T>, Configuration, Connection, DBConfiguration, String, String[], String) - Constructor for class org.apache.hadoop.mapreduce.lib.db.OracleDBRecordReader
 
org.apache.hadoop.contrib.index.example - package org.apache.hadoop.contrib.index.example
 
org.apache.hadoop.contrib.index.lucene - package org.apache.hadoop.contrib.index.lucene
 
org.apache.hadoop.contrib.index.main - package org.apache.hadoop.contrib.index.main
 
org.apache.hadoop.contrib.index.mapred - package org.apache.hadoop.contrib.index.mapred
 
org.apache.hadoop.contrib.utils.join - package org.apache.hadoop.contrib.utils.join
 
org.apache.hadoop.examples - package org.apache.hadoop.examples
Hadoop example code.
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.
org.apache.hadoop.filecache - package org.apache.hadoop.filecache
Deprecated. Use Job instead.
org.apache.hadoop.fs - package org.apache.hadoop.fs
Hadoop filesystem classes for MapReduce.
org.apache.hadoop.mapred - package org.apache.hadoop.mapred
A software framework for easily writing applications which process vast amounts of data (multi-terabyte data-sets) parallelly on large clusters (thousands of nodes) built of commodity hardware in a reliable, fault-tolerant manner.
org.apache.hadoop.mapred.gridmix - package org.apache.hadoop.mapred.gridmix
 
org.apache.hadoop.mapred.jobcontrol - package org.apache.hadoop.mapred.jobcontrol
Utilities for managing dependent jobs.
org.apache.hadoop.mapred.join - package org.apache.hadoop.mapred.join
Given a set of sorted datasets keyed with the same class and yielding equal partitions, it is possible to effect a join of those datasets prior to the map.
org.apache.hadoop.mapred.lib - package org.apache.hadoop.mapred.lib
Library of generally useful mappers, reducers, and partitioners.
org.apache.hadoop.mapred.lib.aggregate - package org.apache.hadoop.mapred.lib.aggregate
Classes for performing various counting and aggregations.
org.apache.hadoop.mapred.lib.db - package org.apache.hadoop.mapred.lib.db
org.apache.hadoop.mapred.lib.db Package
org.apache.hadoop.mapred.pipes - package org.apache.hadoop.mapred.pipes
Hadoop Pipes allows C++ code to use Hadoop DFS and map/reduce.
org.apache.hadoop.mapred.tools - package org.apache.hadoop.mapred.tools
Command-line tools associated with the org.apache.hadoop.mapred package.
org.apache.hadoop.mapreduce - package org.apache.hadoop.mapreduce
 
org.apache.hadoop.mapreduce.lib.aggregate - package org.apache.hadoop.mapreduce.lib.aggregate
Classes for performing various counting and aggregations.
org.apache.hadoop.mapreduce.lib.chain - package org.apache.hadoop.mapreduce.lib.chain
 
org.apache.hadoop.mapreduce.lib.db - package org.apache.hadoop.mapreduce.lib.db
org.apache.hadoop.mapred.lib.db Package
org.apache.hadoop.mapreduce.lib.fieldsel - package org.apache.hadoop.mapreduce.lib.fieldsel
 
org.apache.hadoop.mapreduce.lib.input - package org.apache.hadoop.mapreduce.lib.input
 
org.apache.hadoop.mapreduce.lib.jobcontrol - package org.apache.hadoop.mapreduce.lib.jobcontrol
Utilities for managing dependent jobs.
org.apache.hadoop.mapreduce.lib.join - package org.apache.hadoop.mapreduce.lib.join
Given a set of sorted datasets keyed with the same class and yielding equal partitions, it is possible to effect a join of those datasets prior to the map.
org.apache.hadoop.mapreduce.lib.map - package org.apache.hadoop.mapreduce.lib.map
 
org.apache.hadoop.mapreduce.lib.output - package org.apache.hadoop.mapreduce.lib.output
 
org.apache.hadoop.mapreduce.lib.partition - package org.apache.hadoop.mapreduce.lib.partition
 
org.apache.hadoop.mapreduce.lib.reduce - package org.apache.hadoop.mapreduce.lib.reduce
 
org.apache.hadoop.mapreduce.security - package org.apache.hadoop.mapreduce.security
 
org.apache.hadoop.mapreduce.server.jobtracker - package org.apache.hadoop.mapreduce.server.jobtracker
 
org.apache.hadoop.mapreduce.tools - package org.apache.hadoop.mapreduce.tools
Command-line tools associated with the org.apache.hadoop.mapreduce package.
org.apache.hadoop.streaming - package org.apache.hadoop.streaming
Hadoop Streaming is a utility which allows users to create and run Map-Reduce jobs with any executables (e.g.
org.apache.hadoop.streaming.io - package org.apache.hadoop.streaming.io
 
org.apache.hadoop.tools - package org.apache.hadoop.tools
Command-line tools for MapReduce.
org.apache.hadoop.tools.rumen - package org.apache.hadoop.tools.rumen
Rumen is a data extraction and analysis tool built for Apache Hadoop.
org.apache.hadoop.typedbytes - package org.apache.hadoop.typedbytes
Typed bytes are sequences of bytes in which the first byte is a type code.
org.apache.hadoop.vaidya - package org.apache.hadoop.vaidya
 
org.apache.hadoop.vaidya.postexdiagnosis - package org.apache.hadoop.vaidya.postexdiagnosis
 
org.apache.hadoop.vaidya.postexdiagnosis.tests - package org.apache.hadoop.vaidya.postexdiagnosis.tests
 
org.apache.hadoop.vaidya.statistics.job - package org.apache.hadoop.vaidya.statistics.job
 
org.apache.hadoop.vaidya.util - package org.apache.hadoop.vaidya.util
 
org.apache.hadoop.vertica - package org.apache.hadoop.vertica
 
out - Static variable in class org.apache.hadoop.examples.pi.Util
Output stream
out - Variable in class org.apache.hadoop.mapred.TextOutputFormat.LineRecordWriter
Deprecated.  
out - Variable in class org.apache.hadoop.mapreduce.lib.output.TextOutputFormat.LineRecordWriter
 
OUTDIR - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
OuterJoinRecordReader<K extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.hadoop.mapred.join
Deprecated. Use OuterJoinRecordReader instead
OuterJoinRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>> - Class in org.apache.hadoop.mapreduce.lib.join
Full outer join.
outerrThreadsThrowable - Variable in class org.apache.hadoop.streaming.PipeMapRed
 
output(T) - Method in class org.apache.hadoop.tools.rumen.DefaultOutputter
 
output(T) - Method in interface org.apache.hadoop.tools.rumen.Outputter
Output an object.
output_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
OUTPUT_DATABASE_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Name of database to connect to
OUTPUT_DELIMITER_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Optional output format delimiter
OUTPUT_FIELD_COUNT_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. Number of fields in the Output table
OUTPUT_FIELD_COUNT_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Number of fields in the Output table
OUTPUT_FIELD_NAMES_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. Field names in the Output table
OUTPUT_FIELD_NAMES_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Field names in the Output table
OUTPUT_FILTER - Static variable in class org.apache.hadoop.mapreduce.Job
 
OUTPUT_FORMAT - Static variable in class org.apache.hadoop.mapreduce.lib.output.LazyOutputFormat
 
OUTPUT_HOSTNAMES_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Host names to connect to, selected from at random
OUTPUT_PASSWORD_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Password for Vertica
OUTPUT_TABLE_DEF_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Definition of output table types
OUTPUT_TABLE_DROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Whether to drop tables
OUTPUT_TABLE_NAME_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Output table name
OUTPUT_TABLE_NAME_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. Output table name
OUTPUT_TABLE_NAME_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Output table name
OUTPUT_TERMINATOR_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Optional output format terminator
OUTPUT_USERNAME_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
User name for Vertica
OutputCollector<K,V> - Interface in org.apache.hadoop.mapred
Collects the <key, value> pairs output by Mappers and Reducers.
OutputCommitter - Class in org.apache.hadoop.mapred
Deprecated. Use OutputCommitter instead.
OutputCommitter() - Constructor for class org.apache.hadoop.mapred.OutputCommitter
Deprecated.  
OutputCommitter - Class in org.apache.hadoop.mapreduce
OutputCommitter describes the commit of task output for a Map-Reduce job.
OutputCommitter() - Constructor for class org.apache.hadoop.mapreduce.OutputCommitter
 
OutputFormat<K,V> - Interface in org.apache.hadoop.mapred
Deprecated. Use OutputFormat instead.
OutputFormat<K,V> - Class in org.apache.hadoop.mapreduce
OutputFormat describes the output-specification for a Map-Reduce job.
OutputFormat() - Constructor for class org.apache.hadoop.mapreduce.OutputFormat
 
outputFormatSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
OutputLogFilter - Class in org.apache.hadoop.mapred
Deprecated. Use Utils.OutputFileUtils.OutputLogFilter instead.
OutputLogFilter() - Constructor for class org.apache.hadoop.mapred.OutputLogFilter
Deprecated.  
OutputReader<K,V> - Class in org.apache.hadoop.streaming.io
Abstract base for classes that read the client's output.
OutputReader() - Constructor for class org.apache.hadoop.streaming.io.OutputReader
 
outputRecords(OutputStream, boolean, Unsigned16, Unsigned16, Unsigned16) - Static method in class org.apache.hadoop.examples.terasort.GenSort
 
outputSingleNode_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
Outputter<T> - Interface in org.apache.hadoop.tools.rumen
Interface to output a sequence of objects of type T.
OverrideRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.join
Deprecated. Use OverrideRecordReader instead
OverrideRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.join
Prefer the "rightmost" data source for this key.

P

packageFiles_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
packageJobJar() - Method in class org.apache.hadoop.streaming.StreamJob
 
parse(InputStream) - Static method in class org.apache.hadoop.vaidya.util.XMLUtils
Parse the XML file and create Document
parseLongVariable(String, String) - Static method in class org.apache.hadoop.examples.pi.Util
Parse a variable.
parseOutputKeyValueSpec(String, List<Integer>, List<Integer>) - Static method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
Parser - Class in org.apache.hadoop.examples.pi
A class for parsing outputs
Parser(boolean) - Constructor for class org.apache.hadoop.examples.pi.Parser
 
Parser - Class in org.apache.hadoop.mapred.join
Deprecated. Use Parser instead
Parser() - Constructor for class org.apache.hadoop.mapred.join.Parser
Deprecated.  
Parser - Class in org.apache.hadoop.mapreduce.lib.join
Very simple shift-reduce parser for join expressions.
Parser() - Constructor for class org.apache.hadoop.mapreduce.lib.join.Parser
 
Parser.Node - Class in org.apache.hadoop.mapred.join
Deprecated.  
Parser.Node(String) - Constructor for class org.apache.hadoop.mapred.join.Parser.Node
Deprecated.  
Parser.Node - Class in org.apache.hadoop.mapreduce.lib.join
 
Parser.Node(String) - Constructor for class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
Parser.NodeToken - Class in org.apache.hadoop.mapred.join
Deprecated.  
Parser.NodeToken - Class in org.apache.hadoop.mapreduce.lib.join
 
Parser.NumToken - Class in org.apache.hadoop.mapred.join
Deprecated.  
Parser.NumToken(double) - Constructor for class org.apache.hadoop.mapred.join.Parser.NumToken
Deprecated.  
Parser.NumToken - Class in org.apache.hadoop.mapreduce.lib.join
 
Parser.NumToken(double) - Constructor for class org.apache.hadoop.mapreduce.lib.join.Parser.NumToken
 
Parser.StrToken - Class in org.apache.hadoop.mapred.join
Deprecated.  
Parser.StrToken(Parser.TType, String) - Constructor for class org.apache.hadoop.mapred.join.Parser.StrToken
Deprecated.  
Parser.StrToken - Class in org.apache.hadoop.mapreduce.lib.join
 
Parser.StrToken(Parser.TType, String) - Constructor for class org.apache.hadoop.mapreduce.lib.join.Parser.StrToken
 
Parser.Token - Class in org.apache.hadoop.mapred.join
Deprecated. Tagged-union type for tokens from the join expression.
Parser.Token - Class in org.apache.hadoop.mapreduce.lib.join
Tagged-union type for tokens from the join expression.
Parser.TType - Enum in org.apache.hadoop.mapred.join
Deprecated.  
Parser.TType - Enum in org.apache.hadoop.mapreduce.lib.join
 
parseStringVariable(String, String) - Static method in class org.apache.hadoop.examples.pi.Util
Parse a variable.
parseTopologyTree() - Method in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
PART - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
partition(int) - Method in class org.apache.hadoop.examples.pi.math.Summation
Partition the summation.
Partitioner<K2,V2> - Interface in org.apache.hadoop.mapred
Deprecated. Use Partitioner instead.
PARTITIONER - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
Partitioner<KEY,VALUE> - Class in org.apache.hadoop.mapreduce
Partitions the key space.
Partitioner() - Constructor for class org.apache.hadoop.mapreduce.Partitioner
 
PARTITIONER_OPTIONS - Static variable in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
 
PARTITIONER_PATH - Static variable in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
partitionerSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
PASSWORD_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Password for Vertica
PASSWORD_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. Password to access the database
PASSWORD_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Password to access the database
PATHFILTER_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
PATTERN - Static variable in class org.apache.hadoop.mapreduce.lib.map.RegexMapper
 
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
 
PipeCombiner - Class in org.apache.hadoop.streaming
 
PipeCombiner() - Constructor for class org.apache.hadoop.streaming.PipeCombiner
 
PipeMapper - Class in org.apache.hadoop.streaming
A generic Mapper bridge.
PipeMapper() - Constructor for class org.apache.hadoop.streaming.PipeMapper
 
PipeMapRed - Class in org.apache.hadoop.streaming
Shared functionality for PipeMapper, PipeReducer.
PipeMapRed() - Constructor for class org.apache.hadoop.streaming.PipeMapRed
 
PipeMapRunner<K1,V1,K2,V2> - Class in org.apache.hadoop.streaming
 
PipeMapRunner() - Constructor for class org.apache.hadoop.streaming.PipeMapRunner
 
PipeReducer - Class in org.apache.hadoop.streaming
A generic Reducer bridge.
PipeReducer() - Constructor for class org.apache.hadoop.streaming.PipeReducer
 
PORT - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
PostExPerformanceDiagnoser - Class in org.apache.hadoop.vaidya.postexdiagnosis
This class acts as a driver or rule engine for executing the post execution performance diagnostics tests of a map/reduce job.
PostExPerformanceDiagnoser(String, String, InputStream, String) - Constructor for class org.apache.hadoop.vaidya.postexdiagnosis.PostExPerformanceDiagnoser
 
Pre21JobHistoryConstants - Class in org.apache.hadoop.tools.rumen
 
Pre21JobHistoryConstants() - Constructor for class org.apache.hadoop.tools.rumen.Pre21JobHistoryConstants
 
Pre21JobHistoryConstants.Values - Enum in org.apache.hadoop.tools.rumen
This enum contains some of the values commonly used by history log events.
PREP - Static variable in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
PRESERVE_COMMANDFILE - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
printAll() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
Print all the job information
printAll() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
Print all the information about this attempt.
printAll() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
 
printBitSkipped(long) - Static method in class org.apache.hadoop.examples.pi.Util
Print a "bits skipped" message.
printDOM(Node) - Static method in class org.apache.hadoop.vaidya.util.XMLUtils
Prints the specified node, then prints all of its children.
printJobExecutionStatistics() - Method in class org.apache.hadoop.vaidya.statistics.job.JobStatistics
 
printJobExecutionStatistics() - Method in interface org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface
 
printKeys() - Method in class org.apache.hadoop.vaidya.statistics.job.TaskStatistics
 
printReduceCounters(List<Hashtable<JobStatisticsInterface.ReduceTaskKeys, String>>, JobStatisticsInterface.ReduceTaskKeys) - Method in class org.apache.hadoop.vaidya.postexdiagnosis.tests.BalancedReducePartitioning
 
printReport() - Method in class org.apache.hadoop.vaidya.JobDiagnoser
 
printUsage(String[], String) - Static method in class org.apache.hadoop.examples.pi.Util
Print usage messages
printUsage(PrintStream) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
printUsage - Variable in class org.apache.hadoop.streaming.StreamJob
 
process(IntermediateForm) - Method in class org.apache.hadoop.contrib.index.lucene.ShardWriter
Process an intermediate form by carrying out, on the Lucene instance of the shard, the deletes and the inserts (a ram index) in the form.
process(DocumentAndOp, Analyzer) - Method in class org.apache.hadoop.contrib.index.mapred.IntermediateForm
This method is used by the index update mapper and process a document operation into the current intermediate form.
process(IntermediateForm) - Method in class org.apache.hadoop.contrib.index.mapred.IntermediateForm
This method is used by the index update combiner and process an intermediate form into the current intermediate form.
process(HistoryEvent) - Method in class org.apache.hadoop.tools.rumen.JobBuilder
Process one HistoryEvent
process(Properties) - Method in class org.apache.hadoop.tools.rumen.JobBuilder
Process a collection of JobConf Properties.
process(HistoryEvent) - Method in class org.apache.hadoop.tools.rumen.TopologyBuilder
Process one HistoryEvent
process(Properties) - Method in class org.apache.hadoop.tools.rumen.TopologyBuilder
Process a collection of JobConf Properties.
progress - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
progress - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
progress() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
progress() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
progress() - Method in class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl.DummyReporter
 
PROGRESS_MONITOR_POLL_INTERVAL_KEY - Static variable in class org.apache.hadoop.mapreduce.Job
Key in mapred-*.xml that sets progMonitorPollIntervalMillis

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
 
QUERY_PARAM_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Query to run to retrieve parameters
QUERY_PARAMS_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Static parameters for query
QUERY_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Query to run for input
QueueAclsInfo - Class in org.apache.hadoop.mapreduce
Class to encapsulate Queue ACLs for a particular user.
QueueAclsInfo() - Constructor for class org.apache.hadoop.mapreduce.QueueAclsInfo
Default constructor for QueueAclsInfo.
QueueAclsInfo(String, String[]) - Constructor for class org.apache.hadoop.mapreduce.QueueAclsInfo
Construct a new QueueAclsInfo object using the queue name and the queue operations array
QueueInfo - Class in org.apache.hadoop.mapreduce
Class that contains the information regarding the Job Queues which are maintained by the Hadoop Map/Reduce framework.
QueueInfo() - Constructor for class org.apache.hadoop.mapreduce.QueueInfo
Default constructor for QueueInfo.
QueueInfo(String, String) - Constructor for class org.apache.hadoop.mapreduce.QueueInfo
Construct a new QueueInfo object using the queue name and the scheduling information passed.
QueueInfo(String, String, QueueState, JobStatus[]) - Constructor for class org.apache.hadoop.mapreduce.QueueInfo
 
QueueState - Enum in org.apache.hadoop.mapreduce
Enum representing queue state

R

RackNode - Class in org.apache.hadoop.tools.rumen
RackNode represents a rack node in the cluster topology.
RackNode(String, int) - Constructor for class org.apache.hadoop.tools.rumen.RackNode
 
rackNodes - Variable in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
RAMDirectoryUtil - Class in org.apache.hadoop.contrib.index.lucene
A utility class which writes an index in a ram dir into a DataOutput and read from a DataInput an index into a ram dir.
RAMDirectoryUtil() - Constructor for class org.apache.hadoop.contrib.index.lucene.RAMDirectoryUtil
 
RandomAlgorithms - Class in org.apache.hadoop.mapred.gridmix
Random algorithms.
RandomAlgorithms() - Constructor for class org.apache.hadoop.mapred.gridmix.RandomAlgorithms
 
RandomAlgorithms.Selector - Class in org.apache.hadoop.mapred.gridmix
Iteratively pick random numbers from pool 0..n-1.
RandomAlgorithms.Selector(int, double, Random) - Constructor for class org.apache.hadoop.mapred.gridmix.RandomAlgorithms.Selector
Constructor.
RandomSeedGenerator - Class in org.apache.hadoop.tools.rumen
The purpose of this class is to generate new random seeds from a master seed.
RandomSeedGenerator() - Constructor for class org.apache.hadoop.tools.rumen.RandomSeedGenerator
 
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
 
randomValue() - Method in class org.apache.hadoop.tools.rumen.CDFRandomGenerator
 
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
 
RAW_BYTES_ID - Static variable in class org.apache.hadoop.streaming.io.IdentifierResolver
 
RawBytesInputWriter - Class in org.apache.hadoop.streaming.io
InputWriter that writes the client's input as raw bytes.
RawBytesInputWriter() - Constructor for class org.apache.hadoop.streaming.io.RawBytesInputWriter
 
RawBytesOutputReader - Class in org.apache.hadoop.streaming.io
OutputReader that reads the client's output as raw bytes.
RawBytesOutputReader() - Constructor for class org.apache.hadoop.streaming.io.RawBytesOutputReader
 
rawWriter - Variable in class org.apache.hadoop.mapred.lib.FilterOutputFormat.FilterRecordWriter
Deprecated.  
rawWriter - Variable in class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat.FilterRecordWriter
 
read(Class<?>, Configuration) - Static method in class org.apache.hadoop.examples.pi.SummationWritable
Read sigma from conf
read(DataInput) - Static method in class org.apache.hadoop.mapred.JobID
Deprecated. 
read(DataInput) - Static method in class org.apache.hadoop.mapred.TaskAttemptID
Deprecated. 
read(DataInput) - Static method in class org.apache.hadoop.mapred.TaskID
Deprecated. 
read() - Method in class org.apache.hadoop.mapred.TaskLog.Reader
 
read(byte[], int, int) - Method in class org.apache.hadoop.mapred.TaskLog.Reader
 
read() - Method in class org.apache.hadoop.tools.rumen.RewindableInputStream
 
read(byte[], int, int) - Method in class org.apache.hadoop.tools.rumen.RewindableInputStream
 
read() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads a typed bytes sequence and converts it to a Java object.
read() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readArray(ArrayWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readArray() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readBool() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the boolean following a Type.BOOL code.
readBool(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readBoolean(BooleanWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readBoolean() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readBuffer(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readByte() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the byte following a Type.BYTE code.
readByte(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readByte(ByteWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readByte() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readBytes() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the bytes following a Type.BYTES code.
readBytes(BytesWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readBytes() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readDouble() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the double following a Type.DOUBLE code.
readDouble(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readDouble(DoubleWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readDouble() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readFields(DataInput) - Method in class org.apache.hadoop.contrib.index.example.LineDocTextAndOp
 
readFields(DataInput) - Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
 
readFields(DataInput) - Method in class org.apache.hadoop.contrib.index.mapred.DocumentID
 
readFields(DataInput) - Method in class org.apache.hadoop.contrib.index.mapred.IntermediateForm
 
readFields(DataInput) - Method in class org.apache.hadoop.contrib.index.mapred.Shard
 
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.mapred.ClusterStatus.BlackListInfo
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Read a set of groups.
readFields(DataInput) - Method in class org.apache.hadoop.mapred.FileSplit
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Deprecated. 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.Counter
Read the binary representation of the counter
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.CounterGroup
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.Counters
Read a set of groups.
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.ID
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.JobID
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.JobStatus
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat.DataDrivenDBInputSplit
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.NullDBWritable
 
readFields(ResultSet) - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.NullDBWritable
 
readFields(ResultSet) - Method in interface org.apache.hadoop.mapreduce.lib.db.DBWritable
Reads the fields of the object from the ResultSet.
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.lib.input.FileSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.QueueAclsInfo
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.QueueInfo
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.split.JobSplit.SplitMetaInfo
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitIndex
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.TaskID
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
 
readFields(DataInput) - Method in class org.apache.hadoop.vertica.VerticaInputSplit
readFields(DataInput) - Method in class org.apache.hadoop.vertica.VerticaRecord
 
readFloat() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the float following a Type.FLOAT code.
readFloat(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readFloat(FloatWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readFloat() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
ReadingHDFSFilesAsSideEffect - Class in org.apache.hadoop.vaidya.postexdiagnosis.tests
 
ReadingHDFSFilesAsSideEffect() - Constructor for class org.apache.hadoop.vaidya.postexdiagnosis.tests.ReadingHDFSFilesAsSideEffect
 
readInt() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the integer following a Type.INT code.
readInt(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readInt(IntWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readInt() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readKeyValue() - Method in class org.apache.hadoop.streaming.io.OutputReader
Read the next key/value pair outputted by the client.
readKeyValue() - Method in class org.apache.hadoop.streaming.io.RawBytesOutputReader
 
readKeyValue() - Method in class org.apache.hadoop.streaming.io.TextOutputReader
 
readKeyValue() - Method in class org.apache.hadoop.streaming.io.TypedBytesOutputReader
 
readLine(LineReader, Text) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
Read a utf8 encoded line from a data input stream.
readList() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the list following a Type.LIST code.
readLong() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the long following a Type.LONG code.
readLong(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readLong(LongWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readLong() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readMap() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the map following a Type.MAP code.
readMap(MapWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readMap() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readMapHeader() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the header following a Type.MAP code.
readRAMFiles(DataInput, RAMDirectory) - Static method in class org.apache.hadoop.contrib.index.lucene.RAMDirectoryUtil
Read a number of files from a data input to a ram directory.
readRaw() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads a typed bytes sequence.
readRawBool() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.BOOL code.
readRawByte() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw byte following a Type.BYTE code.
readRawBytes(int) - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a custom code.
readRawBytes() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.BYTES code.
readRawDouble() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.DOUBLE code.
readRawFloat() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.FLOAT code.
readRawInt() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.INT code.
readRawList() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.LIST code.
readRawLong() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.LONG code.
readRawMap() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.MAP code.
readRawString() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.STRING code.
readRawVector() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.VECTOR code.
readSortedMap(SortedMapWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readSortedMap() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readString() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the string following a Type.STRING code.
readString(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readText(Text) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readText() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readType() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads a type byte and returns the corresponding Type.
readType() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readVector() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the vector following a Type.VECTOR code.
readVectorHeader() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the header following a Type.VECTOR code.
readVInt(VIntWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readVInt() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readVLong(VLongWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readVLong() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readWritable(Writable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readWritable() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
READY - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated.  
RECORD_TERMINATER - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
 
RecordReader<K,V> - Interface in org.apache.hadoop.mapred
RecordReader reads <key, value> pairs from an InputSplit.
RecordReader<KEYIN,VALUEIN> - Class in org.apache.hadoop.mapreduce
The record reader breaks the data into key/value pairs for input to the Mapper.
RecordReader() - Constructor for class org.apache.hadoop.mapreduce.RecordReader
 
RecordWriter<K,V> - Interface in org.apache.hadoop.mapred
RecordWriter writes the output <key, value> pairs to an output file.
RecordWriter<K,V> - Class in org.apache.hadoop.mapreduce
RecordWriter writes the output <key, value> pairs to an output file.
RecordWriter() - Constructor for class org.apache.hadoop.mapreduce.RecordWriter
 
redCmd_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
reduce(Shard, Iterator<IntermediateForm>, OutputCollector<Shard, IntermediateForm>, Reporter) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateCombiner
 
reduce(Shard, Iterator<IntermediateForm>, OutputCollector<Shard, Text>, Reporter) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateReducer
 
reduce(Object, Iterator, OutputCollector, Reporter) - Method in class org.apache.hadoop.contrib.utils.join.DataJoinMapperBase
 
reduce(Object, Iterator, OutputCollector, Reporter) - Method in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
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(Text, Iterable<IntWritable>, Reducer<Text, IntWritable, Text, IntWritable>.Context) - Method in class org.apache.hadoop.examples.WordCount.IntSumReducer
 
reduce(Text, Iterator<Text>, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Deprecated. Combines values for a given key.
reduce(Text, Iterator<Text>, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorMapper
Deprecated. Do nothing.
reduce(Text, Iterator<Text>, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorReducer
Deprecated.  
reduce(Object, Iterator, OutputCollector, Reporter) - Method in class org.apache.hadoop.mapred.lib.ChainReducer
Deprecated. Chains the reduce(...) method of the Reducer with the map(...) methods of the Mappers in the chain.
reduce(Text, Iterator<Text>, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
Deprecated.  
reduce(K, Iterator<V>, OutputCollector<K, V>, Reporter) - Method in class org.apache.hadoop.mapred.lib.IdentityReducer
Deprecated. Writes all keys and values directly to output.
reduce(K, Iterator<LongWritable>, OutputCollector<K, LongWritable>, Reporter) - Method in class org.apache.hadoop.mapred.lib.LongSumReducer
Deprecated.  
reduce(K2, Iterator<V2>, OutputCollector<K3, V3>, Reporter) - Method in interface org.apache.hadoop.mapred.Reducer
Deprecated. Reduces values for a given key.
reduce(Text, Iterable<Text>, Reducer<Text, Text, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorCombiner
Combines values for a given key.
reduce(Text, Iterable<Text>, Reducer<Text, Text, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorReducer
 
reduce(Text, Iterable<Text>, Reducer<Text, Text, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionReducer
 
reduce(Key, Iterable<IntWritable>, Reducer<Key, IntWritable, Key, IntWritable>.Context) - Method in class org.apache.hadoop.mapreduce.lib.reduce.IntSumReducer
 
reduce(KEY, Iterable<LongWritable>, Reducer<KEY, LongWritable, KEY, LongWritable>.Context) - Method in class org.apache.hadoop.mapreduce.lib.reduce.LongSumReducer
 
reduce(KEYIN, Iterable<VALUEIN>, Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Reducer
This method is called once for each key.
reduce(Object, Iterator, OutputCollector, Reporter) - Method in class org.apache.hadoop.streaming.PipeReducer
 
REDUCE_OUTPUT_KEY_VALUE_SPEC - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
ReduceAttempt20LineHistoryEventEmitter - Class in org.apache.hadoop.tools.rumen
 
reduceContext - Variable in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
ReduceContext<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Interface in org.apache.hadoop.mapreduce
The context passed to the Reducer.
ReduceContext.ValueIterator<VALUEIN> - Interface in org.apache.hadoop.mapreduce
Iterator to iterate over values for a given group of records.
ReduceContextImpl.ValueIterable - Class in org.apache.hadoop.mapreduce.task
 
ReduceContextImpl.ValueIterable() - Constructor for class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterable
 
ReduceContextImpl.ValueIterator - Class in org.apache.hadoop.mapreduce.task
 
ReduceContextImpl.ValueIterator() - Constructor for class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterator
 
reduceDebugSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
reduceProgress() - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
reduceProgress() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Get the progress of the job's reduce-tasks, as a float between 0.0 and 1.0.
reduceProgress() - Method in class org.apache.hadoop.mapreduce.Job
Get the progress of the job's reduce-tasks, as a float between 0.0 and 1.0.
Reducer<K2,V2,K3,V3> - Interface in org.apache.hadoop.mapred
Deprecated. Use Reducer instead.
Reducer<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce
Reduces a set of intermediate values which share a key to a smaller set of values.
Reducer() - Constructor for class org.apache.hadoop.mapreduce.Reducer
 
Reducer.Context - Class in org.apache.hadoop.mapreduce
The Context passed on to the Reducer implementations.
Reducer.Context() - Constructor for class org.apache.hadoop.mapreduce.Reducer.Context
 
REDUCES_PER_HOST - Static variable in class org.apache.hadoop.examples.Join
 
REDUCES_PER_HOST - Static variable in class org.apache.hadoop.examples.Sort
 
ReducesReExecutionImpact - Class in org.apache.hadoop.vaidya.postexdiagnosis.tests
 
ReducesReExecutionImpact() - Constructor for class org.apache.hadoop.vaidya.postexdiagnosis.tests.ReducesReExecutionImpact
 
ReduceTaskAttemptInfo - Class in org.apache.hadoop.tools.rumen
ReduceTaskAttemptInfo represents the information with regard to a reduce task attempt.
ReduceTaskAttemptInfo(TaskStatus.State, TaskInfo, long, long, long) - Constructor for class org.apache.hadoop.tools.rumen.ReduceTaskAttemptInfo
 
ReduceTaskStatistics - Class in org.apache.hadoop.vaidya.statistics.job
 
ReduceTaskStatistics() - Constructor for class org.apache.hadoop.vaidya.statistics.job.ReduceTaskStatistics
 
refreshSuperUserGroupsConfiguration() - Method in class org.apache.hadoop.mapred.tools.MRAdmin
refreshSuperUserGroupsConfiguration JobTracker.
RegexMapper<K> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use RegexMapper
RegexMapper() - Constructor for class org.apache.hadoop.mapred.lib.RegexMapper
Deprecated.  
RegexMapper<K> - Class in org.apache.hadoop.mapreduce.lib.map
A Mapper that extracts text matching a regular expression.
RegexMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.map.RegexMapper
 
remainingTerms(List<T>) - Method in class org.apache.hadoop.examples.pi.math.Summation
Find the remaining terms.
remove() - Method in class org.apache.hadoop.contrib.utils.join.ArrayListBackedIterator
 
remove() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
 
remove() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterator
 
renameFile(String, String) - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
renewDelegationToken(Token<DelegationTokenIdentifier>) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Renew a delegation token
renewDelegationToken(Token<DelegationTokenIdentifier>) - Method in class org.apache.hadoop.mapreduce.Cluster
Renew a delegation token
replay(TupleWritable) - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
Deprecated.  
replay(V) - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
Deprecated.  
replay(X) - Method in class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
 
replay(TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader.JoinCollector
Replay the last Tuple emitted.
replay(TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader.JoinDelegationIterator
 
replay(V) - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
replay(U) - Method in class org.apache.hadoop.mapreduce.lib.join.ResetableIterator.EMPTY
 
replay(T) - Method in interface org.apache.hadoop.mapreduce.lib.join.ResetableIterator
Assign last value returned to actual.
replay(X) - Method in class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
 
report() - Method in class org.apache.hadoop.contrib.utils.join.JobBase
log the counters
reporter - Variable in class org.apache.hadoop.contrib.utils.join.DataJoinMapperBase
 
reporter - Variable in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
reporter - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
Reporter - Interface in org.apache.hadoop.mapred
A facility for Map-Reduce applications to report progress and update counters, status information etc.
reset() - Method in class org.apache.hadoop.contrib.utils.join.ArrayListBackedIterator
 
reset() - Method in interface org.apache.hadoop.contrib.utils.join.ResetableIterator
 
reset() - Method in class org.apache.hadoop.mapred.gridmix.RandomAlgorithms.Selector
Reset the selector for reuse usage.
reset() - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
Deprecated.  
reset() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
Deprecated.  
reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.DoubleValueSum
reset the aggregator
reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMax
reset the aggregator
reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMin
reset the aggregator
reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueSum
reset the aggregator
reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMax
reset the aggregator
reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMin
reset the aggregator
reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
reset the aggregator
reset() - Method in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregator
reset the aggregator
reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueHistogram
reset the aggregator
reset() - Method in class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
 
reset(K) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader.JoinCollector
Codify the contents of the collector to be iterated over.
reset() - Method in class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader.JoinDelegationIterator
 
reset() - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
reset() - Method in class org.apache.hadoop.mapreduce.lib.join.ResetableIterator.EMPTY
 
reset() - Method in interface org.apache.hadoop.mapreduce.lib.join.ResetableIterator
Set iterator to return to the start of its range.
reset() - Method in class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
 
reset(BytesWritable) - Method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat.WritableValueBytes
 
reset() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
 
reset() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterator
 
ResetableIterator - Interface in org.apache.hadoop.contrib.utils.join
This defines an iterator interface that will help the reducer class re-group its input by source tags.
ResetableIterator<T extends org.apache.hadoop.io.Writable> - Interface in org.apache.hadoop.mapred.join
Deprecated. Use ResetableIterator instead
ResetableIterator<T extends org.apache.hadoop.io.Writable> - Interface in org.apache.hadoop.mapreduce.lib.join
This defines an interface to a stateful Iterator that can replay elements added to it directly.
ResetableIterator.EMPTY<U extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.join
Deprecated.  
ResetableIterator.EMPTY() - Constructor for class org.apache.hadoop.mapred.join.ResetableIterator.EMPTY
Deprecated.  
ResetableIterator.EMPTY<U extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.join
 
ResetableIterator.EMPTY() - Constructor for class org.apache.hadoop.mapreduce.lib.join.ResetableIterator.EMPTY
 
resetBackupStore() - Method in interface org.apache.hadoop.mapreduce.ReduceContext.ValueIterator
This method is called when the reducer moves from one key to another.
resetBackupStore() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterator
This method is called when the reducer moves from one key to another.
resolve(String) - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Resolves a given identifier.
ResourceCalculatorPlugin.ProcResourceValues - Class in org.apache.hadoop.mapreduce.util
 
ResourceCalculatorPlugin.ProcResourceValues(long, long, long) - Constructor for class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin.ProcResourceValues
 
resume() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
resume the suspended thread
rewind() - Method in class org.apache.hadoop.tools.rumen.RewindableInputStream
 
RewindableInputStream - Class in org.apache.hadoop.tools.rumen
A simple wrapper class to make any input stream "rewindable".
RewindableInputStream(InputStream) - Constructor for class org.apache.hadoop.tools.rumen.RewindableInputStream
Constructor.
RewindableInputStream(InputStream, int) - Constructor for class org.apache.hadoop.tools.rumen.RewindableInputStream
Constructor
RIGHT_OFFSET_PROPERTY_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
 
rNodeMap - Variable in class org.apache.hadoop.tools.rumen.AbstractClusterStory
 
RoundRobinDistributionPolicy - Class in org.apache.hadoop.contrib.index.example
Choose a shard for each insert in a round-robin fashion.
RoundRobinDistributionPolicy() - Constructor for class org.apache.hadoop.contrib.index.example.RoundRobinDistributionPolicy
 
RoundRobinUserResolver - Class in org.apache.hadoop.mapred.gridmix
 
RoundRobinUserResolver() - Constructor for class org.apache.hadoop.mapred.gridmix.RoundRobinUserResolver
 
rrClass - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
rrClass - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
rrConstructor - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
rrConstructor - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
rrCstrMap - Static variable in class org.apache.hadoop.mapred.join.Parser.Node
Deprecated.  
rrCstrMap - Static variable in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
run(Configuration, Path[], Path, int, Shard[]) - Method in interface org.apache.hadoop.contrib.index.mapred.IIndexUpdater
Create a Map/Reduce job configuration and run the Map/Reduce job to analyze documents and update Lucene instances in parallel.
run(Configuration, Path[], Path, int, Shard[]) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdater
 
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.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(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.TeraSort
 
run(String[]) - Method in class org.apache.hadoop.examples.terasort.TeraValidate
 
run(String[]) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
run(RecordReader<K1, V1>, OutputCollector<K2, V2>, Reporter) - Method in class org.apache.hadoop.mapred.lib.MultithreadedMapRunner
Deprecated.  
run(RecordReader<K1, V1>, OutputCollector<K2, V2>, Reporter) - Method in interface org.apache.hadoop.mapred.MapRunnable
Deprecated. Start mapping input <key, value> pairs.
run(RecordReader<K1, V1>, OutputCollector<K2, V2>, Reporter) - Method in class org.apache.hadoop.mapred.MapRunner
 
run(String[]) - Method in class org.apache.hadoop.mapred.pipes.Submitter
 
run(String[]) - Method in class org.apache.hadoop.mapred.tools.MRAdmin
 
run(Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.lib.chain.ChainMapper
 
run(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.lib.chain.ChainReducer
 
run() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
The main loop for the thread.
run(Mapper<K1, V1, K2, V2>.Context) - Method in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
Run the application's maps using a thread pool.
run(String[]) - Method in class org.apache.hadoop.mapreduce.lib.partition.InputSampler
Driver for InputSampler from the command line.
run(Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Mapper
Expert users can override this method for more complete control over the execution of the Mapper.
run(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Reducer
Advanced application writers can use the Reducer.run(org.apache.hadoop.mapreduce.Reducer.Context) method to control how the reduce task works.
run(String[]) - Method in class org.apache.hadoop.mapreduce.tools.CLI
 
run(String[]) - Method in class org.apache.hadoop.streaming.DumpTypedBytes
The main driver for DumpTypedBytes.
run(String[]) - Method in class org.apache.hadoop.streaming.LoadTypedBytes
The main driver for LoadTypedBytes.
run(RecordReader<K1, V1>, OutputCollector<K2, V2>, Reporter) - Method in class org.apache.hadoop.streaming.PipeMapRunner
 
run(String[]) - Method in class org.apache.hadoop.streaming.StreamJob
 
run(String[]) - Method in class org.apache.hadoop.tools.DistCh
This is the main driver for recursively changing files properties.
run(String[]) - Method in class org.apache.hadoop.tools.DistCp
This is the main driver for recursively copying directories across file systems.
run(String[]) - Method in class org.apache.hadoop.tools.HadoopArchives
the main driver for creating the archives it takes at least three command line parameters.
run(String[]) - Method in class org.apache.hadoop.tools.rumen.Folder
 
run() - Method in class org.apache.hadoop.tools.rumen.Folder
 
run(String[]) - Method in class org.apache.hadoop.tools.rumen.HadoopLogsAnalyzer
Deprecated.  
run(String[]) - Method in class org.apache.hadoop.tools.rumen.TraceBuilder
 
run() - Method in class org.apache.hadoop.vaidya.DiagnosticTest
 
runJob(JobConf) - Static method in class org.apache.hadoop.contrib.utils.join.DataJoinJob
Submit/run a map/reduce job.
runJob(JobConf) - Static method in class org.apache.hadoop.mapred.JobClient
Deprecated. Utility that submits a job, then polls for progress until the job is complete.
runJob(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Submit a job to the map/reduce cluster.
RUNNING - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated.  
RUNNING - Static variable in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
running_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
RunningJob - Interface in org.apache.hadoop.mapred
Deprecated. Use Job instead

S

saveReport(String) - Method in class org.apache.hadoop.vaidya.JobDiagnoser
 
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
 
seek(long) - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
seekNextRecordBoundary() - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
Implementation should seek forward in_ to the first byte of the next record.
seekNextRecordBoundary() - Method in class org.apache.hadoop.streaming.StreamXmlRecordReader
 
seenPrimary_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
select(int, int, Random) - Static method in class org.apache.hadoop.mapred.gridmix.RandomAlgorithms
Selecting m random integers from 0..n-1.
SEPARATOR - Static variable in class org.apache.hadoop.mapreduce.ID
 
SEPERATOR - Static variable in class org.apache.hadoop.mapreduce.lib.output.TextOutputFormat
 
SequenceFileAsBinaryInputFormat - Class in org.apache.hadoop.mapred
Deprecated. Use SequenceFileAsBinaryInputFormat instead
SequenceFileAsBinaryInputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat
Deprecated.  
SequenceFileAsBinaryInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
InputFormat reading keys, values from SequenceFiles in binary (raw) format.
SequenceFileAsBinaryInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat
 
SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader - Class in org.apache.hadoop.mapred
Deprecated. Read records from a SequenceFile as binary (raw) bytes.
SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Deprecated.  
SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader - Class in org.apache.hadoop.mapreduce.lib.input
Read records from a SequenceFile as binary (raw) bytes.
SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
 
SequenceFileAsBinaryOutputFormat - Class in org.apache.hadoop.mapred
Deprecated. Use SequenceFileAsBinaryOutputFormat instead
SequenceFileAsBinaryOutputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
Deprecated.  
SequenceFileAsBinaryOutputFormat - Class in org.apache.hadoop.mapreduce.lib.output
An OutputFormat that writes keys, values to SequenceFiles in binary(raw) format
SequenceFileAsBinaryOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
 
SequenceFileAsBinaryOutputFormat.WritableValueBytes - Class in org.apache.hadoop.mapred
Deprecated. Inner class used for appendRaw
SequenceFileAsBinaryOutputFormat.WritableValueBytes() - Constructor for class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat.WritableValueBytes
Deprecated.  
SequenceFileAsBinaryOutputFormat.WritableValueBytes - Class in org.apache.hadoop.mapreduce.lib.output
Inner class used for appendRaw
SequenceFileAsBinaryOutputFormat.WritableValueBytes() - Constructor for class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat.WritableValueBytes
 
SequenceFileAsBinaryOutputFormat.WritableValueBytes(BytesWritable) - Constructor for class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat.WritableValueBytes
 
SequenceFileAsTextInputFormat - Class in org.apache.hadoop.mapred
Deprecated. Use SequenceFileAsTextInputFormat instead
SequenceFileAsTextInputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileAsTextInputFormat
Deprecated.  
SequenceFileAsTextInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
This class is similar to SequenceFileInputFormat, except it generates SequenceFileAsTextRecordReader which converts the input keys and values to their String forms by calling toString() method.
SequenceFileAsTextInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextInputFormat
 
SequenceFileAsTextRecordReader - Class in org.apache.hadoop.mapred
Deprecated. Use SequenceFileAsTextRecordReader instead
SequenceFileAsTextRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
Deprecated.  
SequenceFileAsTextRecordReader - Class in org.apache.hadoop.mapreduce.lib.input
This class converts the input keys and values to their String forms by calling toString() method.
SequenceFileAsTextRecordReader() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextRecordReader
 
SequenceFileInputFilter<K,V> - Class in org.apache.hadoop.mapred
Deprecated. Use SequenceFileInputFilter instead
SequenceFileInputFilter() - Constructor for class org.apache.hadoop.mapred.SequenceFileInputFilter
Deprecated.  
SequenceFileInputFilter<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
A class that allows a map/red job to work on a sample of sequence files.
SequenceFileInputFilter() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
 
SequenceFileInputFilter.Filter - Interface in org.apache.hadoop.mapred
Deprecated. filter interface
SequenceFileInputFilter.Filter - Interface in org.apache.hadoop.mapreduce.lib.input
filter interface
SequenceFileInputFilter.FilterBase - Class in org.apache.hadoop.mapred
Deprecated. base class for Filters
SequenceFileInputFilter.FilterBase() - Constructor for class org.apache.hadoop.mapred.SequenceFileInputFilter.FilterBase
Deprecated.  
SequenceFileInputFilter.FilterBase - Class in org.apache.hadoop.mapreduce.lib.input
base class for Filters
SequenceFileInputFilter.FilterBase() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.FilterBase
 
SequenceFileInputFilter.MD5Filter - Class in org.apache.hadoop.mapred
Deprecated. This class returns a set of records by examing the MD5 digest of its key against a filtering frequency f.
SequenceFileInputFilter.MD5Filter() - Constructor for class org.apache.hadoop.mapred.SequenceFileInputFilter.MD5Filter
Deprecated.  
SequenceFileInputFilter.MD5Filter - Class in org.apache.hadoop.mapreduce.lib.input
This class returns a set of records by examing the MD5 digest of its key against a filtering frequency f.
SequenceFileInputFilter.MD5Filter() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.MD5Filter
 
SequenceFileInputFilter.PercentFilter - Class in org.apache.hadoop.mapred
Deprecated. This class returns a percentage of records The percentage is determined by a filtering frequency f using the criteria record# % f == 0.
SequenceFileInputFilter.PercentFilter() - Constructor for class org.apache.hadoop.mapred.SequenceFileInputFilter.PercentFilter
Deprecated.  
SequenceFileInputFilter.PercentFilter - Class in org.apache.hadoop.mapreduce.lib.input
This class returns a percentage of records The percentage is determined by a filtering frequency f using the criteria record# % f == 0.
SequenceFileInputFilter.PercentFilter() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.PercentFilter
 
SequenceFileInputFilter.RegexFilter - Class in org.apache.hadoop.mapred
Deprecated. Records filter by matching key to regex
SequenceFileInputFilter.RegexFilter() - Constructor for class org.apache.hadoop.mapred.SequenceFileInputFilter.RegexFilter
Deprecated.  
SequenceFileInputFilter.RegexFilter - Class in org.apache.hadoop.mapreduce.lib.input
Records filter by matching key to regex
SequenceFileInputFilter.RegexFilter() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.RegexFilter
 
SequenceFileInputFormat<K,V> - Class in org.apache.hadoop.mapred
Deprecated. Use SequenceFileInputFormat instead.
SequenceFileInputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileInputFormat
Deprecated.  
SequenceFileInputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
An InputFormat for SequenceFiles.
SequenceFileInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFormat
 
SequenceFileOutputFormat<K,V> - Class in org.apache.hadoop.mapred
Deprecated. Use SequenceFileOutputFormat instead.
SequenceFileOutputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileOutputFormat
Deprecated.  
SequenceFileOutputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.output
An OutputFormat that writes SequenceFiles.
SequenceFileOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.SequenceFileOutputFormat
 
SequenceFileRecordReader<K,V> - Class in org.apache.hadoop.mapred
An RecordReader for SequenceFiles.
SequenceFileRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.mapred.SequenceFileRecordReader
 
SequenceFileRecordReader<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
An RecordReader for SequenceFiles.
SequenceFileRecordReader() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
 
SerialJobFactory - Class in org.apache.hadoop.mapred.gridmix
 
SerialJobFactory(JobSubmitter, JobStoryProducer, Path, Configuration, CountDownLatch, UserResolver) - Constructor for class org.apache.hadoop.mapred.gridmix.SerialJobFactory
Creating a new instance does not start the thread.
SESSION_TIMEZONE_KEY - Static variable in class org.apache.hadoop.mapreduce.lib.db.OracleDBRecordReader
Configuration key to set to a timezone string.
set(int, int) - Method in class org.apache.hadoop.examples.SecondarySort.IntPair
Set the left and right values.
set(String, Object) - Method in class org.apache.hadoop.vertica.VerticaRecord
 
set(Integer, Object) - Method in class org.apache.hadoop.vertica.VerticaRecord
set a value, 0 indexed
set(Integer, Object, boolean) - Method in class org.apache.hadoop.vertica.VerticaRecord
set a value, 0 indexed
setAggregatorDescriptors(JobConf, Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
Deprecated.  
setAggregatorDescriptors(Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
 
setAssignedJobID(JobID) - Method in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated. setAssignedJobID should not be called. JOBID is set by the framework.
setAttemptsToStartSkipping(Configuration, int) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Set the number of Task attempts AFTER which skip mode will be kicked off.
setAutoIncrMapperProcCount(Configuration, boolean) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Set the flag which if set to true, SkipBadRecords.COUNTER_MAP_PROCESSED_RECORDS is incremented by MapRunner after invoking the map function.
setAutoIncrReducerProcCount(Configuration, boolean) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Set the flag which if set to true, SkipBadRecords.COUNTER_REDUCE_PROCESSED_GROUPS is incremented by framework after invoking the reduce function.
setBoundingQuery(Configuration, String) - Static method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
Set the user-defined bounding query to use with a user-defined query.
setCacheArchives(URI[]) - Method in class org.apache.hadoop.mapreduce.Job
Set the given set of archives
setCacheFiles(URI[]) - Method in class org.apache.hadoop.mapreduce.Job
Set the given set of files
setCancelDelegationTokenUponJobCompletion(boolean) - Method in class org.apache.hadoop.mapreduce.Job
Sets the flag that will allow the JobTracker to cancel the HDFS delegation tokens upon job completion.
setChildren(List<JobQueueInfo>) - Method in class org.apache.hadoop.mapred.JobQueueInfo
Deprecated.  
setCleanupProgress(float) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Sets the cleanup progress of this job
setCleanupProgress(float) - Method in class org.apache.hadoop.mapreduce.JobStatus
Sets the cleanup progress of this job
setCombinerClass(Class<? extends Reducer>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the user-defined combiner class used to combine map-outputs before being sent to the reducers.
setCombinerClass(Class<? extends Reducer>) - Method in class org.apache.hadoop.mapreduce.Job
Set the combiner class for the job.
setCompressMapOutput(boolean) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Should the map outputs be compressed before transfer? Uses the SequenceFile compression.
setCompressOutput(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
Set whether the output of the job is compressed.
setCompressOutput(Job, boolean) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Set whether the output of the job is compressed.
setConf(Configuration) - Method in class org.apache.hadoop.examples.terasort.TeraSort.SimplePartitioner
 
setConf(Configuration) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. 
setConf(Configuration) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.MD5Filter
Deprecated. configure the filter according to configuration
setConf(Configuration) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.PercentFilter
Deprecated. configure the filter by checking the configuration
setConf(Configuration) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.RegexFilter
Deprecated. configure the Filter by checking the configuration
setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.MD5Filter
configure the filter according to configuration
setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.PercentFilter
configure the filter by checking the configuration
setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.RegexFilter
configure the Filter by checking the configuration
setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
 
setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
 
setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
 
setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
Read in the partition file and build indexing data structures.
setConf(Configuration) - Method in class org.apache.hadoop.streaming.DumpTypedBytes
 
setConf(Configuration) - Method in class org.apache.hadoop.streaming.LoadTypedBytes
 
setConf(Configuration) - Method in class org.apache.hadoop.streaming.StreamJob
 
setConf(Configuration) - Method in class org.apache.hadoop.tools.DistCp
 
setConf(Configuration) - Method in class org.apache.hadoop.tools.HadoopArchives
 
setConf(Configuration) - Method in class org.apache.hadoop.tools.Logalyzer.LogComparator
 
setConf(Configuration) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
setCountersEnabled(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Deprecated. Enables or disables counters for the named outputs.
setCountersEnabled(Job, boolean) - Static method in class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
Enables or disables counters for the named outputs.
setDelete(Term) - Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
Set the instance to be a delete operation.
setDisplayName(String) - Method in class org.apache.hadoop.mapred.Counters.Counter
Deprecated.  
setDisplayName(String) - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated. Set the display name
setDisplayName(String) - Method in class org.apache.hadoop.mapreduce.Counter
Deprecated. 
setDistributionPolicyClass(Class<? extends IDistributionPolicy>) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Set the distribution policy class.
setDocumentAnalyzerClass(Class<? extends Analyzer>) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Set the analyzer class.
setDoubleValue(Object, double) - Method in class org.apache.hadoop.contrib.utils.join.JobBase
Set the given counter to the given value
setDropTable(boolean) - Method in class org.apache.hadoop.vertica.VerticaConfiguration
Set whether to truncate the output table before loading
setEventId(int) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated. set event Id.
setEventId(int) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
set event Id.
setExecutable(JobConf, String) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Set the URI for the application's executable.
setFilterClass(Configuration, Class) - Static method in class org.apache.hadoop.mapred.SequenceFileInputFilter
Deprecated. set the filter class
setFilterClass(Job, Class<?>) - Static method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
set the filter class
setFinishTime(long) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Set the finish time of the job
setFinishTime(long) - Method in class org.apache.hadoop.mapred.TaskReport
Deprecated. set finish time of task.
setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.JobStatus
Set the finish time of the job
setFormat(JobConf) - Method in class org.apache.hadoop.mapred.join.CompositeInputFormat
Deprecated. Interpret a given string as a composite expression.
setFormat(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
Interpret a given string as a composite expression.
setFrequency(Configuration, int) - Static method in class org.apache.hadoop.mapred.SequenceFileInputFilter.MD5Filter
Deprecated. set the filtering frequency in configuration
setFrequency(Configuration, int) - Static method in class org.apache.hadoop.mapred.SequenceFileInputFilter.PercentFilter
Deprecated. set the frequency and stores it in conf
setFrequency(Configuration, int) - Static method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.MD5Filter
set the filtering frequency in configuration
setFrequency(Configuration, int) - Static method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.PercentFilter
set the frequency and stores it in conf
setGroupingComparatorClass(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapreduce.Job
Define the comparator that controls which keys are grouped together for a single call to Reducer.reduce(Object, Iterable, org.apache.hadoop.mapreduce.Reducer.Context)
setHistoryFile(String) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Set the job history file url for a completed job
setHistoryFile(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
Set the job history file url for a completed job
setID(int) - Method in class org.apache.hadoop.mapred.join.Parser.Node
Deprecated.  
setID(int) - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
setIndexInputFormatClass(Class<? extends InputFormat>) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Set the index input format class.
setIndexMaxFieldLength(int) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Set the max field length for a Lucene instance.
setIndexMaxNumSegments(int) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Set the max number of segments for a Lucene instance.
setIndexShards(String) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Set the string representation of a number of shards.
setIndexShards(IndexUpdateConfiguration, Shard[]) - Static method in class org.apache.hadoop.contrib.index.mapred.Shard
 
setIndexUpdaterClass(Class<? extends IIndexUpdater>) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Set the index updater class.
setIndexUseCompoundFile(boolean) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Set whether use the compound file format for a Lucene instance.
setInput(JobConf, Class<? extends DBWritable>, String, String, String, String...) - Static method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
Deprecated. Initializes the map-part of the job with the appropriate input settings.
setInput(JobConf, Class<? extends DBWritable>, String, String) - Static method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
Deprecated. Initializes the map-part of the job with the appropriate input settings.
setInput(Job, Class<? extends DBWritable>, String, String, String, String...) - Static method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
Note that the "orderBy" column is called the "splitBy" in this version.
setInput(Job, Class<? extends DBWritable>, String, String) - Static method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
setInput() takes a custom query and a separate "bounding query" to use instead of the custom "count query" used by DBInputFormat.
setInput(Job, Class<? extends DBWritable>, String, String, String, String...) - Static method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
Initializes the map-part of the job with the appropriate input settings.
setInput(Job, Class<? extends DBWritable>, String, String) - Static method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
Initializes the map-part of the job with the appropriate input settings.
setInput(Job, String) - Static method in class org.apache.hadoop.vertica.VerticaInputFormat
Set the input query for a job
setInput(Job, String, String) - Static method in class org.apache.hadoop.vertica.VerticaInputFormat
Set a parameterized input query for a job and the query that returns the parameters.
setInput(Job, String, String...) - Static method in class org.apache.hadoop.vertica.VerticaInputFormat
Set the input query and any number of comma delimited literal list of parameters
setInput(Job, String, Collection<List<Object>>) - Static method in class org.apache.hadoop.vertica.VerticaInputFormat
Set the input query and a collection of parameter lists
setInputBoundingQuery(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setInputClass(Class<? extends DBWritable>) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setInputConditions(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setInputCountQuery(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setInputDataLength(long) - Method in class org.apache.hadoop.mapreduce.split.JobSplit.SplitMetaInfo
 
setInputDataLocations(String[]) - Method in class org.apache.hadoop.mapreduce.split.JobSplit.SplitMetaInfo
 
setInputDelimiter(String) - Method in class org.apache.hadoop.vertica.VerticaConfiguration
For streaming set the delimiter to separate values to the mapper
setInputFieldNames(String...) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setInputFormat(Class<? extends InputFormat>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the InputFormat implementation for the map-reduce job.
setInputFormatClass(Class<? extends InputFormat>) - Method in class org.apache.hadoop.mapreduce.Job
Set the InputFormat for the job.
setInputOrderBy(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setInputParams(Collection<List<Object>>) - Method in class org.apache.hadoop.vertica.VerticaConfiguration
Sets a collection of lists.
setInputPathFilter(JobConf, Class<? extends PathFilter>) - Static method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. Set a PathFilter to be applied to the input paths for the map-reduce job.
setInputPathFilter(Job, Class<? extends PathFilter>) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Set a PathFilter to be applied to the input paths for the map-reduce job.
setInputPaths(JobConf, String) - Static method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. Sets the given comma separated paths as the list of inputs for the map-reduce job.
setInputPaths(JobConf, Path...) - Static method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated. Set the array of Paths as the list of inputs for the map-reduce job.
setInputPaths(Job, String) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Sets the given comma separated paths as the list of inputs for the map-reduce job.
setInputPaths(Job, Path...) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Set the array of Paths as the list of inputs for the map-reduce job.
setInputQuery(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setInputQuery(String) - Method in class org.apache.hadoop.vertica.VerticaConfiguration
get Run this query and give the results to mappers.
setInputRecordTerminator(String) - Method in class org.apache.hadoop.vertica.VerticaConfiguration
For streaming set the record terminator to separate values to the mapper
setInputTableName(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setInputWriterClass(Class<? extends InputWriter>) - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Sets the InputWriter class.
setInsert(Document) - Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
Set the instance to be an insert operation.
setIOSortMB(int) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Set the IO sort space in MB.
setIsCleanup(boolean) - Method in class org.apache.hadoop.mapred.TaskLogAppender
Set whether the task is a cleanup attempt or not.
setIsJavaMapper(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Set whether the Mapper is written in Java.
setIsJavaRecordReader(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Set whether the job is using a Java RecordReader.
setIsJavaRecordWriter(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Set whether the job will use a Java RecordWriter.
setIsJavaReducer(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Set whether the Reducer is written in Java.
setJar(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the user jar for the map-reduce job.
setJar(String) - Method in class org.apache.hadoop.mapreduce.Job
Set the job jar
setJarByClass(Class) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the job's jar file by finding an example class location.
setJarByClass(Class<?>) - Method in class org.apache.hadoop.mapreduce.Job
Set the Jar by finding where a given class came from.
setJob(Job) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Set the mapreduce job
setJobACLs(Map<JobACL, AccessControlList>) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
setJobACLs(Map<JobACL, AccessControlList>) - Method in class org.apache.hadoop.mapreduce.JobStatus
Set the job acls.
setJobConf(JobConf) - Method in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated. Set the mapred job conf for this job.
setJobConf() - Method in class org.apache.hadoop.streaming.StreamJob
 
setJobEndNotificationURI(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the uri to be invoked in-order to send a notification after the job has completed (success/failure).
setJobID(String) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Set the job ID for this job.
setJobName(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the user-specified job name.
setJobName(String) - Method in class org.apache.hadoop.mapreduce.Job
Set the user-specified job name.
setJobName(String) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Set the job name for this job.
setJobPriority(JobPriority) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set JobPriority for this job.
setJobPriority(JobPriority) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Set the priority of the job, defaulting to NORMAL.
setJobPriority(String) - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Set the priority of a running job.
setJobSetupCleanupNeeded(boolean) - Method in class org.apache.hadoop.mapreduce.Job
Specify whether job-setup and job-cleanup is needed for the job
setJobState(ControlledJob.State) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Set the state for this job.
setJobStatuses(JobStatus[]) - Method in class org.apache.hadoop.mapred.JobQueueInfo
Deprecated.  
setJobStatuses(JobStatus[]) - Method in class org.apache.hadoop.mapreduce.QueueInfo
 
setJobToken(Token<? extends TokenIdentifier>, Credentials) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
store job token
setKeepCommandFile(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Set whether to keep the command file for debugging
setKeepFailedTaskFiles(boolean) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set whether the framework should keep the intermediate files for failed tasks.
setKeepTaskFilesPattern(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set a regular expression for task names that should be kept.
setKeyComparator(Class<? extends WritableComparator>) - Method in class org.apache.hadoop.mapred.join.Parser.Node
Deprecated.  
setKeyComparator(Class<? extends WritableComparator>) - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
setKeyFieldComparatorOptions(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the KeyFieldBasedComparator options used to compare keys.
setKeyFieldComparatorOptions(Job, String) - Static method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
Set the KeyFieldBasedComparator options used to compare keys.
setKeyFieldPartitionerOptions(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the KeyFieldBasedPartitioner options used for Partitioner
setKeyFieldPartitionerOptions(Job, String) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
Set the KeyFieldBasedPartitioner options used for Partitioner
setKeyValue(Text, Text, byte[], int, int) - Static method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
setLeftOffset(Configuration, int) - Static method in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
Set the subarray to be used for partitioning to bytes[offset:] in Python syntax.
setLocalAnalysisClass(Class<? extends ILocalAnalysis>) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Set the local analysis class.
setLongValue(Object, long) - Method in class org.apache.hadoop.contrib.utils.join.JobBase
Set the given counter to the given value
setMapDebugScript(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the debug script to run when the map tasks fail.
setMapOutputCompressorClass(Class<? extends CompressionCodec>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the given class as the CompressionCodec for the map outputs.
setMapOutputKeyClass(Class<?>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the key class for the map output data.
setMapOutputKeyClass(Class<?>) - Method in class org.apache.hadoop.mapreduce.Job
Set the key class for the map output data.
setMapOutputValueClass(Class<?>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the value class for the map output data.
setMapOutputValueClass(Class<?>) - Method in class org.apache.hadoop.mapreduce.Job
Set the value class for the map output data.
setMapperClass(Class<? extends Mapper>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the Mapper class for the job.
setMapperClass(Class<? extends Mapper>) - Method in class org.apache.hadoop.mapreduce.Job
Set the Mapper for the job.
setMapperClass(Job, Class<? extends Mapper<K1, V1, K2, V2>>) - Static method in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
Set the application's mapper class.
setMapperMaxSkipRecords(Configuration, long) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Set the number of acceptable skip records surrounding the bad record PER bad record in mapper.
setMapProgress(float) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Sets the map progress of this job
setMapProgress(float) - Method in class org.apache.hadoop.mapreduce.JobStatus
Sets the map progress of this job
setMapRunnerClass(Class<? extends MapRunnable>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Expert: Set the MapRunnable class for the job.
setMapSlots(int) - Method in class org.apache.hadoop.tools.rumen.MachineNode.Builder
Set the number of map slot for the node.
setMapSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Turn speculative execution on or off for this job for map tasks.
setMapSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapreduce.Job
Turn speculative execution on or off for this job for map tasks.
setMaxInputSplitSize(Job, long) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Set the maximum split size
setMaxItems(long) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
Set the limit on the number of unique values
setMaxMapAttempts(int) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Expert: Set the number of maximum attempts that will be made to run a map task.
setMaxMapAttempts(int) - Method in class org.apache.hadoop.mapreduce.Job
Expert: Set the number of maximum attempts that will be made to run a map task.
setMaxMapTaskFailuresPercent(int) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Expert: Set the maximum percentage of map tasks that can fail without the job being aborted.
setMaxPhysicalMemoryForTask(long) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. 
setMaxRAMSizeInBytes(long) - Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
Set the max ram index size in bytes.
setMaxReduceAttempts(int) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Expert: Set the number of maximum attempts that will be made to run a reduce task.
setMaxReduceAttempts(int) - Method in class org.apache.hadoop.mapreduce.Job
Expert: Set the number of maximum attempts that will be made to run a reduce task.
setMaxReduceTaskFailuresPercent(int) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the maximum percentage of reduce tasks that can fail without the job being aborted.
setMaxSplitSize(long) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
Specify the maximum size (in bytes) of each split.
setMaxTaskFailuresPerTracker(int) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the maximum no.
setMaxVirtualMemoryForTask(long) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Use JobConf.setMemoryForMapTask(long mem) and Use JobConf.setMemoryForReduceTask(long mem)
setMemory(long) - Method in class org.apache.hadoop.tools.rumen.MachineNode.Builder
Set the physical memory of the node.
setMemoryForMapTask(long) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated.  
setMemoryForReduceTask(long) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated.  
setMemoryPerMapSlot(long) - Method in class org.apache.hadoop.tools.rumen.MachineNode.Builder
Set the amount of RAM reserved for each map slot.
setMemoryPerReduceSlot(long) - Method in class org.apache.hadoop.tools.rumen.MachineNode.Builder
Set the amount of RAM reserved for each reduce slot.
setMessage(String) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Set the message for this job.
setMinInputSplitSize(Job, long) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Set the minimum input split size
setMinSplitSize(long) - Method in class org.apache.hadoop.mapred.FileInputFormat
Deprecated.  
setMinSplitSizeNode(long) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
Specify the minimum size (in bytes) of each split per node.
setMinSplitSizeRack(long) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
Specify the minimum size (in bytes) of each split per rack.
setNumberOfThreads(Job, int) - Static method in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
Set the number of threads in the pool for running maps.
setNumCores(int) - Method in class org.apache.hadoop.tools.rumen.MachineNode.Builder
Set the number of cores for the node.
setNumLinesPerSplit(Job, int) - Static method in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
Set the number of lines per split
setNumMapTasks(int) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the number of map tasks for this job.
setNumReduceTasks(int) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the requisite number of reduce tasks for this job.
setNumReduceTasks(int) - Method in class org.apache.hadoop.mapreduce.Job
Set the number of reduce tasks for the job.
setNumTasksToExecutePerJvm(int) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Sets the number of tasks that a spawned task JVM should run before it exits
setOffsets(Configuration, int, int) - Static method in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
Set the subarray to be used for partitioning to bytes[left:(right+1)] in Python syntax.
setOp(DocumentAndOp.Op) - Method in class org.apache.hadoop.contrib.index.example.LineDocTextAndOp
Set the type of the operation.
setOptimizePollTimeout(Long) - Method in class org.apache.hadoop.vertica.VerticaConfiguration
Set the timour for the optimize poll loop
setOutput(JobConf, String, String...) - Static method in class org.apache.hadoop.mapred.lib.db.DBOutputFormat
Deprecated. Initializes the reduce-part of the job with the appropriate output settings
setOutput(JobConf, String, int) - Static method in class org.apache.hadoop.mapred.lib.db.DBOutputFormat
Deprecated. Initializes the reduce-part of the job with the appropriate output settings
setOutput(Job, String, String...) - Static method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat
Initializes the reduce-part of the job with the appropriate output settings
setOutput(Job, String, int) - Static method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat
Initializes the reduce-part of the job with the appropriate output settings
setOutput(Job, String) - Static method in class org.apache.hadoop.vertica.VerticaOutputFormat
Set the output table
setOutput(Job, String, boolean) - Static method in class org.apache.hadoop.vertica.VerticaOutputFormat
Set the output table and whether to drop it before loading
setOutput(Job, String, boolean, String...) - Static method in class org.apache.hadoop.vertica.VerticaOutputFormat
Set the output table, whether to drop it before loading and the create table specification if it doesn't exist
setOutputCommitter(Class<? extends OutputCommitter>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the OutputCommitter implementation for the map-reduce job.
setOutputCompressionType(JobConf, SequenceFile.CompressionType) - Static method in class org.apache.hadoop.mapred.SequenceFileOutputFormat
Deprecated. Set the SequenceFile.CompressionType for the output SequenceFile.
setOutputCompressionType(Job, SequenceFile.CompressionType) - Static method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileOutputFormat
Set the SequenceFile.CompressionType for the output SequenceFile.
setOutputCompressorClass(JobConf, Class<? extends CompressionCodec>) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
Set the CompressionCodec to be used to compress job outputs.
setOutputCompressorClass(Job, Class<? extends CompressionCodec>) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Set the CompressionCodec to be used to compress job outputs.
setOutputDelimiter(String) - Method in class org.apache.hadoop.vertica.VerticaConfiguration
For streaming set the delimiter used by the reducer
setOutputFieldCount(int) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setOutputFieldNames(String...) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setOutputFormat(Class<? extends OutputFormat>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the OutputFormat implementation for the map-reduce job.
setOutputFormatClass(JobConf, Class<? extends OutputFormat>) - Static method in class org.apache.hadoop.mapred.lib.LazyOutputFormat
Deprecated. Set the underlying output format for LazyOutputFormat.
setOutputFormatClass(Class<? extends OutputFormat>) - Method in class org.apache.hadoop.mapreduce.Job
Set the OutputFormat for the job.
setOutputFormatClass(Job, Class<? extends OutputFormat>) - Static method in class org.apache.hadoop.mapreduce.lib.output.LazyOutputFormat
Set the underlying output format for LazyOutputFormat.
setOutputKeyClass(Class<?>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the key class for the job output data.
setOutputKeyClass(Class<?>) - Method in class org.apache.hadoop.mapreduce.Job
Set the key class for the job output data.
setOutputKeyClass(Class) - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Sets the output key class class.
setOutputKeyComparatorClass(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the RawComparator comparator used to compare keys.
setOutputName(JobContext, String) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Set the base output name for output file to be created.
setOutputPath(JobConf, Path) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
Set the Path of the output directory for the map-reduce job.
setOutputPath(Job, Path) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Set the Path of the output directory for the map-reduce job.
setOutputReaderClass(Class<? extends OutputReader>) - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Sets the OutputReader class.
setOutputRecordTerminator(String) - Method in class org.apache.hadoop.vertica.VerticaConfiguration
For streaming set the record terminator used by the reducer
setOutputReplication(Job, int) - Static method in class org.apache.hadoop.examples.terasort.TeraSort
 
setOutputTableDef(String...) - Method in class org.apache.hadoop.vertica.VerticaConfiguration
Set the definition of a table for output if it needs to be created
setOutputTableName(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setOutputTableName(String) - Method in class org.apache.hadoop.vertica.VerticaConfiguration
Set table that is being loaded as output
setOutputValueClass(Class<?>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the value class for job outputs.
setOutputValueClass(Class<?>) - Method in class org.apache.hadoop.mapreduce.Job
Set the value class for job outputs.
setOutputValueClass(Class) - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Sets the output value class.
setOutputValueGroupingComparator(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the user defined RawComparator comparator for grouping keys in the input to the reduce.
setOwner(Path, String, String) - Method in class org.apache.hadoop.fs.HarFileSystem
not implemented.
setParamsQuery(String) - Method in class org.apache.hadoop.vertica.VerticaConfiguration
Query used to retrieve parameters for the input query.
setPartitionerClass(Class<? extends Partitioner>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the Partitioner class used to partition Mapper-outputs to be sent to the Reducers.
setPartitionerClass(Class<? extends Partitioner>) - Method in class org.apache.hadoop.mapreduce.Job
Set the Partitioner for the job.
setPartitionFile(Configuration, Path) - Static method in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
Set the path to the SequenceFile storing the sorted partition keyset.
setPattern(Configuration, String) - Static method in class org.apache.hadoop.mapred.SequenceFileInputFilter.RegexFilter
Deprecated.  
setPattern(Configuration, String) - Static method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.RegexFilter
Define the filtering regex and stores it in conf
setPermission(Path, FsPermission) - Method in class org.apache.hadoop.fs.HarFileSystem
Not implemented.
setPrinter(DancingLinks.SolutionAcceptor<Pentomino.ColumnName>) - Method in class org.apache.hadoop.examples.dancing.Pentomino
Set the printer for the puzzle.
setPriority(JobPriority) - Method in class org.apache.hadoop.mapreduce.Job
Set the priority of a running job.
setPriority(JobPriority) - Method in class org.apache.hadoop.mapreduce.JobStatus
Set the priority of the job, defaulting to NORMAL.
setProfileEnabled(boolean) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set whether the system should collect profiler information for some of the tasks in this job? The information is stored in the user log directory.
setProfileEnabled(boolean) - Method in class org.apache.hadoop.mapreduce.Job
Set whether the system should collect profiler information for some of the tasks in this job? The information is stored in the user log directory.
setProfileParams(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the profiler configuration arguments.
setProfileParams(String) - Method in class org.apache.hadoop.mapreduce.Job
Set the profiler configuration arguments.
setProfileTaskRange(boolean, String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the ranges of maps or reduces to profile.
setProfileTaskRange(boolean, String) - Method in class org.apache.hadoop.mapreduce.Job
Set the ranges of maps or reduces to profile.
setProperties(Properties) - Method in class org.apache.hadoop.mapred.JobQueueInfo
Deprecated.  
setProperties(Properties) - Method in class org.apache.hadoop.mapreduce.QueueInfo
 
setQueueChildren(List<QueueInfo>) - Method in class org.apache.hadoop.mapreduce.QueueInfo
 
setQueueName(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the name of the queue to which this job should be submitted.
setQueueName(String) - Method in class org.apache.hadoop.mapred.JobQueueInfo
Deprecated. Set the queue name of the JobQueueInfo
setQueueName(String) - Method in class org.apache.hadoop.mapreduce.QueueAclsInfo
 
setQueueName(String) - Method in class org.apache.hadoop.mapreduce.QueueInfo
Set the queue name of the JobQueueInfo
setQueueState(String) - Method in class org.apache.hadoop.mapred.JobQueueInfo
Deprecated. Set the state of the queue
setReduceDebugScript(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the debug script to run when the reduce tasks fail.
setReduceProgress(float) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Sets the reduce progress of this Job
setReduceProgress(float) - Method in class org.apache.hadoop.mapreduce.JobStatus
Sets the reduce progress of this Job
setReducer(JobConf, Class<? extends Reducer<K1, V1, K2, V2>>, Class<? extends K1>, Class<? extends V1>, Class<? extends K2>, Class<? extends V2>, boolean, JobConf) - Static method in class org.apache.hadoop.mapred.lib.ChainReducer
Deprecated. Sets the Reducer class to the chain job's JobConf.
setReducer(Job, Class<? extends Reducer>, Class<?>, Class<?>, Class<?>, Class<?>, Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.chain.ChainReducer
Sets the Reducer class to the chain job.
setReducerClass(Class<? extends Reducer>) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the Reducer class for the job.
setReducerClass(Class<? extends Reducer>) - Method in class org.apache.hadoop.mapreduce.Job
Set the Reducer for the job.
setReducerMaxSkipGroups(Configuration, long) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Set the number of acceptable skip groups surrounding the bad group PER bad group in reducer.
setReduceSlots(int) - Method in class org.apache.hadoop.tools.rumen.MachineNode.Builder
Set the number of reduce slot for the node.
setReduceSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Turn speculative execution on or off for this job for reduce tasks.
setReduceSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapreduce.Job
Turn speculative execution on or off for this job for reduce tasks.
setReplication(Path, short) - Method in class org.apache.hadoop.fs.HarFileSystem
Not implemented.
setRetired() - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Set the job retire flag to true.
setRetired() - Method in class org.apache.hadoop.mapreduce.JobStatus
Set the job retire flag to true.
setRightOffset(Configuration, int) - Static method in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
Set the subarray to be used for partitioning to bytes[:(offset+1)] in Python syntax.
setRunningTaskAttempts(Collection<TaskAttemptID>) - Method in class org.apache.hadoop.mapred.TaskReport
Deprecated. set running attempt(s) of the task.
setRunState(int) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Change the current run state of the job.
setSchedulingInfo(String) - Method in class org.apache.hadoop.mapred.JobQueueInfo
Deprecated. Set the scheduling information associated to particular job queue
setSchedulingInfo(String) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Used to set the scheduling information associated to a particular Job.
setSchedulingInfo(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
Used to set the scheduling information associated to a particular Job.
setSchedulingInfo(String) - Method in class org.apache.hadoop.mapreduce.QueueInfo
Set the scheduling information associated to particular job queue
setSequenceFileOutputKeyClass(JobConf, Class<?>) - Static method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
Deprecated. Set the key class for the SequenceFile
setSequenceFileOutputKeyClass(Job, Class<?>) - Static method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
Set the key class for the SequenceFile
setSequenceFileOutputValueClass(JobConf, Class<?>) - Static method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
Deprecated. Set the value class for the SequenceFile
setSequenceFileOutputValueClass(Job, Class<?>) - Static method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
Set the value class for the SequenceFile
setSessionId(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. 
setSessionTimeZone(Configuration, Connection) - Static method in class org.apache.hadoop.mapreduce.lib.db.OracleDBRecordReader
Set session time zone
setSetupProgress(float) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Sets the setup progress of this job
setSetupProgress(float) - Method in class org.apache.hadoop.mapreduce.JobStatus
Sets the setup progress of this job
setSkipOutputPath(JobConf, Path) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Set the directory to which skipped records are written.
setSortComparatorClass(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapreduce.Job
Define the comparator that controls how the keys are sorted before they are passed to the Reducer.
setSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Turn speculative execution on or off for this job.
setSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapreduce.Job
Turn speculative execution on or off for this job.
setStartTime(long) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Set the start time of the job
setStartTime(long) - Method in class org.apache.hadoop.mapred.TaskReport
Deprecated. set start time of the task.
setStartTime(long) - Method in class org.apache.hadoop.mapreduce.JobStatus
Set the start time of the job
setState(JobStatus.State) - Method in class org.apache.hadoop.mapreduce.JobStatus
Change the current run state of the job.
setState(QueueState) - Method in class org.apache.hadoop.mapreduce.QueueInfo
Set the state of the queue
setStatement(PreparedStatement) - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
setStatus(String) - Method in interface org.apache.hadoop.mapred.Reporter
Set the status description for the task.
setStatus(String) - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
setStatus(String) - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
setStatus(String) - Method in class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl.DummyReporter
 
setStatus(String) - Method in interface org.apache.hadoop.mapreduce.TaskAttemptContext
Set the current status of the task to the given string.
setSuccessfulAttempt(TaskAttemptID) - Method in class org.apache.hadoop.mapred.TaskReport
Deprecated. set successful attempt ID of the task.
setTag(Text) - Method in class org.apache.hadoop.contrib.utils.join.TaggedMapOutput
 
setTargetUsers(URI, Configuration) - Method in class org.apache.hadoop.mapred.gridmix.EchoUserResolver
 
setTargetUsers(URI, Configuration) - Method in class org.apache.hadoop.mapred.gridmix.RoundRobinUserResolver
 
setTargetUsers(URI, Configuration) - Method in class org.apache.hadoop.mapred.gridmix.SubmitterUserResolver
 
setTaskAttemptId(TaskAttemptID) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated. Sets task id.
setTaskAttemptId(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Sets task id.
setTaskId(String) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated. use TaskCompletionEvent.setTaskAttemptId(TaskAttemptID) instead.
setTaskId(String) - Method in class org.apache.hadoop.mapred.TaskLogAppender
 
setTaskOutputFilter(JobClient.TaskStatusFilter) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. 
setTaskOutputFilter(JobConf, JobClient.TaskStatusFilter) - Static method in class org.apache.hadoop.mapred.JobClient
Deprecated. Modify the JobConf to set the task output filter.
setTaskOutputFilter(Configuration, Job.TaskStatusFilter) - Static method in class org.apache.hadoop.mapreduce.Job
Modify the Configuration to set the task output filter.
setTaskRunTime(int) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated. Set the task completion time
setTaskRunTime(int) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Set the task completion time
setTaskStatus(TaskCompletionEvent.Status) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated. Set task status.
setTaskStatus(TaskCompletionEvent.Status) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Set task status.
setTaskTrackerHttp(String) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated. Set task tracker http location.
setTaskTrackerHttp(String) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Set task tracker http location.
setTestsConfFileIs(InputStream) - Method in class org.apache.hadoop.vaidya.postexdiagnosis.PostExPerformanceDiagnoser
 
setTotalLogFileSize(long) - Method in class org.apache.hadoop.mapred.TaskLogAppender
 
setTrackingUrl(String) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. Set the link to the web-ui for details of the job.
setTrackingUrl(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
Set the link to the web-ui for details of the job.
setUnknownAttribute(String, Object) - Method in class org.apache.hadoop.tools.rumen.LoggedJob
 
setUnknownAttribute(String, Object) - Method in class org.apache.hadoop.tools.rumen.LoggedLocation
 
setUnknownAttribute(String, Object) - Method in class org.apache.hadoop.tools.rumen.LoggedNetworkTopology
 
setUnknownAttribute(String, Object) - Method in class org.apache.hadoop.tools.rumen.LoggedSingleRelativeRanking
 
setUnknownAttribute(String, Object) - Method in class org.apache.hadoop.tools.rumen.LoggedTask
 
setUnknownAttribute(String, Object) - Method in class org.apache.hadoop.tools.rumen.LoggedTaskAttempt
 
setup(Mapper<WritableComparable<?>, Text, Text, Text>.Context) - Method in class org.apache.hadoop.examples.dancing.DistributedPentomino.PentMap
 
setup(Reducer<GridmixKey, NullWritable, NullWritable, NullWritable>.Context) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepReducer
 
setup(Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
setup(Mapper<K1, V1, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorMapper
 
setup(Reducer<Text, Text, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorReducer
 
setup(Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.lib.chain.ChainMapper
 
setup(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.lib.chain.ChainReducer
 
setup(Mapper<K, V, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionMapper
 
setup(Reducer<Text, Text, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionReducer
 
setup(Mapper<K, Text, Text, LongWritable>.Context) - Method in class org.apache.hadoop.mapreduce.lib.map.RegexMapper
 
setup(Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Mapper
Called once at the beginning of the task.
setup(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Reducer
Called once at the start of the task.
setUpdate(Document, Term) - Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
Set the instance to be an update operation.
setupJob(JobContext) - Method in class org.apache.hadoop.examples.terasort.TeraOutputFormat.TeraOutputCommitter
 
setupJob(JobContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
setupJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. For the framework to setup the job output during initialization
setupJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. This method implements the new interface by calling the old method.
setupJob(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Create the temporary directory that is the root of all of the task work directories.
setupJob(JobContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
For the framework to setup the job output during initialization
setupProgress() - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
setupProgress() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Get the progress of the job's setup-tasks, as a float between 0.0 and 1.0.
setupProgress() - Method in class org.apache.hadoop.mapreduce.Job
Get the progress of the job's setup-tasks, as a float between 0.0 and 1.0.
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.examples.terasort.TeraOutputFormat.TeraOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. Sets up output for the task.
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Deprecated. This method implements the new interface by calling the old method.
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
No task setup required.
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
Sets up output for the task.
setUseNewMapper(boolean) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set whether the framework should use the new api for the mapper.
setUseNewReducer(boolean) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set whether the framework should use the new api for the reducer.
setUser(String) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the reported username for this job.
setUser(String) - Method in class org.apache.hadoop.mapreduce.Job
Set the reported username for this job.
setUsername(String) - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
setUsername(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
 
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
setValue(long) - Method in class org.apache.hadoop.mapreduce.Counter
Set this counter by the given value
setValue(Object) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritable
Set the typed bytes from a given Java object.
setValue(Enum, long) - Method in class org.apache.hadoop.vaidya.statistics.job.JobStatistics
 
setValue(Enum, double) - Method in class org.apache.hadoop.vaidya.statistics.job.JobStatistics
 
setValue(Enum, String) - Method in class org.apache.hadoop.vaidya.statistics.job.JobStatistics
 
setValue(Enum, long) - Method in interface org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface
 
setValue(Enum, double) - Method in interface org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface
 
setValue(Enum, String) - Method in interface org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface
 
setValue(Enum, long) - Method in class org.apache.hadoop.vaidya.statistics.job.TaskStatistics
 
setValue(Enum, double) - Method in class org.apache.hadoop.vaidya.statistics.job.TaskStatistics
 
setValue(Enum, String) - Method in class org.apache.hadoop.vaidya.statistics.job.TaskStatistics
 
setVerbose(boolean) - Method in class org.apache.hadoop.streaming.JarBuilder
 
setWorkingDirectory(Path) - Method in class org.apache.hadoop.fs.HarFileSystem
 
setWorkingDirectory(Path) - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. Set the current working directory for the default file system.
setWorkingDirectory(Path) - Method in class org.apache.hadoop.mapreduce.Job
Set the current working directory for the default file system.
Shard - Class in org.apache.hadoop.contrib.index.mapred
This class represents the metadata of a shard.
Shard() - Constructor for class org.apache.hadoop.contrib.index.mapred.Shard
Constructor.
Shard(long, String, long) - Constructor for class org.apache.hadoop.contrib.index.mapred.Shard
Construct a shard from a versio number, a directory and a generation number.
Shard(Shard) - Constructor for class org.apache.hadoop.contrib.index.mapred.Shard
Construct using a shard object.
ShardWriter - Class in org.apache.hadoop.contrib.index.lucene
The initial version of an index is stored in the perm dir.
ShardWriter(FileSystem, Shard, String, IndexUpdateConfiguration) - Constructor for class org.apache.hadoop.contrib.index.lucene.ShardWriter
Constructor
shippedCanonFiles_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
Shuffle.ShuffleError - Exception in org.apache.hadoop.mapreduce.task.reduce
 
shutdown() - Method in class org.apache.hadoop.mapred.gridmix.Statistics
 
size() - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated. Returns the number of counters in this group.
size() - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Returns the total number of counters, by summing the number of counters in each group.
size() - Method in class org.apache.hadoop.mapreduce.CounterGroup
Returns the number of counters in this group.
size() - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
The number of children in this Tuple.
skip(K) - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
Deprecated. Skip key-value pairs with keys less than or equal to the key provided.
skip(K) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Deprecated. Pass skip key to child RRs.
skip(K) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Deprecated. Skip key-value pairs with keys less than or equal to the key provided.
skip(K) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Pass skip key to child RRs.
skip(K) - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Skip key-value pairs with keys less than or equal to the key provided.
SkipBadRecords - Class in org.apache.hadoop.mapred
Utility class for skip bad records functionality.
SkipBadRecords() - Constructor for class org.apache.hadoop.mapred.SkipBadRecords
 
skipType() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Skips a type byte.
SleepJob - Class in org.apache.hadoop.mapred.gridmix
 
SleepJob(Configuration, long, JobStory, Path, UserGroupInformation, int, int, String[]) - Constructor for class org.apache.hadoop.mapred.gridmix.SleepJob
 
SleepJob.SleepInputFormat - Class in org.apache.hadoop.mapred.gridmix
 
SleepJob.SleepInputFormat() - Constructor for class org.apache.hadoop.mapred.gridmix.SleepJob.SleepInputFormat
 
SleepJob.SleepMapper - Class in org.apache.hadoop.mapred.gridmix
 
SleepJob.SleepMapper() - Constructor for class org.apache.hadoop.mapred.gridmix.SleepJob.SleepMapper
 
SleepJob.SleepReducer - Class in org.apache.hadoop.mapred.gridmix
 
SleepJob.SleepReducer() - Constructor for class org.apache.hadoop.mapred.gridmix.SleepJob.SleepReducer
 
SleepJob.SleepSplit - Class in org.apache.hadoop.mapred.gridmix
 
SleepJob.SleepSplit() - Constructor for class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
SleepJob.SleepSplit(int, long, long[], int, String[]) - Constructor for class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
SLEEPJOB_MAPTASK_ONLY - Static variable in class org.apache.hadoop.mapred.gridmix.SleepJob
 
SLEEPJOB_RANDOM_LOCATIONS - Static variable in enum org.apache.hadoop.mapred.gridmix.JobCreator
 
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
 
SORT_COLUMNS - Static variable in class org.apache.hadoop.tools.Logalyzer
 
SOURCE_TAGS_FIELD - Static variable in class org.apache.hadoop.contrib.utils.join.DataJoinReducerBase
 
specToString(String, String, int, List<Integer>, List<Integer>) - Static method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
split(int) - Method in class org.apache.hadoop.examples.dancing.DancingLinks
Generate a list of row choices to cover the first moves.
split - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
Deprecated.  
split(Configuration, ResultSet, String) - Method in class org.apache.hadoop.mapreduce.lib.db.BigDecimalSplitter
 
split(Configuration, ResultSet, String) - Method in class org.apache.hadoop.mapreduce.lib.db.BooleanSplitter
 
split(Configuration, ResultSet, String) - Method in class org.apache.hadoop.mapreduce.lib.db.DateSplitter
 
split(Configuration, ResultSet, String) - Method in interface org.apache.hadoop.mapreduce.lib.db.DBSplitter
Given a ResultSet containing one record (and already advanced to that record) with two columns (a low value, and a high value, both of the same type), determine a set of splits that span the given values.
split(Configuration, ResultSet, String) - Method in class org.apache.hadoop.mapreduce.lib.db.FloatSplitter
 
split(Configuration, ResultSet, String) - Method in class org.apache.hadoop.mapreduce.lib.db.IntegerSplitter
 
split(Configuration, ResultSet, String) - Method in class org.apache.hadoop.mapreduce.lib.db.TextSplitter
This method needs to determine the splits between two user-provided strings.
split - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
SPLIT_MAXSIZE - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
SPLIT_MINSIZE - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
SPLIT_MINSIZE_PERNODE - Static variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
 
SPLIT_MINSIZE_PERRACK - Static variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
 
splitKeyVal(byte[], int, int, Text, Text, int, int) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
split a UTF-8 byte array into key and value assuming that the delimilator is at splitpos.
splitKeyVal(byte[], int, int, Text, Text, int) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
split a UTF-8 byte array into key and value assuming that the delimilator is at splitpos.
splitKeyVal(byte[], Text, Text, int, int) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
split a UTF-8 byte array into key and value assuming that the delimilator is at splitpos.
splitKeyVal(byte[], Text, Text, int) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
split a UTF-8 byte array into key and value assuming that the delimilator is at splitpos.
start() - Method in class org.apache.hadoop.mapred.gridmix.SerialJobFactory
Start the reader thread, wait for latch if necessary.
start() - Method in class org.apache.hadoop.mapred.gridmix.Statistics
Attempt to start the service.
start() - Method in class org.apache.hadoop.mapred.gridmix.StressJobFactory
Start the reader thread, wait for latch if necessary.
startLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.HarFileSystem
not implemented.
startMap(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
startMap(TreeMap, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
startRecord(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
startRecord(Record, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
startVector(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
startVector(ArrayList, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
State - Enum in org.apache.hadoop.mapreduce.server.jobtracker
Deprecated. Use Cluster.JobTrackerStatus instead.
state - Variable in class org.apache.hadoop.tools.rumen.TaskAttemptInfo
 
statement - Variable in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
Statistics - Class in org.apache.hadoop.mapred.gridmix
Component collecting the stats required by other components to make decisions.
Statistics(Configuration, int, CountDownLatch) - Constructor for class org.apache.hadoop.mapred.gridmix.Statistics
 
stop() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
set the thread state to STOPPING so that the thread will stop when it wakes up.
StreamBackedIterator<X extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.join
Deprecated. Use StreamBackedIterator instead
StreamBackedIterator() - Constructor for class org.apache.hadoop.mapred.join.StreamBackedIterator
Deprecated.  
StreamBackedIterator<X extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.join
This class provides an implementation of ResetableIterator.
StreamBackedIterator() - Constructor for class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
 
StreamBaseRecordReader - Class in org.apache.hadoop.streaming
Shared functionality for hadoopStreaming formats.
StreamBaseRecordReader(FSDataInputStream, FileSplit, Reporter, JobConf, FileSystem) - Constructor for class org.apache.hadoop.streaming.StreamBaseRecordReader
 
StreamInputFormat - Class in org.apache.hadoop.streaming
An input format that selects a RecordReader based on a JobConf property.
StreamInputFormat() - Constructor for class org.apache.hadoop.streaming.StreamInputFormat
 
StreamJob - Class in org.apache.hadoop.streaming
All the client-side work happens here.
StreamJob(String[], boolean) - Constructor for class org.apache.hadoop.streaming.StreamJob
Deprecated. use StreamJob() with ToolRunner or set the Configuration using StreamJob.setConf(Configuration) and run with StreamJob.run(String[]).
StreamJob() - Constructor for class org.apache.hadoop.streaming.StreamJob
 
StreamKeyValUtil - Class in org.apache.hadoop.streaming
 
StreamKeyValUtil() - Constructor for class org.apache.hadoop.streaming.StreamKeyValUtil
 
StreamXmlRecordReader - Class in org.apache.hadoop.streaming
A way to interpret XML fragments as Mapper input records.
StreamXmlRecordReader(FSDataInputStream, FileSplit, Reporter, JobConf, FileSystem) - Constructor for class org.apache.hadoop.streaming.StreamXmlRecordReader
 
StressJobFactory - Class in org.apache.hadoop.mapred.gridmix
 
StressJobFactory(JobSubmitter, JobStoryProducer, Path, Configuration, CountDownLatch, UserResolver) - Constructor for class org.apache.hadoop.mapred.gridmix.StressJobFactory
Creating a new instance does not start the thread.
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
STRING_VALUE_MAX - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
Deprecated.  
STRING_VALUE_MAX - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
STRING_VALUE_MIN - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
Deprecated.  
STRING_VALUE_MIN - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
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.
StringValueMax - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use StringValueMax instead
StringValueMax() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.StringValueMax
Deprecated.  
StringValueMax - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements a value aggregator that maintain the biggest of a sequence of strings.
StringValueMax() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMax
the default constructor
StringValueMin - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use StringValueMin instead
StringValueMin() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.StringValueMin
Deprecated.  
StringValueMin - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements a value aggregator that maintain the smallest of a sequence of strings.
StringValueMin() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMin
the default constructor
submit() - Method in class org.apache.hadoop.mapreduce.Job
Submit the job to the cluster and return immediately.
submit() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Submit this job to mapred.
SUBMIT_REPLICATION - Static variable in class org.apache.hadoop.mapreduce.Job
 
submitAndMonitorJob() - Method in class org.apache.hadoop.streaming.StreamJob
 
submitJob(String) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Submit a job to the MR system.
submitJob(JobConf) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Submit a job to the MR system.
submitJob(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Deprecated. Use Submitter.runJob(JobConf)
Submitter - Class in org.apache.hadoop.mapred.pipes
The main entry point and job submitter.
Submitter() - Constructor for class org.apache.hadoop.mapred.pipes.Submitter
 
Submitter(Configuration) - Constructor for class org.apache.hadoop.mapred.pipes.Submitter
 
SubmitterUserResolver - Class in org.apache.hadoop.mapred.gridmix
Resolves all UGIs to the submitting user.
SubmitterUserResolver() - Constructor for class org.apache.hadoop.mapred.gridmix.SubmitterUserResolver
 
SUBSTITUTE_TOKEN - Static variable in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
If users are providing their own query, the following string is expected to appear in the WHERE clause, which will be substituted with a pair of conditions on the input to allow input splits to parallelise the import.
SUCCEEDED - Static variable in class org.apache.hadoop.mapred.JobStatus
Deprecated.  
SUCCEEDED_FILE_NAME - Static variable in class org.apache.hadoop.mapred.FileOutputCommitter
 
SUCCEEDED_FILE_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
 
SUCCESS - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated.  
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.
sum(Counters, Counters) - Static method in class org.apache.hadoop.mapred.Counters
Deprecated. Convenience method for computing the sum of two sets of counters.
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
 
suspend() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
suspend the running thread
symbol - Variable in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
A symbol

T

tag - Variable in class org.apache.hadoop.contrib.utils.join.TaggedMapOutput
 
TaggedMapOutput - Class in org.apache.hadoop.contrib.utils.join
This abstract class serves as the base class for the values that flow from the mappers to the reducers in a data join job.
TaggedMapOutput() - Constructor for class org.apache.hadoop.contrib.utils.join.TaggedMapOutput
 
TASK - Static variable in class org.apache.hadoop.mapreduce.TaskID
 
Task20LineHistoryEventEmitter - Class in org.apache.hadoop.tools.rumen
 
Task20LineHistoryEventEmitter() - Constructor for class org.apache.hadoop.tools.rumen.Task20LineHistoryEventEmitter
 
TaskAttempt20LineEventEmitter - Class in org.apache.hadoop.tools.rumen
 
TaskAttempt20LineEventEmitter() - Constructor for class org.apache.hadoop.tools.rumen.TaskAttempt20LineEventEmitter
 
TaskAttemptContext - Interface in org.apache.hadoop.mapred
Deprecated. Use TaskAttemptContext instead.
TaskAttemptContext - Interface in org.apache.hadoop.mapreduce
The context for task attempts.
TaskAttemptContextImpl.DummyReporter - Class in org.apache.hadoop.mapreduce.task
 
TaskAttemptContextImpl.DummyReporter() - Constructor for class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl.DummyReporter
 
TaskAttemptID - Class in org.apache.hadoop.mapred
Deprecated. 
TaskAttemptID(TaskID, int) - Constructor for class org.apache.hadoop.mapred.TaskAttemptID
Deprecated. Constructs a TaskAttemptID object from given TaskID.
TaskAttemptID(String, int, boolean, int, int) - Constructor for class org.apache.hadoop.mapred.TaskAttemptID
Deprecated. Use TaskAttemptID.TaskAttemptID(String, int, TaskType, int, int).
TaskAttemptID(String, int, TaskType, int, int) - Constructor for class org.apache.hadoop.mapred.TaskAttemptID
Deprecated. Constructs a TaskId object from given parts.
TaskAttemptID() - Constructor for class org.apache.hadoop.mapred.TaskAttemptID
Deprecated.  
TaskAttemptID - Class in org.apache.hadoop.mapreduce
TaskAttemptID represents the immutable and unique identifier for a task attempt.
TaskAttemptID(TaskID, int) - Constructor for class org.apache.hadoop.mapreduce.TaskAttemptID
Constructs a TaskAttemptID object from given TaskID.
TaskAttemptID(String, int, TaskType, int, int) - Constructor for class org.apache.hadoop.mapreduce.TaskAttemptID
Constructs a TaskId object from given parts.
TaskAttemptID() - Constructor for class org.apache.hadoop.mapreduce.TaskAttemptID
 
TaskAttemptInfo - Class in org.apache.hadoop.tools.rumen
TaskAttemptInfo is a collection of statistics about a particular task-attempt gleaned from job-history of the job.
TaskAttemptInfo(TaskStatus.State, TaskInfo) - Constructor for class org.apache.hadoop.tools.rumen.TaskAttemptInfo
 
TaskCompletionEvent - Class in org.apache.hadoop.mapred
Deprecated. Use TaskCompletionEvent instead
TaskCompletionEvent() - Constructor for class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated. Default constructor for Writable.
TaskCompletionEvent(int, TaskAttemptID, int, boolean, TaskCompletionEvent.Status, String) - Constructor for class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated. Constructor.
TaskCompletionEvent - Class in org.apache.hadoop.mapreduce
This is used to track task completion events on job tracker.
TaskCompletionEvent() - Constructor for class org.apache.hadoop.mapreduce.TaskCompletionEvent
Default constructor for Writable.
TaskCompletionEvent(int, TaskAttemptID, int, boolean, TaskCompletionEvent.Status, String) - Constructor for class org.apache.hadoop.mapreduce.TaskCompletionEvent
Constructor.
TaskCompletionEvent.Status - Enum in org.apache.hadoop.mapred
Deprecated.  
TaskCompletionEvent.Status - Enum in org.apache.hadoop.mapreduce
 
TaskCounter - Enum in org.apache.hadoop.mapreduce
 
TaskID - Class in org.apache.hadoop.mapred
Deprecated. 
TaskID(JobID, boolean, int) - Constructor for class org.apache.hadoop.mapred.TaskID
Deprecated. Use TaskID.TaskID(String, int, TaskType, int)
TaskID(String, int, boolean, int) - Constructor for class org.apache.hadoop.mapred.TaskID
Deprecated. Use TaskID.TaskID(org.apache.hadoop.mapreduce.JobID, TaskType, int)
TaskID(JobID, TaskType, int) - Constructor for class org.apache.hadoop.mapred.TaskID
Deprecated. Constructs a TaskID object from given JobID.
TaskID(String, int, TaskType, int) - Constructor for class org.apache.hadoop.mapred.TaskID
Deprecated. Constructs a TaskInProgressId object from given parts.
TaskID() - Constructor for class org.apache.hadoop.mapred.TaskID
Deprecated.  
TaskID - Class in org.apache.hadoop.mapreduce
TaskID represents the immutable and unique identifier for a Map or Reduce Task.
TaskID(JobID, TaskType, int) - Constructor for class org.apache.hadoop.mapreduce.TaskID
Constructs a TaskID object from given JobID.
TaskID(String, int, TaskType, int) - Constructor for class org.apache.hadoop.mapreduce.TaskID
Constructs a TaskInProgressId object from given parts.
TaskID() - Constructor for class org.apache.hadoop.mapreduce.TaskID
 
taskInfo - Variable in class org.apache.hadoop.tools.rumen.TaskAttemptInfo
 
TaskInfo - Class in org.apache.hadoop.tools.rumen
 
TaskInfo(long, int, long, int, long) - Constructor for class org.apache.hadoop.tools.rumen.TaskInfo
 
TaskInputOutputContext<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Interface in org.apache.hadoop.mapreduce
A context object that allows input and output from the task.
TaskLog.Reader - Class in org.apache.hadoop.mapred
 
TaskLog.Reader(TaskAttemptID, TaskLog.LogName, long, long, boolean) - Constructor for class org.apache.hadoop.mapred.TaskLog.Reader
Read a log file from start to end positions.
TaskLogAppender - Class in org.apache.hadoop.mapred
A simple log4j-appender for the task child's map-reduce system logs.
TaskLogAppender() - Constructor for class org.apache.hadoop.mapred.TaskLogAppender
 
TaskReport - Class in org.apache.hadoop.mapred
Deprecated. Use TaskReport instead
TaskReport() - Constructor for class org.apache.hadoop.mapred.TaskReport
Deprecated.  
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
TaskStatistics - Class in org.apache.hadoop.vaidya.statistics.job
 
TaskStatistics() - Constructor for class org.apache.hadoop.vaidya.statistics.job.TaskStatistics
 
TaskTrackerInfo - Class in org.apache.hadoop.mapreduce
Information about TaskTracker.
TaskTrackerInfo() - Constructor for class org.apache.hadoop.mapreduce.TaskTrackerInfo
 
TaskTrackerInfo(String) - Constructor for class org.apache.hadoop.mapreduce.TaskTrackerInfo
 
TaskTrackerInfo(String, String, String) - Constructor for class org.apache.hadoop.mapreduce.TaskTrackerInfo
 
TaskType - Enum in org.apache.hadoop.mapreduce
Enum for map, reduce, job-setup, job-cleanup, task-cleanup task types.
TEMP_DIR_NAME - Static variable in class org.apache.hadoop.mapred.FileOutputCommitter
Temporary directory name
TEMP_DIR_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Temporary directory name
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
 
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
 
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
 
TeraOutputFormat.TeraOutputCommitter - Class in org.apache.hadoop.examples.terasort
 
TeraOutputFormat.TeraOutputCommitter(Path, TaskAttemptContext) - Constructor for class org.apache.hadoop.examples.terasort.TeraOutputFormat.TeraOutputCommitter
 
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
 
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
 
TEXT_ID - Static variable in class org.apache.hadoop.streaming.io.IdentifierResolver
 
TextInputFormat - Class in org.apache.hadoop.mapred
Deprecated. Use TextInputFormat instead.
TextInputFormat() - Constructor for class org.apache.hadoop.mapred.TextInputFormat
Deprecated.  
TextInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
An InputFormat for plain text files.
TextInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.TextInputFormat
 
TextInputWriter - Class in org.apache.hadoop.streaming.io
InputWriter that writes the client's input as text.
TextInputWriter() - Constructor for class org.apache.hadoop.streaming.io.TextInputWriter
 
TextOutputFormat<K,V> - Class in org.apache.hadoop.mapred
Deprecated. Use TextOutputFormat instead.
TextOutputFormat() - Constructor for class org.apache.hadoop.mapred.TextOutputFormat
Deprecated.  
TextOutputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.output
An OutputFormat that writes plain text files.
TextOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.TextOutputFormat
 
TextOutputFormat.LineRecordWriter<K,V> - Class in org.apache.hadoop.mapred
Deprecated.  
TextOutputFormat.LineRecordWriter(DataOutputStream, String) - Constructor for class org.apache.hadoop.mapred.TextOutputFormat.LineRecordWriter
Deprecated.  
TextOutputFormat.LineRecordWriter(DataOutputStream) - Constructor for class org.apache.hadoop.mapred.TextOutputFormat.LineRecordWriter
Deprecated.  
TextOutputFormat.LineRecordWriter<K,V> - Class in org.apache.hadoop.mapreduce.lib.output
 
TextOutputFormat.LineRecordWriter(DataOutputStream, String) - Constructor for class org.apache.hadoop.mapreduce.lib.output.TextOutputFormat.LineRecordWriter
 
TextOutputFormat.LineRecordWriter(DataOutputStream) - Constructor for class org.apache.hadoop.mapreduce.lib.output.TextOutputFormat.LineRecordWriter
 
TextOutputReader - Class in org.apache.hadoop.streaming.io
OutputReader that reads the client's output as text.
TextOutputReader() - Constructor for class org.apache.hadoop.streaming.io.TextOutputReader
 
TextSplitter - Class in org.apache.hadoop.mapreduce.lib.db
Implement DBSplitter over text strings.
TextSplitter() - Constructor for class org.apache.hadoop.mapreduce.lib.db.TextSplitter
 
theAggregatorDescriptor - Variable in class org.apache.hadoop.mapreduce.lib.aggregate.UserDefinedValueAggregatorDescriptor
 
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
TokenCache - Class in org.apache.hadoop.mapreduce.security
This class provides user facing APIs for transferring secrets from the job client to the tasks.
TokenCache() - Constructor for class org.apache.hadoop.mapreduce.security.TokenCache
 
TokenCounterMapper - Class in org.apache.hadoop.mapreduce.lib.map
Tokenize the input values and emit each word with a count of 1.
TokenCounterMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.map.TokenCounterMapper
 
TokenCountMapper<K> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use TokenCounterMapper instead.
TokenCountMapper() - Constructor for class org.apache.hadoop.mapred.lib.TokenCountMapper
Deprecated.  
TopologyBuilder - Class in org.apache.hadoop.tools.rumen
Building the cluster topology.
TopologyBuilder() - Constructor for class org.apache.hadoop.tools.rumen.TopologyBuilder
 
toSQLString() - Method in class org.apache.hadoop.vertica.VerticaRecord
 
toSQLString(String, String) - Method in class org.apache.hadoop.vertica.VerticaRecord
 
toString() - Method in class org.apache.hadoop.contrib.index.example.LineDocTextAndOp
 
toString() - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
toString() - Method in class org.apache.hadoop.contrib.index.lucene.ShardWriter
 
toString() - Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp.Op
 
toString() - Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
 
toString() - Method in class org.apache.hadoop.contrib.index.mapred.DocumentID
 
toString() - Method in class org.apache.hadoop.contrib.index.mapred.IntermediateForm
 
toString() - Method in class org.apache.hadoop.contrib.index.mapred.Shard
 
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
toString() - Method in class org.apache.hadoop.mapred.ClusterStatus.BlackListInfo
Deprecated.  
toString() - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Return textual representation of the counter values.
toString() - Method in class org.apache.hadoop.mapred.FileSplit
Deprecated.  
toString() - Method in class org.apache.hadoop.mapred.MultiFileSplit
Deprecated.  
toString() - Method in class org.apache.hadoop.mapreduce.Counters
Return textual representation of the counter values.
toString() - Method in class org.apache.hadoop.mapreduce.ID
 
toString() - Method in class org.apache.hadoop.mapreduce.Job
Dump stats to screen.
toString() - Method in class org.apache.hadoop.mapreduce.JobID
 
toString() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
toString() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UserDefinedValueAggregatorDescriptor
 
toString() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
 
toString() - Method in class org.apache.hadoop.mapreduce.lib.input.FileSplit
 
toString() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
toString() - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Convert Tuple to String as in the following.
toString() - Method in enum org.apache.hadoop.mapreduce.QueueState
 
toString() - Method in class org.apache.hadoop.mapreduce.split.JobSplit.SplitMetaInfo
 
toString() - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
 
toString() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
toString() - Method in class org.apache.hadoop.mapreduce.TaskID
 
toString() - Method in class org.apache.hadoop.tools.rumen.Node
 
toString() - Method in class org.apache.hadoop.tools.rumen.TreePath
 
toString() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritable
Generate a suitable string representation.
TOTAL_BYTES - Static variable in class org.apache.hadoop.examples.RandomTextWriter
 
TOTAL_BYTES - Static variable in class org.apache.hadoop.examples.RandomWriter
 
TotalOrderPartitioner<K extends org.apache.hadoop.io.WritableComparable<?>,V> - Class in org.apache.hadoop.mapred.lib
Deprecated. Use TotalOrderPartitioner
TotalOrderPartitioner() - Constructor for class org.apache.hadoop.mapred.lib.TotalOrderPartitioner
Deprecated.  
TotalOrderPartitioner<K extends org.apache.hadoop.io.WritableComparable<?>,V> - Class in org.apache.hadoop.mapreduce.lib.partition
Partitioner effecting a total order by reading split points from an externally generated source.
TotalOrderPartitioner() - Constructor for class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
totalSizeInBytes() - Method in class org.apache.hadoop.contrib.index.mapred.IntermediateForm
The total size of files in the directory and ram used by the index writer.
touchFile(String) - Method in class org.apache.hadoop.contrib.index.lucene.FileSystemDirectory
 
TraceBuilder - Class in org.apache.hadoop.tools.rumen
The main driver of the Rumen Parser.
TraceBuilder() - Constructor for class org.apache.hadoop.tools.rumen.TraceBuilder
 
TreePath - Class in org.apache.hadoop.tools.rumen
This describes a path from a node to the root.
TreePath(TreePath, String) - Constructor for class org.apache.hadoop.tools.rumen.TreePath
 
TreePath(TreePath, String, int) - Constructor for class org.apache.hadoop.tools.rumen.TreePath
 
truncate(double) - Static method in class org.apache.hadoop.vaidya.DiagnosticTest
 
tryDivide(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.mapreduce.lib.db.BigDecimalSplitter
Divide numerator by denominator.
TupleWritable - Class in org.apache.hadoop.mapred.join
Deprecated. Use TupleWritable instead
TupleWritable() - Constructor for class org.apache.hadoop.mapred.join.TupleWritable
Deprecated. Create an empty tuple with no allocated storage for writables.
TupleWritable(Writable[]) - Constructor for class org.apache.hadoop.mapred.join.TupleWritable
Deprecated. Initialize tuple with storage; unknown whether any of them contain "written" values.
TupleWritable - Class in org.apache.hadoop.mapreduce.lib.join
Writable type storing multiple Writables.
TupleWritable() - Constructor for class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Create an empty tuple with no allocated storage for writables.
TupleWritable(Writable[]) - Constructor for class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Initialize tuple with storage; unknown whether any of them contain "written" values.
twoRotations - Static variable in class org.apache.hadoop.examples.dancing.Pentomino
Is the piece identical if rotated 180 degrees?
Type - Enum in org.apache.hadoop.typedbytes
The possible type codes.
TYPE_SEPARATOR - Static variable in interface org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorDescriptor
Deprecated.  
TYPE_SEPARATOR - Static variable in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorDescriptor
 
TYPED_BYTES_ID - Static variable in class org.apache.hadoop.streaming.io.IdentifierResolver
 
TypedBytesInput - Class in org.apache.hadoop.typedbytes
Provides functionality for reading typed bytes.
TypedBytesInput(DataInput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesInput
Creates a new instance of TypedBytesInput.
TypedBytesInputWriter - Class in org.apache.hadoop.streaming.io
InputWriter that writes the client's input as typed bytes.
TypedBytesInputWriter() - Constructor for class org.apache.hadoop.streaming.io.TypedBytesInputWriter
 
TypedBytesOutput - Class in org.apache.hadoop.typedbytes
Provides functionality for writing typed bytes.
TypedBytesOutput(DataOutput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesOutput
Creates a new instance of TypedBytesOutput.
TypedBytesOutputReader - Class in org.apache.hadoop.streaming.io
OutputReader that reads the client's output as typed bytes.
TypedBytesOutputReader() - Constructor for class org.apache.hadoop.streaming.io.TypedBytesOutputReader
 
TypedBytesRecordInput - Class in org.apache.hadoop.typedbytes
Serializer for records that writes typed bytes.
TypedBytesRecordInput(TypedBytesInput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesRecordInput
Creates a new instance of TypedBytesRecordInput.
TypedBytesRecordInput(DataInput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesRecordInput
Creates a new instance of TypedBytesRecordInput.
TypedBytesRecordOutput - Class in org.apache.hadoop.typedbytes
Deserialized for records that reads typed bytes.
TypedBytesRecordOutput(TypedBytesOutput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
Creates a new instance of TypedBytesRecordOutput.
TypedBytesRecordOutput(DataOutput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
Creates a new instance of TypedBytesRecordOutput.
TypedBytesWritable - Class in org.apache.hadoop.typedbytes
Writable for typed bytes.
TypedBytesWritable() - Constructor for class org.apache.hadoop.typedbytes.TypedBytesWritable
Create a TypedBytesWritable.
TypedBytesWritable(byte[]) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesWritable
Create a TypedBytesWritable with a given byte array as initial value.
TypedBytesWritableInput - Class in org.apache.hadoop.typedbytes
Provides functionality for reading typed bytes as Writable objects.
TypedBytesWritableInput(TypedBytesInput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesWritableInput
Creates a new instance of TypedBytesWritableInput.
TypedBytesWritableInput(DataInput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesWritableInput
Creates a new instance of TypedBytesWritableInput.
TypedBytesWritableOutput - Class in org.apache.hadoop.typedbytes
Provides functionality for writing Writable objects as typed bytes.
TypedBytesWritableOutput(TypedBytesOutput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
Creates a new instance of TypedBytesWritableOutput.
TypedBytesWritableOutput(DataOutput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
Creates a new instance of TypedBytesWritableOutput.

U

UNIQ_VALUE_COUNT - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
Deprecated.  
UNIQ_VALUE_COUNT - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
UniqValueCount - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use UniqValueCount instead
UniqValueCount() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.UniqValueCount
Deprecated. the default constructor
UniqValueCount(long) - Constructor for class org.apache.hadoop.mapred.lib.aggregate.UniqValueCount
Deprecated. constructor
UniqValueCount - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements a value aggregator that dedupes a sequence of objects.
UniqValueCount() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
the default constructor
UniqValueCount(long) - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
constructor
UNPACK_JAR_PATTERN_DEFAULT - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Pattern for the default unpacking behavior for job jars
UPDATE - Static variable in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp.Op
 
update(Statistics.JobStats) - Method in class org.apache.hadoop.mapred.gridmix.SerialJobFactory
SERIAL.
update(Statistics.ClusterStats) - Method in class org.apache.hadoop.mapred.gridmix.StressJobFactory
STRESS Once you get the notification from StatsCollector.Collect the clustermetrics.
UpdateIndex - Class in org.apache.hadoop.contrib.index.main
A distributed "index" is partitioned into "shards".
UpdateIndex() - Constructor for class org.apache.hadoop.contrib.index.main.UpdateIndex
 
UPPER_LIMIT_ON_TASK_VMEM_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.  
URL_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. JDBC Database access URL
URL_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
JDBC Database access URL
USED_GENERIC_PARSER - Static variable in class org.apache.hadoop.mapreduce.Job
 
USER_JAR - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
UserDefinedValueAggregatorDescriptor - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use UserDefinedValueAggregatorDescriptor instead
UserDefinedValueAggregatorDescriptor(String, JobConf) - Constructor for class org.apache.hadoop.mapred.lib.aggregate.UserDefinedValueAggregatorDescriptor
Deprecated.  
UserDefinedValueAggregatorDescriptor - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements a wrapper for a user defined value aggregator descriptor.
UserDefinedValueAggregatorDescriptor(String, Configuration) - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.UserDefinedValueAggregatorDescriptor
 
USERNAME_PROP - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
User name for Vertica
USERNAME_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Deprecated. User name to access the database
USERNAME_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
User name to access the database
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
Utils - Class in org.apache.hadoop.mapred
A utility class.
Utils() - Constructor for class org.apache.hadoop.mapred.Utils
 
Utils.OutputFileUtils - Class in org.apache.hadoop.mapred
 
Utils.OutputFileUtils() - Constructor for class org.apache.hadoop.mapred.Utils.OutputFileUtils
 
Utils.OutputFileUtils.OutputFilesFilter - Class in org.apache.hadoop.mapred
This class filters output(part) files from the given directory It does not accept files with filenames _logs and _SUCCESS.
Utils.OutputFileUtils.OutputFilesFilter() - Constructor for class org.apache.hadoop.mapred.Utils.OutputFileUtils.OutputFilesFilter
 
Utils.OutputFileUtils.OutputLogFilter - Class in org.apache.hadoop.mapred
This class filters log files from directory given It doesnt accept paths having _logs.
Utils.OutputFileUtils.OutputLogFilter() - Constructor for class org.apache.hadoop.mapred.Utils.OutputFileUtils.OutputLogFilter
 

V

value - Variable in class org.apache.hadoop.examples.pi.math.ArithmeticProgression
Starting value
value - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
VALUE_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
 
VALUE_HISTOGRAM - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
Deprecated.  
VALUE_HISTOGRAM - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
ValueAggregator<E> - Interface in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use ValueAggregator instead
ValueAggregator<E> - Interface in org.apache.hadoop.mapreduce.lib.aggregate
This interface defines the minimal protocol for value aggregators.
ValueAggregatorBaseDescriptor - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use ValueAggregatorBaseDescriptor instead
ValueAggregatorBaseDescriptor() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
Deprecated.  
ValueAggregatorBaseDescriptor - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements the common functionalities of the subclasses of ValueAggregatorDescriptor class.
ValueAggregatorBaseDescriptor() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
ValueAggregatorCombiner<K1 extends org.apache.hadoop.io.WritableComparable,V1 extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use ValueAggregatorCombiner instead
ValueAggregatorCombiner() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Deprecated.  
ValueAggregatorCombiner<K1 extends org.apache.hadoop.io.WritableComparable<?>,V1 extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements the generic combiner of Aggregate.
ValueAggregatorCombiner() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorCombiner
 
ValueAggregatorDescriptor - Interface in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use ValueAggregatorDescriptor instead
ValueAggregatorDescriptor - Interface in org.apache.hadoop.mapreduce.lib.aggregate
This interface defines the contract a value aggregator descriptor must support.
ValueAggregatorJob - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use ValueAggregatorJob instead
ValueAggregatorJob() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
Deprecated.  
ValueAggregatorJob - Class in org.apache.hadoop.mapreduce.lib.aggregate
This is the main class for creating a map/reduce job using Aggregate framework.
ValueAggregatorJob() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
 
ValueAggregatorJobBase<K1 extends org.apache.hadoop.io.WritableComparable,V1 extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use ValueAggregatorJobBase instead
ValueAggregatorJobBase() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
Deprecated.  
ValueAggregatorJobBase<K1 extends org.apache.hadoop.io.WritableComparable<?>,V1 extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.aggregate
This abstract class implements some common functionalities of the the generic mapper, reducer and combiner classes of Aggregate.
ValueAggregatorJobBase() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
ValueAggregatorMapper<K1 extends org.apache.hadoop.io.WritableComparable,V1 extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use ValueAggregatorMapper instead
ValueAggregatorMapper() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorMapper
Deprecated.  
ValueAggregatorMapper<K1 extends org.apache.hadoop.io.WritableComparable<?>,V1 extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements the generic mapper of Aggregate.
ValueAggregatorMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorMapper
 
ValueAggregatorReducer<K1 extends org.apache.hadoop.io.WritableComparable,V1 extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use ValueAggregatorReducer instead
ValueAggregatorReducer() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorReducer
Deprecated.  
ValueAggregatorReducer<K1 extends org.apache.hadoop.io.WritableComparable<?>,V1 extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements the generic reducer of Aggregate.
ValueAggregatorReducer() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorReducer
 
valueAt(double) - Method in class org.apache.hadoop.tools.rumen.CDFPiecewiseLinearRandomGenerator
TODO This code assumes that the empirical minimum resp.
valueAt(double) - Method in class org.apache.hadoop.tools.rumen.CDFRandomGenerator
 
ValueHistogram - Class in org.apache.hadoop.mapred.lib.aggregate
Deprecated. Use ValueHistogram instead
ValueHistogram() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueHistogram
Deprecated.  
ValueHistogram - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements a value aggregator that computes the histogram of a sequence of strings.
ValueHistogram() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueHistogram
 
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.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.gridmix.JobCreator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.JobClient.TaskStatusFilter
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.JobPriority
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.join.Parser.TType
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.TaskCompletionEvent.Status
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.Cluster.JobTrackerStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.Job.JobState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.Job.TaskStatusFilter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.JobCounter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.JobPriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.JobStatus.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl.ThreadState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.lib.join.Parser.TType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.QueueState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.server.jobtracker.State
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.TaskCompletionEvent.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.TaskCounter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.TaskType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.tools.rumen.JobConfPropertyNames
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.tools.rumen.JobHistoryParserFactory.VersionDetector
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.tools.rumen.LoggedJob.JobPriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.tools.rumen.LoggedJob.JobType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.tools.rumen.Pre21JobHistoryConstants.Values
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.typedbytes.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface.JobKeys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface.KeyDataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface.MapTaskKeys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface.ReduceTaskKeys
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.
values() - Static method in enum org.apache.hadoop.mapred.gridmix.JobCreator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapred.JobClient.TaskStatusFilter
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapred.JobPriority
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapred.join.Parser.TType
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapred.TaskCompletionEvent.Status
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.Cluster.JobTrackerStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.Job.JobState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.Job.TaskStatusFilter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.JobCounter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.JobPriority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.JobStatus.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl.ThreadState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.lib.join.Parser.TType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.QueueState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.server.jobtracker.State
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.TaskCompletionEvent.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.TaskCounter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapreduce.TaskType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.tools.rumen.JobConfPropertyNames
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.tools.rumen.JobHistoryParserFactory.VersionDetector
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.tools.rumen.LoggedJob.JobPriority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.tools.rumen.LoggedJob.JobType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.tools.rumen.Pre21JobHistoryConstants.Values
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.typedbytes.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface.JobKeys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface.KeyDataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface.MapTaskKeys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.vaidya.statistics.job.JobStatisticsInterface.ReduceTaskKeys
Returns an array containing the constants of this enum type, in the order they are declared.
verbose - Variable in class org.apache.hadoop.streaming.JarBuilder
 
verbose_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
VERSION - Static variable in class org.apache.hadoop.fs.HarFileSystem
 
VERSION - Static variable in class org.apache.hadoop.tools.HadoopArchives
 
VERSION_3_5 - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Vertica Version Constants
VERTICA_DRIVER_CLASS - Static variable in class org.apache.hadoop.vertica.VerticaConfiguration
Class name for Vertica JDBC Driver
VerticaConfiguration - Class in org.apache.hadoop.vertica
A container for configuration property names for jobs with Vertica input/output.
VerticaInputFormat - Class in org.apache.hadoop.vertica
Input formatter that returns the results of a query executed against Vertica.
VerticaInputFormat() - Constructor for class org.apache.hadoop.vertica.VerticaInputFormat
 
VerticaInputSplit - Class in org.apache.hadoop.vertica
Input split class for reading data from Vertica
VerticaInputSplit() - Constructor for class org.apache.hadoop.vertica.VerticaInputSplit
(@inheritDoc)
VerticaInputSplit(String, List<Object>, long, long) - Constructor for class org.apache.hadoop.vertica.VerticaInputSplit
Set the input query and a list of parameters to substitute when evaluating the query
VerticaOutputFormat - Class in org.apache.hadoop.vertica
Output formatter for loading reducer output to Vertica
VerticaOutputFormat() - Constructor for class org.apache.hadoop.vertica.VerticaOutputFormat
 
VerticaRecord - Class in org.apache.hadoop.vertica
Serializable record for records returned from and written to Vertica
VerticaRecord() - Constructor for class org.apache.hadoop.vertica.VerticaRecord
 
VerticaRecord(List<String>, List<Integer>) - Constructor for class org.apache.hadoop.vertica.VerticaRecord
 
VerticaRecord(List<Object>, boolean) - Constructor for class org.apache.hadoop.vertica.VerticaRecord
 
VerticaRecord(List<String>, List<Integer>, List<Object>, boolean) - Constructor for class org.apache.hadoop.vertica.VerticaRecord
Test interface for junit tests that do not require a database
VerticaRecordReader - Class in org.apache.hadoop.vertica
 
VerticaRecordReader(VerticaInputSplit, Configuration) - Constructor for class org.apache.hadoop.vertica.VerticaRecordReader
 
VerticaRecordWriter - Class in org.apache.hadoop.vertica
 
VerticaRecordWriter(Connection, String, String, String, String) - Constructor for class org.apache.hadoop.vertica.VerticaRecordWriter
 
VerticaStreamingInput - Class in org.apache.hadoop.vertica
 
VerticaStreamingInput() - Constructor for class org.apache.hadoop.vertica.VerticaStreamingInput
 
VerticaStreamingOutput - Class in org.apache.hadoop.vertica
 
VerticaStreamingOutput() - Constructor for class org.apache.hadoop.vertica.VerticaStreamingOutput
 
VerticaStreamingRecordReader - Class in org.apache.hadoop.vertica
 
VerticaStreamingRecordReader(VerticaInputSplit, Configuration) - Constructor for class org.apache.hadoop.vertica.VerticaStreamingRecordReader
 
VerticaStreamingRecordWriter - Class in org.apache.hadoop.vertica
 
VerticaStreamingRecordWriter(Connection, String, String) - Constructor for class org.apache.hadoop.vertica.VerticaStreamingRecordWriter
 
VerticaUtil - Class in org.apache.hadoop.vertica
 
VerticaUtil() - Constructor for class org.apache.hadoop.vertica.VerticaUtil
 
verticaVersion(Configuration, boolean) - Static method in class org.apache.hadoop.vertica.VerticaUtil
 

W

waitForCompletion() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated. Blocks until the job is complete.
waitForCompletion(boolean) - Method in class org.apache.hadoop.mapreduce.Job
Submit the job to the cluster and wait for it to finish.
WAITING - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated.  
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
 
WrappedMapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce.lib.map
A Mapper which wraps a given one to allow custom WrappedMapper.Context implementations.
WrappedMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.map.WrappedMapper
 
WrappedMapper.Context - Class in org.apache.hadoop.mapreduce.lib.map
 
WrappedMapper.Context(MapContext<KEYIN, VALUEIN, KEYOUT, VALUEOUT>) - Constructor for class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
WrappedRecordReader<K extends org.apache.hadoop.io.WritableComparable,U extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.join
Deprecated. Use WrappedRecordReader instead
WrappedRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>,U extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapreduce.lib.join
Proxy class for a RecordReader participating in the join framework.
WrappedRecordReader(int) - Constructor for class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
 
WrappedReducer<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce.lib.reduce
A Reducer which wraps a given one to allow for custom WrappedReducer.Context implementations.
WrappedReducer() - Constructor for class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer
 
WrappedReducer.Context - Class in org.apache.hadoop.mapreduce.lib.reduce
 
WrappedReducer.Context(ReduceContext<KEYIN, VALUEIN, KEYOUT, VALUEOUT>) - Constructor for class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
write(DataOutput) - Method in class org.apache.hadoop.contrib.index.example.LineDocTextAndOp
 
write(DataOutput) - Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
 
write(DataOutput) - Method in class org.apache.hadoop.contrib.index.mapred.DocumentID
 
write(DataOutput) - Method in class org.apache.hadoop.contrib.index.mapred.IntermediateForm
 
write(DataOutput) - Method in class org.apache.hadoop.contrib.index.mapred.Shard
 
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.mapred.ClusterStatus.BlackListInfo
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.mapred.Counters
Deprecated. Write the set of groups.
write(DataOutput) - Method in class org.apache.hadoop.mapred.FileSplit
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
write(DataOutput) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Deprecated. Write splits in the following format.
write(K, V) - Method in class org.apache.hadoop.mapred.lib.FilterOutputFormat.FilterRecordWriter
Deprecated.  
write(K, V) - Method in interface org.apache.hadoop.mapred.RecordWriter
Writes a key/value pair.
write(K, V) - Method in class org.apache.hadoop.mapred.TextOutputFormat.LineRecordWriter
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.Counter
Write the binary representation of the counter
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.CounterGroup
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.Counters
Write the set of groups.
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.ID
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.JobID
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.JobStatus
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat.DataDrivenDBInputSplit
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.NullDBWritable
 
write(PreparedStatement) - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.NullDBWritable
 
write(K, V) - Method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat.DBRecordWriter
Writes a key/value pair.
write(PreparedStatement) - Method in interface org.apache.hadoop.mapreduce.lib.db.DBWritable
Sets the fields of the object in the PreparedStatement.
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.lib.input.FileSplit
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
Write splits in the following format.
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Writes each Writable to out.
write(KEYOUT, VALUEOUT) - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
write(K, V) - Method in class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat.FilterRecordWriter
 
write(String, K, V) - Method in class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
Write key and value to the namedOutput.
write(String, K, V, String) - Method in class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
Write key and value to baseOutputPath using the namedOutput.
write(KEYOUT, VALUEOUT, String) - Method in class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
Write key value to an output file name.
write(K, V) - Method in class org.apache.hadoop.mapreduce.lib.output.TextOutputFormat.LineRecordWriter
 
write(KEYOUT, VALUEOUT) - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.QueueAclsInfo
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.QueueInfo
 
write(K, V) - Method in class org.apache.hadoop.mapreduce.RecordWriter
Writes a key/value pair.
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.split.JobSplit.SplitMetaInfo
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitIndex
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.TaskID
 
write(KEYOUT, VALUEOUT) - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Generate an output key/value pair.
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
 
write(T) - Method in class org.apache.hadoop.tools.rumen.JsonObjectMapperWriter
 
write(Object) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a Java object as a typed bytes sequence.
write(Writable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
write(DataOutput) - Method in class org.apache.hadoop.vertica.VerticaInputSplit
write(DataOutput) - Method in class org.apache.hadoop.vertica.VerticaRecord
 
write(Text, VerticaRecord) - Method in class org.apache.hadoop.vertica.VerticaRecordWriter
 
write(Text, Text) - Method in class org.apache.hadoop.vertica.VerticaStreamingRecordWriter
 
writeArray(ArrayWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeBool(boolean) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a boolean as a typed bytes sequence.
writeBool(boolean, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeBoolean(BooleanWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeBuffer(Buffer, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeByte(byte) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a byte as a typed bytes sequence.
writeByte(byte, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeByte(ByteWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a bytes array as a typed bytes sequence, using a given typecode and length.
writeBytes(byte[], int) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a bytes array as a typed bytes sequence, using a given typecode.
writeBytes(byte[]) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a bytes array as a typed bytes sequence.
writeBytes(Buffer) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a bytes buffer as a typed bytes sequence.
writeBytes(BytesWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeCompressedBytes(DataOutputStream) - Method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat.WritableValueBytes
 
writeDouble(double) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a double as a typed bytes sequence.
writeDouble(double, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeDouble(DoubleWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeFloat(float) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a float as a typed bytes sequence.
writeFloat(float, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeFloat(FloatWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeInputData(long, Path) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
Write random bytes at the path provided.
writeInt(int) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes an integer as a typed bytes sequence.
writeInt(int, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeInt(IntWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeKey(K) - Method in class org.apache.hadoop.streaming.io.InputWriter
Writes an input key.
writeKey(Writable) - Method in class org.apache.hadoop.streaming.io.RawBytesInputWriter
 
writeKey(Object) - Method in class org.apache.hadoop.streaming.io.TextInputWriter
 
writeKey(Object) - Method in class org.apache.hadoop.streaming.io.TypedBytesInputWriter
 
writeList(List) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a list as a typed bytes sequence.
writeListFooter() - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a list footer.
writeListHeader() - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a list header.
writeLong(long) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a long as a typed bytes sequence.
writeLong(long, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeLong(LongWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeMap(Map) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a map as a typed bytes sequence.
writeMap(MapWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeMapHeader(int) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a map header.
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(JobConf, InputSampler.Sampler<K, V>) - Static method in class org.apache.hadoop.mapred.lib.InputSampler
Deprecated.  
writePartitionFile(Job, InputSampler.Sampler<K, V>) - Static method in class org.apache.hadoop.mapreduce.lib.partition.InputSampler
Write a partition file for the given job, using the Sampler provided.
writeRAMFiles(DataOutput, RAMDirectory, String[]) - Static method in class org.apache.hadoop.contrib.index.lucene.RAMDirectoryUtil
Write a number of files from a ram directory to a data output.
writeRaw(byte[]) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a raw sequence of typed bytes.
writeRaw(byte[], int, int) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a raw sequence of typed bytes.
writeRecord(Record) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeSortedMap(SortedMapWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeString(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a string as a typed bytes sequence.
writeString(String, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeText(Text) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeTypedBytes(TypedBytesWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeUncompressedBytes(DataOutputStream) - Method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat.WritableValueBytes
 
writeValue(V) - Method in class org.apache.hadoop.streaming.io.InputWriter
Writes an input value.
writeValue(Writable) - Method in class org.apache.hadoop.streaming.io.RawBytesInputWriter
 
writeValue(Object) - Method in class org.apache.hadoop.streaming.io.TextInputWriter
 
writeValue(Object) - Method in class org.apache.hadoop.streaming.io.TypedBytesInputWriter
 
writeVector(ArrayList) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a vector as a typed bytes sequence.
writeVectorHeader(int) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a vector header.
writeVInt(VIntWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeVLong(VLongWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeWritable(Writable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeXmlToFile(String, Document) - Static method in class org.apache.hadoop.vaidya.util.XMLUtils
This method writes a DOM document to a file
written - Variable in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
 

X

XMLUtils - Class in org.apache.hadoop.vaidya.util
Sample Utility class to work with DOM document
XMLUtils() - Constructor for class org.apache.hadoop.vaidya.util.XMLUtils
 

Z

ZombieCluster - Class in org.apache.hadoop.tools.rumen
ZombieCluster rebuilds the cluster topology using the information obtained from job history logs.
ZombieCluster(LoggedNetworkTopology, MachineNode) - Constructor for class org.apache.hadoop.tools.rumen.ZombieCluster
Construct a homogeneous cluster.
ZombieCluster(Path, MachineNode, Configuration) - Constructor for class org.apache.hadoop.tools.rumen.ZombieCluster
Construct a homogeneous cluster.
ZombieCluster(InputStream, MachineNode) - Constructor for class org.apache.hadoop.tools.rumen.ZombieCluster
Construct a homogeneous cluster.
ZombieJob - Class in org.apache.hadoop.tools.rumen
ZombieJob is a layer above LoggedJob raw JSON objects.
ZombieJob(LoggedJob, ClusterStory, long) - Constructor for class org.apache.hadoop.tools.rumen.ZombieJob
This constructor creates a ZombieJob with the same semantics as the LoggedJob passed in this parameter
ZombieJob(LoggedJob, ClusterStory) - Constructor for class org.apache.hadoop.tools.rumen.ZombieJob
This constructor creates a ZombieJob with the same semantics as the LoggedJob passed in this parameter
ZombieJobProducer - Class in org.apache.hadoop.tools.rumen
Producing JobStorys from job trace.
ZombieJobProducer(Path, ZombieCluster, Configuration) - Constructor for class org.apache.hadoop.tools.rumen.ZombieJobProducer
Constructor
ZombieJobProducer(Path, ZombieCluster, Configuration, long) - Constructor for class org.apache.hadoop.tools.rumen.ZombieJobProducer
Constructor
ZombieJobProducer(InputStream, ZombieCluster) - Constructor for class org.apache.hadoop.tools.rumen.ZombieJobProducer
Constructor
ZombieJobProducer(InputStream, ZombieCluster, long) - Constructor for class org.apache.hadoop.tools.rumen.ZombieJobProducer
Constructor

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

Copyright © 2009 The Apache Software Foundation