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

A

abort() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapOutput
 
abortJob(JobContext, int) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
abortJob(JobContext, int) - Method in class org.apache.hadoop.mapred.OutputCommitter
For aborting an unsuccessful job's output.
abortJob(JobContext, JobStatus.State) - Method in class org.apache.hadoop.mapred.OutputCommitter
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
Discard the task output.
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
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, Path) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
 
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
Discard the task output.
AbstractCounter - Class in org.apache.hadoop.mapreduce.counters
An abstract counter class to provide common implementation of the counter interface in both mapred and mapreduce packages.
AbstractCounter() - Constructor for class org.apache.hadoop.mapreduce.counters.AbstractCounter
 
AbstractCounterGroup<T extends Counter> - Class in org.apache.hadoop.mapreduce.counters
An abstract class to provide common implementation of the generic counter group in both mapred and mapreduce package.
AbstractCounterGroup(String, String, Limits) - Constructor for class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
AbstractCounters<C extends Counter,G extends CounterGroupBase<C>> - Class in org.apache.hadoop.mapreduce.counters
An abstract class to provide common implementation for the Counters container in both mapred and mapreduce packages.
AbstractCounters(CounterGroupFactory<C, G>) - Constructor for class org.apache.hadoop.mapreduce.counters.AbstractCounters
 
AbstractCounters(AbstractCounters<C1, G1>, CounterGroupFactory<C, G>) - Constructor for class org.apache.hadoop.mapreduce.counters.AbstractCounters
Construct from another counters object.
accept(CompositeRecordReader.JoinCollector, K) - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
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
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
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
 
accept(Object) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.MD5Filter
Filtering method If MD5(key) % frequency==0, return true; otherwise return false
accept(Object) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.PercentFilter
Filtering method If record# % frequency==0, return true; otherwise return false
accept(Object) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.RegexFilter
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).
acls - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Deprecated. 
activateOptions() - Method in class org.apache.hadoop.mapred.TaskLogAppender
 
add(InputSplit) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Add an InputSplit to this collection.
add(ComposableRecordReader<K, ? extends V>) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Add a RecordReader to this collection.
add(TupleWritable) - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
 
add(V) - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
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, Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use Job.addArchiveToClassPath(Path) instead
addArchiveToClassPath(Path, Configuration, FileSystem) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Add an archive path to the current set of classpath entries.
addArchiveToClassPath(Path) - Method in class org.apache.hadoop.mapreduce.Job
Add an archive path to the current set of classpath entries.
addCacheArchive(URI, Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use Job.addCacheArchive(URI) instead
addCacheArchive(URI) - Method in class org.apache.hadoop.mapreduce.Job
Add a archives to be localized
addCacheFile(URI, Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use Job.addCacheFile(URI) instead
addCacheFile(URI) - Method in class org.apache.hadoop.mapreduce.Job
Add a file to be localized
addCommand(List<String>, boolean) - Static method in class org.apache.hadoop.mapred.TaskLog
Add quotes to each of the command strings and return as a single string
addCounter(Counters.Counter) - Method in class org.apache.hadoop.mapred.Counters.Group
 
addCounter(String, String, long) - Method in class org.apache.hadoop.mapred.Counters.Group
 
addCounter(T) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
addCounter(String, String, long) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
addCounter(T) - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
Add a counter to this group.
addCounter(String, String, long) - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
Add a counter to this group
addCounter(C) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
addCounter(String, String, long) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
addCounter(C) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
addCounter(String, String, long) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
addDefaults() - Method in class org.apache.hadoop.mapred.join.CompositeInputFormat
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(Job) - Method in class org.apache.hadoop.mapred.jobcontrol.Job
Add a job to this jobs' dependency list.
addDependingJob(ControlledJob) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Add a job to this jobs' dependency list.
addFetchFailedMap(TaskAttemptID) - Method in class org.apache.hadoop.mapred.TaskStatus
Add to the list of maps from which output-fetches failed.
addFileToClassPath(Path, Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use Job.addFileToClassPath(Path) instead
addFileToClassPath(Path, Configuration, FileSystem) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Add a file path to the current set of classpath entries.
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(G) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Add a group.
addGroup(String, String) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Add a new group
addIdentifier(String, Class<?>[], Class<? extends Parser.Node>, Class<? extends ComposableRecordReader>) - Static method in class org.apache.hadoop.mapred.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.
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
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
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
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
Add files in the input path recursively into the results.
addInputPathRecursively(List<FileStatus>, FileSystem, Path, PathFilter) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Add files in the input path recursively into the results.
addInputPaths(JobConf, String) - Static method in class org.apache.hadoop.mapred.FileInputFormat
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.
addJob(ControlledJob) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
Add a new controlled job.
addJob(Job) - 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
Add a collection of jobs
addKnownMap(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.task.reduce.MapHost
 
addKnownMapOutput(String, String, TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
addLocalArchives(Configuration, String) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
addLocalFiles(Configuration, String) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
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
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
Adds a Mapper class to the chain job's JobConf.
addMapper(boolean, Job, Class<? extends Mapper>, Class<?>, Class<?>, Class<?>, Class<?>, Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.chain.Chain
Adds a Mapper class to the chain job.
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.
addMultiNamedOutput(JobConf, String, Class<? extends OutputFormat>, Class<?>, Class<?>) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
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
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.
addTokenForJob(String, Token<JobTokenIdentifier>) - Method in class org.apache.hadoop.mapreduce.security.token.JobTokenSecretManager
Add the job token of a job to cache
advanceState(double, int) - Method in class org.apache.hadoop.mapred.PeriodicStatsAccumulator
 
aggregatorDescriptorList - Variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
 
aggregatorDescriptorList - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
allFinished() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
AMStarted - Class in org.apache.hadoop.mapreduce.jobhistory
 
AMStarted() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Default constructor.
AMStarted(CharSequence, Long, CharSequence, CharSequence, Integer, Integer) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.AMStarted
All-args constructor.
AMStarted.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for AMStarted instances.
AMStartedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record start of a task attempt
AMStartedEvent(ApplicationAttemptId, long, ContainerId, String, int, int) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.AMStartedEvent
Create an event to record the start of an MR AppMaster
AMStartedEvent(ApplicationAttemptId, long, ContainerId, String, int, int, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.AMStartedEvent
Create an event to record the start of an MR AppMaster
append(K, V) - Method in class org.apache.hadoop.mapred.IFile.Writer
 
append(DataInputBuffer, DataInputBuffer) - Method in class org.apache.hadoop.mapred.IFile.Writer
 
append(LoggingEvent) - Method in class org.apache.hadoop.mapred.TaskLogAppender
 
append(K, V) - Method in class org.apache.hadoop.mapreduce.task.reduce.InMemoryWriter
 
append(DataInputBuffer, DataInputBuffer) - Method in class org.apache.hadoop.mapreduce.task.reduce.InMemoryWriter
 
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.
APPLICATION_ATTEMPT_ID - Static variable in interface org.apache.hadoop.mapred.MRConstants
Used on by MRv2
APPLICATION_ATTEMPT_ID - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
APPLICATION_MASTER_CLASS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
applicationAttemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Deprecated. 
areACLsEnabled() - Method in class org.apache.hadoop.mapred.JobACLsManager
 
arrayGet(int[][], int) - Static method in class org.apache.hadoop.mapred.ProgressSplitsBlock
 
arrayGetCPUTime(int[][]) - Static method in class org.apache.hadoop.mapred.ProgressSplitsBlock
 
arrayGetPhysMemKbytes(int[][]) - Static method in class org.apache.hadoop.mapred.ProgressSplitsBlock
 
arrayGetVMemKbytes(int[][]) - Static method in class org.apache.hadoop.mapred.ProgressSplitsBlock
 
arrayGetWallclockTime(int[][]) - Static method in class org.apache.hadoop.mapred.ProgressSplitsBlock
 
ArrayListBackedIterator<X extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.join
This class provides an implementation of ResetableIterator.
ArrayListBackedIterator() - Constructor for class org.apache.hadoop.mapred.join.ArrayListBackedIterator
 
ArrayListBackedIterator(ArrayList<X>) - Constructor for class org.apache.hadoop.mapred.join.ArrayListBackedIterator
 
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
 
attemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
attemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
attemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Deprecated. 
attemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Deprecated. 
attemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
available() - Method in class org.apache.hadoop.mapred.TaskLog.Reader
 
avataar - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Deprecated. 
AvroArrayUtils - Class in org.apache.hadoop.mapreduce.jobhistory
 
AvroArrayUtils() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.AvroArrayUtils
 

B

BackupStore<K,V> - Class in org.apache.hadoop.mapred
BackupStore is an utility class that is used to support the mark-reset functionality of values iterator
BackupStore(Configuration, TaskAttemptID) - Constructor for class org.apache.hadoop.mapred.BackupStore
 
BASE_OUTPUT_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
baseOut - Variable in class org.apache.hadoop.mapred.lib.FilterOutputFormat
 
baseOut - Variable in class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat
 
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
Partition BinaryComparable keys using a configurable part of the bytes array returned by BinaryComparable.getBytes().
BinaryPartitioner() - Constructor for class org.apache.hadoop.mapred.lib.BinaryPartitioner
 
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
 
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
 
buffer - Variable in class org.apache.hadoop.mapred.IFile.Reader
 
bufferSize - Variable in class org.apache.hadoop.mapred.IFile.Reader
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.Event.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
 
build() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated.Builder
 
buildMsgFrom(URL) - Static method in class org.apache.hadoop.mapreduce.security.SecureShuffleUtils
Shuffle specific utils - build string for encoding from URL
buildMsgFrom(HttpServletRequest) - Static method in class org.apache.hadoop.mapreduce.security.SecureShuffleUtils
Shuffle specific utils - build string for encoding from URL
bytesRead - Variable in class org.apache.hadoop.mapred.IFile.Reader
 

C

CACHE_ARCHIVES - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
CACHE_ARCHIVES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_ARCHIVES_SIZES - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
CACHE_ARCHIVES_SIZES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_ARCHIVES_TIMESTAMPS - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
CACHE_ARCHIVES_TIMESTAMPS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_ARCHIVES_VISIBILITIES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_FILE_TIMESTAMPS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_FILE_VISIBILITIES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_FILES - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
CACHE_FILES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_FILES_SIZES - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
CACHE_FILES_SIZES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_FILES_TIMESTAMPS - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
CACHE_LOCALARCHIVES - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
CACHE_LOCALARCHIVES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_LOCALFILES - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
CACHE_LOCALFILES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_SYMLINK - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
CACHE_SYMLINK - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Deprecated. Symlinks are always on and cannot be disabled.
cancelDelegationToken(Token<DelegationTokenIdentifier>) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Use Token.cancel(org.apache.hadoop.conf.Configuration) instead
cancelDelegationToken(Token<DelegationTokenIdentifier>) - Method in class org.apache.hadoop.mapreduce.Cluster
Deprecated. Use Token.cancel(org.apache.hadoop.conf.Configuration) instead
cancelDelegationToken(Token<DelegationTokenIdentifier>) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Cancel a delegation token.
canCommit(TaskAttemptID) - Method in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Polling to know whether the task can go-ahead with commit
captureOutAndError(List<String>, List<String>, File, File, long, boolean) - Static method in class org.apache.hadoop.mapred.TaskLog
Wrap a command in a shell to capture stdout and stderr to files.
Chain - Class in org.apache.hadoop.mapreduce.lib.chain
The Chain class provides all the common functionality for the ChainMapper and the ChainReducer classes.
Chain(boolean) - Constructor for class org.apache.hadoop.mapreduce.lib.chain.Chain
Creates a Chain instance configured for a Mapper or a Reducer.
CHAIN_MAPPER - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
CHAIN_MAPPER_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
CHAIN_MAPPER_CONFIG - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
CHAIN_MAPPER_SIZE - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
CHAIN_REDUCER - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
CHAIN_REDUCER_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
CHAIN_REDUCER_CONFIG - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
ChainMapper - Class in org.apache.hadoop.mapred.lib
The ChainMapper class allows to use multiple Mapper classes within a single Map task.
ChainMapper() - Constructor for class org.apache.hadoop.mapred.lib.ChainMapper
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
The ChainReducer class allows to chain multiple Mapper classes after a Reducer within the Reducer task.
ChainReducer() - Constructor for class org.apache.hadoop.mapred.lib.ChainReducer
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
 
checkAccess(UserGroupInformation, JobACL, String, AccessControlList) - Method in class org.apache.hadoop.mapred.JobACLsManager
If authorization is enabled, checks whether the user (in the callerUGI) is authorized to perform the operation specified by 'jobOperation' on the job by checking if the user is jobOwner or part of job ACL for the specific job operation.
checkCounters(int) - Method in class org.apache.hadoop.mapreduce.counters.Limits
 
checkGroups(int) - Method in class org.apache.hadoop.mapreduce.counters.Limits
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.mapred.FileOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.mapred.lib.db.DBOutputFormat
Check for validity of the output-specification for the job.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.mapred.lib.FilterOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.mapred.lib.LazyOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.mapred.lib.NullOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in interface org.apache.hadoop.mapred.OutputFormat
Check for validity of the output-specification for the job.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
 
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.
Checkpointable - Annotation Type in org.apache.hadoop.mapreduce.task.annotation
Contract representing to the framework that the task can be safely preempted and restarted between invocations of the user-defined function.
checkReducerAlreadySet(boolean, Configuration, String, boolean) - Static method in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
checkURIs(URI[], URI[]) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. This method checks if there is a conflict in the fragment names of the uris.
CLASSIC_FRAMEWORK_NAME - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
CLASSPATH_ARCHIVES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CLASSPATH_FILES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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) and OutputCommitter.abortJob(JobContext, JobStatus.State) instead.
cleanUpPartialOutputForTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.PartialFileOutputCommitter
 
cleanUpPartialOutputForTask(TaskAttemptContext) - Method in interface org.apache.hadoop.mapreduce.lib.output.PartialOutputCommitter
Remove all previously committed outputs from prior executions of this task.
cleanupProgress() - Method in class org.apache.hadoop.mapred.JobStatus
 
cleanupProgress() - Method in interface org.apache.hadoop.mapred.RunningJob
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.
cleanUpTokenReferral(Configuration) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
Remove jobtoken referrals which don't make sense in the context of the task execution.
clear() - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
 
clear() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
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
 
clearAcls() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Clears the value of the 'acls' field
clearApplicationAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Clears the value of the 'applicationAttemptId' field
clearAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'attemptId' field
clearAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'attemptId' field
clearAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Clears the value of the 'attemptId' field
clearAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Clears the value of the 'attemptId' field
clearAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'attemptId' field
clearAvataar() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Clears the value of the 'avataar' field
clearClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'clockSplits' field
clearClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'clockSplits' field
clearClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'clockSplits' field
clearContainerId() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Clears the value of the 'containerId' field
clearContainerId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Clears the value of the 'containerId' field
clearCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'counters' field
clearCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'counters' field
clearCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Clears the value of the 'counters' field
clearCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'counters' field
clearCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Clears the value of the 'counters' field
clearCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Clears the value of the 'counters' field
clearCounts() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
Clears the value of the 'counts' field
clearCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'cpuUsages' field
clearCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'cpuUsages' field
clearCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'cpuUsages' field
clearDiagnostics() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Clears the value of the 'diagnostics' field
clearDisplayName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
Clears the value of the 'displayName' field
clearDisplayName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
Clears the value of the 'displayName' field
clearError() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'error' field
clearError() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Clears the value of the 'error' field
clearEvent() - Method in class org.apache.hadoop.mapreduce.jobhistory.Event.Builder
Clears the value of the 'event' field
clearFailedDueToAttempt() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Clears the value of the 'failedDueToAttempt' field
clearFailedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Clears the value of the 'failedMaps' field
clearFailedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Clears the value of the 'failedReduces' field
clearFinishedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Clears the value of the 'finishedMaps' field
clearFinishedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Clears the value of the 'finishedMaps' field
clearFinishedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Clears the value of the 'finishedReduces' field
clearFinishedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Clears the value of the 'finishedReduces' field
clearFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Clears the value of the 'finishTime' field
clearFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Clears the value of the 'finishTime' field
clearFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'finishTime' field
clearFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'finishTime' field
clearFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Clears the value of the 'finishTime' field
clearFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'finishTime' field
clearFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Clears the value of the 'finishTime' field
clearFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Clears the value of the 'finishTime' field
clearFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated.Builder
Clears the value of the 'finishTime' field
clearGroups() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters.Builder
Clears the value of the 'groups' field
clearHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'hostname' field
clearHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'hostname' field
clearHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Clears the value of the 'hostname' field
clearHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'hostname' field
clearHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Clears the value of the 'httpPort' field
clearJobConfPath() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Clears the value of the 'jobConfPath' field
clearJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Clears the value of the 'jobid' field
clearJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
Clears the value of the 'jobid' field
clearJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Clears the value of the 'jobid' field
clearJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange.Builder
Clears the value of the 'jobid' field
clearJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange.Builder
Clears the value of the 'jobid' field
clearJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged.Builder
Clears the value of the 'jobid' field
clearJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Clears the value of the 'jobid' field
clearJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Clears the value of the 'jobid' field
clearJobName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Clears the value of the 'jobName' field
clearJobQueueName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange.Builder
Clears the value of the 'jobQueueName' field
clearJobQueueName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Clears the value of the 'jobQueueName' field
clearJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Clears the value of the 'jobStatus' field
clearJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged.Builder
Clears the value of the 'jobStatus' field
clearJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Clears the value of the 'jobStatus' field
clearLaunchTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
Clears the value of the 'launchTime' field
clearLaunchTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Clears the value of the 'launchTime' field
clearLocality() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Clears the value of the 'locality' field
clearMapCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Clears the value of the 'mapCounters' field
clearMapFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'mapFinishTime' field
clearMark() - Method in class org.apache.hadoop.mapred.BackupStore
 
clearMark() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
 
clearMark() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterator
 
clearName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
Clears the value of the 'name' field
clearName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
Clears the value of the 'name' field
clearName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters.Builder
Clears the value of the 'name' field
clearNodeManagerHost() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Clears the value of the 'nodeManagerHost' field
clearNodeManagerHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Clears the value of the 'nodeManagerHttpPort' field
clearNodeManagerPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Clears the value of the 'nodeManagerPort' field
clearPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'physMemKbytes' field
clearPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'physMemKbytes' field
clearPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'physMemKbytes' field
clearPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'port' field
clearPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'port' field
clearPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'port' field
clearPriority() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange.Builder
Clears the value of the 'priority' field
clearRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'rackname' field
clearRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'rackname' field
clearRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Clears the value of the 'rackname' field
clearRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'rackname' field
clearReduceCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Clears the value of the 'reduceCounters' field
clearShuffleFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'shuffleFinishTime' field
clearShufflePort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Clears the value of the 'shufflePort' field
clearSortFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'sortFinishTime' field
clearSplitLocations() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Clears the value of the 'splitLocations' field
clearStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Clears the value of the 'startTime' field
clearStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Clears the value of the 'startTime' field
clearStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Clears the value of the 'startTime' field
clearState() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'state' field
clearState() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'state' field
clearState() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Clears the value of the 'state' field
clearStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'status' field
clearStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Clears the value of the 'status' field
clearStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Clears the value of the 'status' field
clearSubmitTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
Clears the value of the 'submitTime' field
clearSubmitTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Clears the value of the 'submitTime' field
clearSuccessfulAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Clears the value of the 'successfulAttemptId' field
clearTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'taskid' field
clearTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'taskid' field
clearTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Clears the value of the 'taskid' field
clearTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Clears the value of the 'taskid' field
clearTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'taskid' field
clearTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Clears the value of the 'taskid' field
clearTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Clears the value of the 'taskid' field
clearTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Clears the value of the 'taskid' field
clearTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated.Builder
Clears the value of the 'taskid' field
clearTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'taskStatus' field
clearTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'taskStatus' field
clearTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Clears the value of the 'taskStatus' field
clearTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'taskType' field
clearTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'taskType' field
clearTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Clears the value of the 'taskType' field
clearTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Clears the value of the 'taskType' field
clearTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'taskType' field
clearTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Clears the value of the 'taskType' field
clearTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Clears the value of the 'taskType' field
clearTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Clears the value of the 'taskType' field
clearTotalCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Clears the value of the 'totalCounters' field
clearTotalMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Clears the value of the 'totalMaps' field
clearTotalReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Clears the value of the 'totalReduces' field
clearTrackerName() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Clears the value of the 'trackerName' field
clearType() - Method in class org.apache.hadoop.mapreduce.jobhistory.Event.Builder
Clears the value of the 'type' field
clearUberized() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Clears the value of the 'uberized' field
clearUserName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Clears the value of the 'userName' field
clearValue() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
Clears the value of the 'value' field
clearVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Clears the value of the 'vMemKbytes' field
clearVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Clears the value of the 'vMemKbytes' field
clearVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Clears the value of the 'vMemKbytes' field
clearWorkflowAdjacencies() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Clears the value of the 'workflowAdjacencies' field
clearWorkflowId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Clears the value of the 'workflowId' field
clearWorkflowName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Clears the value of the 'workflowName' field
clearWorkflowNodeName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Clears the value of the 'workflowNodeName' field
clearWorkflowTags() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Clears the value of the 'workflowTags' field
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
 
ClientDistributedCacheManager - Class in org.apache.hadoop.mapreduce.filecache
Manages internal configuration of the cache by the client for job submission.
ClientDistributedCacheManager() - Constructor for class org.apache.hadoop.mapreduce.filecache.ClientDistributedCacheManager
 
ClientProtocol - Interface in org.apache.hadoop.mapreduce.protocol
Protocol that a JobClient and the central JobTracker use to communicate.
ClientProtocolProvider - Class in org.apache.hadoop.mapreduce.protocol
 
ClientProtocolProvider() - Constructor for class org.apache.hadoop.mapreduce.protocol.ClientProtocolProvider
 
clockSplits - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
clockSplits - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
clockSplits - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
clone() - Method in class org.apache.hadoop.mapred.TaskStatus
 
clone() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
cloneContext(JobContext, Configuration) - Static method in class org.apache.hadoop.mapreduce.ContextFactory
Clone a JobContext or TaskAttemptContext with a new configuration.
cloneMapContext(MapContext<K1, V1, K2, V2>, Configuration, RecordReader<K1, V1>, RecordWriter<K2, V2>) - Static method in class org.apache.hadoop.mapreduce.ContextFactory
Copy a custom WrappedMapper.Context, optionally replacing the input and output.
close() - Method in class org.apache.hadoop.mapred.FixedLengthRecordReader
 
close() - Method in class org.apache.hadoop.mapred.IFile.Reader
 
close() - Method in class org.apache.hadoop.mapred.IFile.Writer
 
close() - Method in class org.apache.hadoop.mapred.IFileInputStream
Close the input stream.
close() - Method in class org.apache.hadoop.mapred.IFileOutputStream
 
close() - Method in class org.apache.hadoop.mapred.JobClient
Close the JobClient.
close() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Close all child RRs.
close() - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
 
close() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
close() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Forward close request to proxied RR.
close() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
 
close() - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Do nothing.
close() - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
 
close() - Method in class org.apache.hadoop.mapred.lib.ChainMapper
Closes the ChainMapper and all the Mappers in the chain.
close() - Method in class org.apache.hadoop.mapred.lib.ChainReducer
Closes the ChainReducer, the Reducer and all the Mappers in the chain.
close() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
close() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
close(Reporter) - Method in class org.apache.hadoop.mapred.lib.db.DBOutputFormat.DBRecordWriter
Close this RecordWriter to future operations.
close() - Method in class org.apache.hadoop.mapred.lib.DelegatingMapper
 
close() - Method in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
 
close(Reporter) - Method in class org.apache.hadoop.mapred.lib.FilterOutputFormat.FilterRecordWriter
 
close() - Method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Closes all the opened named outputs.
close() - Method in class org.apache.hadoop.mapred.LineRecordReader
 
close() - Method in interface org.apache.hadoop.mapred.MapOutputCollector
 
close() - Method in class org.apache.hadoop.mapred.MapReduceBase
Default implementation that does nothing.
close() - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer
 
close() - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.MRResultIterator
 
close() - Method in interface org.apache.hadoop.mapred.RawKeyValueIterator
Closes the iterator so that the underlying streams can be closed.
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
 
close() - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
 
close() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
close() - Method in interface org.apache.hadoop.mapred.ShuffleConsumerPlugin
 
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
 
close() - Method in class org.apache.hadoop.mapreduce.Cluster
Close the Cluster.
close() - Method in class org.apache.hadoop.mapreduce.jobhistory.EventReader
Close the Event reader
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.CombineFileRecordReaderWrapper
 
close() - Method in class org.apache.hadoop.mapreduce.lib.input.DelegatingRecordReader
 
close() - Method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthRecordReader
 
close() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
close() - Method in class org.apache.hadoop.mapreduce.lib.input.LineRecordReader
 
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(ClientProtocol) - Method in class org.apache.hadoop.mapreduce.protocol.ClientProtocolProvider
 
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.mapreduce.task.reduce.InMemoryReader
 
close() - Method in class org.apache.hadoop.mapreduce.task.reduce.InMemoryWriter
 
close() - Method in interface org.apache.hadoop.mapreduce.task.reduce.MergeManager
Called at the end of shuffle.
close() - Method in class org.apache.hadoop.mapreduce.task.reduce.MergeManagerImpl
 
close() - Method in class org.apache.hadoop.mapreduce.task.reduce.Shuffle
 
close() - Method in interface org.apache.hadoop.mapreduce.task.reduce.ShuffleScheduler
 
close() - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
closeConnection() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
closeInMemoryFile(InMemoryMapOutput<K, V>) - Method in class org.apache.hadoop.mapreduce.task.reduce.MergeManagerImpl
 
closeInMemoryMergedFile(InMemoryMapOutput<K, V>) - Method in class org.apache.hadoop.mapreduce.task.reduce.MergeManagerImpl
 
closeOnDiskFile(MergeManagerImpl.CompressAwarePath) - Method in class org.apache.hadoop.mapreduce.task.reduce.MergeManagerImpl
 
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 - Variable in class org.apache.hadoop.mapreduce.tools.CLI
 
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
 
ClusterMetrics(int, 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
Status information on the current state of the Map-Reduce cluster.
ClusterStatus.BlackListInfo - Class in org.apache.hadoop.mapred
Class which encapsulates information about a blacklisted tasktracker.
cmp - Variable in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
 
cmpcl - Variable in class org.apache.hadoop.mapred.join.Parser.Node
 
cmpcl - Variable in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
collect(K, V, int) - Method in interface org.apache.hadoop.mapred.MapOutputCollector
 
collect(K, V, int) - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer
Serialize the key, value to intermediate storage.
collect(K, V) - Method in interface org.apache.hadoop.mapred.OutputCollector
Adds a key/value pair to the output.
collect(K, V) - Method in class org.apache.hadoop.mapred.Task.CombineOutputCollector
 
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
 
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapred.join.InnerJoinRecordReader
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
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
Emit everything from the collector.
combine(RawKeyValueIterator, OutputCollector<K, V>) - Method in class org.apache.hadoop.mapred.Task.CombinerRunner
Run the combiner over a set of inputs.
combine(RawKeyValueIterator, OutputCollector<K, V>) - Method in class org.apache.hadoop.mapred.Task.NewCombinerRunner
 
combine(RawKeyValueIterator, OutputCollector<K, V>) - Method in class org.apache.hadoop.mapred.Task.OldCombinerRunner
 
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.
COMBINE_CLASS_ATTR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
COMBINE_RECORDS_BEFORE_PROGRESS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CombineFileInputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
An abstract InputFormat that returns CombineFileSplit's in InputFormat.getSplits(JobConf, int) method.
CombineFileInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.CombineFileInputFormat
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
A generic RecordReader that can hand out different recordReaders for each chunk in a CombineFileSplit.
CombineFileRecordReader(JobConf, CombineFileSplit, Reporter, Class<RecordReader<K, V>>) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileRecordReader
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.
CombineFileRecordReaderWrapper<K,V> - Class in org.apache.hadoop.mapred.lib
A wrapper class for a record reader that handles a single file split.
CombineFileRecordReaderWrapper(FileInputFormat<K, V>, CombineFileSplit, Configuration, Reporter, Integer) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
CombineFileRecordReaderWrapper<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
A wrapper class for a record reader that handles a single file split.
CombineFileRecordReaderWrapper(FileInputFormat<K, V>, CombineFileSplit, TaskAttemptContext, Integer) - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReaderWrapper
 
CombineFileSplit - Class in org.apache.hadoop.mapred.lib
 
CombineFileSplit() - Constructor for class org.apache.hadoop.mapred.lib.CombineFileSplit
 
CombineFileSplit(JobConf, Path[], long[], long[], String[]) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileSplit
 
CombineFileSplit(JobConf, Path[], long[]) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileSplit
 
CombineFileSplit(CombineFileSplit) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileSplit
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
COMBINER_GROUP_COMPARATOR_CLASS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CombineSequenceFileInputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
Input format that is a CombineFileInputFormat-equivalent for SequenceFileInputFormat.
CombineSequenceFileInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.CombineSequenceFileInputFormat
 
CombineSequenceFileInputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
Input format that is a CombineFileInputFormat-equivalent for SequenceFileInputFormat.
CombineSequenceFileInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineSequenceFileInputFormat
 
CombineTextInputFormat - Class in org.apache.hadoop.mapred.lib
Input format that is a CombineFileInputFormat-equivalent for TextInputFormat.
CombineTextInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.CombineTextInputFormat
 
CombineTextInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
Input format that is a CombineFileInputFormat-equivalent for TextInputFormat.
CombineTextInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineTextInputFormat
 
commit() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapOutput
 
commitJob(JobContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
commitJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
For committing job's output after successful job completion.
commitJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
This method implements the new interface by calling the old method.
commitJob(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
The job has completed so move all committed tasks to the final output dir.
commitJob(JobContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
For committing job's output after successful job completion.
commitPending(TaskAttemptID, TaskStatus) - Method in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Report that the task is complete, but its commit is pending.
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
To promote the task's temporary output to final output location.
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
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, Path) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
 
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
To promote the task's temporary output to final output location.
committer - Variable in class org.apache.hadoop.mapred.Task
 
COMPARATOR_OPTIONS - Static variable in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
 
compare(int, int) - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer
Compare logical range, st i, j MOD offset capacity.
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
 
compare(MapOutput<K, V>, MapOutput<K, V>) - Method in class org.apache.hadoop.mapreduce.task.reduce.MapOutput.MapOutputComparator
 
compareTo(ComposableRecordReader<K, ?>) - Method in class org.apache.hadoop.mapred.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.mapred.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.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.
COMPLETED_MAPS_FOR_REDUCE_SLOWSTART - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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
Refinement of InputFormat requiring implementors to provide ComposableRecordReader instead of RecordReader.
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
Additional operations required of a RecordReader to participate in a join.
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
Convenience method for constructing composite formats.
compose(String, Class<? extends InputFormat>, String...) - Static method in class org.apache.hadoop.mapred.join.CompositeInputFormat
Convenience method for constructing composite formats.
compose(String, Class<? extends InputFormat>, Path...) - Static method in class org.apache.hadoop.mapred.join.CompositeInputFormat
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
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.mapred.join.CompositeInputFormat
 
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
This InputSplit contains a set of child InputSplits.
CompositeInputSplit() - Constructor for class org.apache.hadoop.mapred.join.CompositeInputSplit
 
CompositeInputSplit(int) - Constructor for class org.apache.hadoop.mapred.join.CompositeInputSplit
 
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
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.mapred.join.CompositeRecordReader
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
 
CompressedSplitLineReader - Class in org.apache.hadoop.mapreduce.lib.input
Line reader for compressed splits Reading records from a compressed split is tricky, as the LineRecordReader is using the reported compressed input stream position directly to determine when a split has ended.
CompressedSplitLineReader(SplitCompressionInputStream, Configuration, byte[]) - Constructor for class org.apache.hadoop.mapreduce.lib.input.CompressedSplitLineReader
 
computeHash(byte[], SecretKey) - Static method in class org.apache.hadoop.mapreduce.security.token.JobTokenSecretManager
Compute the HMAC hash of the message using the key
computeSplitSize(long, long, long) - Method in class org.apache.hadoop.mapred.FileInputFormat
 
computeSplitSize(long, long, long) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
conditions - Variable in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
conf - Variable in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
conf - Variable in class org.apache.hadoop.mapred.Task
 
conf - Variable in class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
 
conf - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
conf - Variable in class org.apache.hadoop.mapreduce.task.JobContextImpl
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.FixedLengthInputFormat
 
configure(JobConf) - Method in interface org.apache.hadoop.mapred.JobConfigurable
Initializes a new instance from a JobConf.
configure(JobConf) - Method in class org.apache.hadoop.mapred.KeyValueTextInputFormat
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.aggregate.UserDefinedValueAggregatorDescriptor
Do nothing.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
get the input file name.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Combiner does not need to configure.
configure(JobConf) - Method in interface org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorDescriptor
Configure the object
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.BinaryPartitioner
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.ChainMapper
Configures the ChainMapper and all the Mappers in the chain.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.ChainReducer
Configures the ChainReducer, the Reducer and all the Mappers in the chain.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
Initializes a new instance from a JobConf.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.DelegatingMapper
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.HashPartitioner
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.KeyFieldBasedComparator
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.KeyFieldBasedPartitioner
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.MultithreadedMapRunner
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.NLineInputFormat
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.RegexMapper
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.TotalOrderPartitioner
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.MapReduceBase
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
 
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
configureDB(JobConf, String, String, String, String) - Static method in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Sets the DB access related fields in the JobConf.
configureDB(JobConf, String, String) - Static method in class org.apache.hadoop.mapred.lib.db.DBConfiguration
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.
ConfigUtil - Class in org.apache.hadoop.mapreduce.util
Place holder for deprecated keys in the framework
ConfigUtil() - Constructor for class org.apache.hadoop.mapreduce.util.ConfigUtil
 
connection - Variable in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
constructJobACLs(Configuration) - Method in class org.apache.hadoop.mapred.JobACLsManager
Construct the jobACLs from the configuration so that they can be kept in the memory.
constructQuery(String, String[]) - Method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat
Constructs the query used as the prepared statement to insert data.
containerId - Variable in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Deprecated. 
containerId - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Deprecated. 
contentEquals(Counters.Counter) - Method in class org.apache.hadoop.mapred.Counters.Counter
Deprecated.  
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
 
convertTrackerNameToHostName(String) - Static method in class org.apache.hadoop.mapreduce.util.HostUtil
 
copyFailed(TaskAttemptID, MapHost, boolean, boolean) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
copySucceeded(TaskAttemptID, MapHost, long, long, MapOutput<K, V>) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
count - Variable in class org.apache.hadoop.mapred.PeriodicStatsAccumulator
 
countCounters() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Returns the total number of counters, by summing the number of counters in each group.
Counter - Interface in org.apache.hadoop.mapreduce
A named counter that tracks the progress of a map/reduce job.
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_NAME_MAX_DEFAULT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
COUNTER_GROUP_NAME_MAX_KEY - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
COUNTER_GROUPS_MAX_DEFAULT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
COUNTER_GROUPS_MAX_KEY - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
COUNTER_MAP_PROCESSED_RECORDS - Static variable in class org.apache.hadoop.mapred.SkipBadRecords
Number of processed map records.
COUNTER_NAME_MAX_DEFAULT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
COUNTER_NAME_MAX_KEY - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
COUNTER_REDUCE_PROCESSED_GROUPS - Static variable in class org.apache.hadoop.mapred.SkipBadRecords
Number of processed reduce groups.
COUNTER_UPDATE_INTERVAL - Static variable in interface org.apache.hadoop.mapred.MRConstants
 
CounterGroup - Interface in org.apache.hadoop.mapreduce
A group of Counters that logically belong together.
CounterGroupBase<T extends Counter> - Interface in org.apache.hadoop.mapreduce.counters
The common counter group interface.
CounterGroupFactory<C extends Counter,G extends CounterGroupBase<C>> - Class in org.apache.hadoop.mapreduce.counters
An abstract class to provide common implementation of the group factory in both mapred and mapreduce packages.
CounterGroupFactory() - Constructor for class org.apache.hadoop.mapreduce.counters.CounterGroupFactory
 
CounterGroupFactory.FrameworkGroupFactory<F> - Interface in org.apache.hadoop.mapreduce.counters
 
Counters - Class in org.apache.hadoop.mapred
A set of named counters.
Counters() - Constructor for class org.apache.hadoop.mapred.Counters
 
Counters(Counters) - Constructor for class org.apache.hadoop.mapred.Counters
 
Counters - Class in org.apache.hadoop.mapreduce
Counters holds per job/task counters, defined either by the Map-Reduce framework or applications.
Counters() - Constructor for class org.apache.hadoop.mapreduce.Counters
Default constructor
Counters(AbstractCounters<C, G>) - Constructor for class org.apache.hadoop.mapreduce.Counters
Construct the Counters object from the another counters object
counters - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
counters - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
counters - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Deprecated. 
counters - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
counters - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Deprecated. 
counters - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Deprecated. 
Counters.Counter - Class in org.apache.hadoop.mapred
A counter record, comprising its name and value.
Counters.Counter() - Constructor for class org.apache.hadoop.mapred.Counters.Counter
 
Counters.CountersExceededException - Exception in org.apache.hadoop.mapred
Counter exception thrown when the number of counters exceed the limit
Counters.CountersExceededException(String) - Constructor for exception org.apache.hadoop.mapred.Counters.CountersExceededException
 
Counters.CountersExceededException(Counters.CountersExceededException) - Constructor for exception org.apache.hadoop.mapred.Counters.CountersExceededException
 
Counters.Group - Class in org.apache.hadoop.mapred
Group of counters, comprising of counters from a particular counter Enum class.
Counters.Group() - Constructor for class org.apache.hadoop.mapred.Counters.Group
 
COUNTERS_MAX_DEFAULT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
COUNTERS_MAX_KEY - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CountersStrings - Class in org.apache.hadoop.mapreduce.util
String conversion utilities for counters.
CountersStrings() - Constructor for class org.apache.hadoop.mapreduce.util.CountersStrings
 
counts - Variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Deprecated. 
cpuUsages - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
cpuUsages - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
cpuUsages - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
create(JobConf, TaskAttemptID, Counters.Counter, Task.TaskReporter, OutputCommitter) - Static method in class org.apache.hadoop.mapred.Task.CombinerRunner
 
create(Configuration) - Method in class org.apache.hadoop.mapreduce.protocol.ClientProtocolProvider
 
create(InetSocketAddress, Configuration) - Method in class org.apache.hadoop.mapreduce.protocol.ClientProtocolProvider
 
CREATE_DIR - Static variable in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
createAllSymlink(Configuration, File, File) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated. Internal to MapReduce framework. Use DistributedCacheManager instead.
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
 
createFileSplit(Path, long, long) - Static method in class org.apache.hadoop.mapred.lib.NLineInputFormat
NLineInputFormat uses LineRecordReader, which always reads (and consumes) at least one character out of its upper split boundary.
createFileSplit(Path, long, long) - Static method in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
NLineInputFormat uses LineRecordReader, which always reads (and consumes) at least one character out of its upper split boundary.
createIdentifier() - Method in class org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenSecretManager
 
createIdentifier() - Method in class org.apache.hadoop.mapreduce.security.token.JobTokenSecretManager
Create an empty job token identifier
createInMemoryMerger() - Method in class org.apache.hadoop.mapreduce.task.reduce.MergeManagerImpl
 
createInstance(String) - Static method in class org.apache.hadoop.mapred.lib.aggregate.UserDefinedValueAggregatorDescriptor
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
Create a value to be used internally for joins.
createKey() - Method in class org.apache.hadoop.mapred.FixedLengthRecordReader
 
createKey() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Create a new key value common to all child RRs.
createKey() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Request new key from proxied RR.
createKey() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
 
createKey() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
createKey() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
createKey() - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBRecordReader
Create an object of the appropriate type to be used as a key.
createKey() - Method in class org.apache.hadoop.mapred.LineRecordReader
 
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
 
createKey() - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
 
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.
createLogSyncer() - Static method in class org.apache.hadoop.mapred.TaskLog
 
createMergeManager(ShuffleConsumerPlugin.Context) - Method in class org.apache.hadoop.mapreduce.task.reduce.Shuffle
 
createPassword(JobTokenIdentifier) - Method in class org.apache.hadoop.mapreduce.security.token.JobTokenSecretManager
Create a new password/secret for the given job token identifier.
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.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
 
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.CombineSequenceFileInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineTextInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.DelegatingInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthInputFormat
 
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.
createReduceContext(Reducer<INKEY, INVALUE, OUTKEY, OUTVALUE>, Configuration, TaskAttemptID, RawKeyValueIterator, Counter, Counter, RecordWriter<OUTKEY, OUTVALUE>, OutputCommitter, StatusReporter, RawComparator<INKEY>, Class<INKEY>, Class<INVALUE>) - Static method in class org.apache.hadoop.mapred.Task
 
createSecretKey(byte[]) - Static method in class org.apache.hadoop.mapreduce.security.token.JobTokenSecretManager
Convert the byte[] to a secret key
createSplitFiles(Path, Configuration, FileSystem, List<InputSplit>) - Static method in class org.apache.hadoop.mapreduce.split.JobSplitWriter
 
createSplitFiles(Path, Configuration, FileSystem, T[]) - Static method in class org.apache.hadoop.mapreduce.split.JobSplitWriter
 
createSplitFiles(Path, Configuration, FileSystem, InputSplit[]) - Static method in class org.apache.hadoop.mapreduce.split.JobSplitWriter
 
createSymlink(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. This is a NO-OP.
createSymlink() - Method in class org.apache.hadoop.mapreduce.Job
Deprecated. 
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.mapred.FixedLengthRecordReader
 
createValue() - Method in class org.apache.hadoop.mapred.join.JoinRecordReader
Create an object of the appropriate type to be used as a value.
createValue() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader
Create an object of the appropriate type to be used as a value.
createValue() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Request new value from proxied RR.
createValue() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
 
createValue() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
createValue() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
createValue() - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBRecordReader
Create an object of the appropriate type to be used as a value.
createValue() - Method in class org.apache.hadoop.mapred.LineRecordReader
 
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
 
createValue() - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
 
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
 
createValueAggregatorJob(String[], Class<?>) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
Create an Aggregate based map/reduce job.
createValueAggregatorJob(String[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
Create an Aggregate based map/reduce job.
createValueAggregatorJob(String[], Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
 
createValueAggregatorJob(String[], Class<? extends ValueAggregatorDescriptor>[], Class<?>) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
 
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
 
createValueAggregatorJobs(String[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
 
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
 
credentials - Variable in class org.apache.hadoop.mapreduce.task.JobContextImpl
 
curReader - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
curReader - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
currentKeyLength - Variable in class org.apache.hadoop.mapred.IFile.Reader
 
currentValueLength - Variable in class org.apache.hadoop.mapred.IFile.Reader
 

D

DATA_FIELD_SEPERATOR - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
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
 
dataIn - Variable in class org.apache.hadoop.mapred.IFile.Reader
 
dataPattern - Static variable in class org.apache.hadoop.mapreduce.tools.CLI
 
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
 
dbConf - Variable in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
DBConfiguration - Class in org.apache.hadoop.mapred.lib.db
 
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
 
DBInputFormat<T extends DBWritable> - Class in org.apache.hadoop.mapred.lib.db
 
DBInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.db.DBInputFormat
 
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
A InputSplit that spans a set of rows
DBInputFormat.DBInputSplit() - Constructor for class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBInputSplit
Default Constructor
DBInputFormat.DBInputSplit(long, long) - Constructor for class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBInputSplit
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
A RecordReader that reads records from a SQL table.
DBInputFormat.DBRecordReader(DBInputFormat.DBInputSplit, Class<T>, JobConf) - Constructor for class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBRecordReader
The constructor is kept to be compatible with M/R 1.x
DBInputFormat.DBRecordReader(DBInputFormat.DBInputSplit, Class<T>, JobConf, Connection, DBConfiguration, String, String[], String) - Constructor for class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBRecordReader
 
DBInputFormat.NullDBWritable - Class in org.apache.hadoop.mapred.lib.db
A Class that does nothing, implementing DBWritable
DBInputFormat.NullDBWritable() - Constructor for class org.apache.hadoop.mapred.lib.db.DBInputFormat.NullDBWritable
 
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
 
DBOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.db.DBOutputFormat
 
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
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
 
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
 
dbProductName - Variable in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
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
 
DBWritable - Interface in org.apache.hadoop.mapreduce.lib.db
Objects that are read from/written to a database should implement DBWritable.
DEFAULT_COMBINE_RECORDS_BEFORE_PROGRESS - Static variable in class org.apache.hadoop.mapred.Task
 
DEFAULT_HTTP_HEADER_NAME - Static variable in class org.apache.hadoop.mapreduce.task.reduce.ShuffleHeader
 
DEFAULT_HTTP_HEADER_VERSION - Static variable in class org.apache.hadoop.mapreduce.task.reduce.ShuffleHeader
 
DEFAULT_JOB_ACL_MODIFY_JOB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_JOB_ACL_VIEW_JOB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_JOB_AM_ACCESS_DISABLED - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_JOB_TOKEN_TRACKING_IDS_ENABLED - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_LIST_STATUS_NUM_THREADS - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
DEFAULT_LOG_LEVEL - Static variable in class org.apache.hadoop.mapred.JobConf
Default logging level for map/reduce tasks.
DEFAULT_LOG_LEVEL - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MAP_CPU_VCORES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MAP_MEMORY_MB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MAPRED_ADMIN_JAVA_OPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MAPRED_ADMIN_USER_ENV - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MAPRED_IFILE_READAHEAD - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
DEFAULT_MAPRED_IFILE_READAHEAD_BYTES - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
DEFAULT_MAPRED_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
 
DEFAULT_MAPREDUCE_APP_SUBMISSION_CROSS_PLATFORM - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
DEFAULT_MAPREDUCE_APPLICATION_CLASSPATH - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Default platform-specific CLASSPATH for all YARN MapReduce applications constructed based on client OS syntax.
DEFAULT_MAPREDUCE_CROSS_PLATFORM_APPLICATION_CLASSPATH - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Default CLASSPATH for all YARN MapReduce applications constructed with platform-agnostic syntax.
DEFAULT_MAPREDUCE_MINICLUSTER_CONTROL_RESOURCE_MONITORING - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
DEFAULT_MAPREDUCE_RECOVER_JOB - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
DEFAULT_MAX_SHUFFLE_FETCH_RETRY_DELAY - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_ADMIN_COMMAND_OPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_COMMAND_OPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_COMMIT_WINDOW_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_COMMITTER_CANCEL_TIMEOUT_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_CONTAINERLAUNCHER_THREAD_COUNT_LIMIT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_CPU_VCORES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_HISTORY_COMPLETE_EVENT_FLUSH_TIMEOUT_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_HISTORY_JOB_COMPLETE_UNFLUSHED_MULTIPLIER - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_HISTORY_MAX_UNFLUSHED_COMPLETE_EVENTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_HISTORY_USE_BATCHED_FLUSH_QUEUE_SIZE_THRESHOLD - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_IGNORE_BLACKLISTING_BLACKLISTED_NODE_PERCENT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_JOB_CLIENT_THREAD_COUNT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_JOB_REDUCE_PREEMPTION_LIMIT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_JOB_REDUCE_RAMP_UP_LIMIT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_LOG_BACKUPS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_LOG_KB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_LOG_LEVEL - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_MAX_ATTEMPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_NUM_PROGRESS_SPLITS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_STAGING_DIR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_TASK_ESTIMATOR_SMOOTH_LAMBDA_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_TASK_LISTENER_THREAD_COUNT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_TO_RM_HEARTBEAT_INTERVAL_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_TO_RM_WAIT_INTERVAL_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_AM_VMEM_MB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_CLIENT_MAX_RETRIES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_CLIENT_TO_AM_IPC_MAX_RETRIES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_CLIENT_TO_AM_IPC_MAX_RETRIES_ON_TIMEOUTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_MR_JOB_END_NOTIFICATION_TIMEOUT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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
Name of the queue to which jobs will be submitted, if no queue name is mentioned.
DEFAULT_REDUCE_CPU_VCORES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_REDUCE_MEMORY_MB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_SHELL - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_SLEEPTIME_BEFORE_SIGKILL - Static variable in class org.apache.hadoop.mapreduce.util.ProcessTree
 
DEFAULT_SPLIT_METAINFO_MAXSIZE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DEFAULT_TASK_LOG_BACKUPS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
DelegatingInputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
An InputFormat that delegates behaviour of paths to multiple other InputFormats.
DelegatingInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.DelegatingInputFormat
 
DelegatingInputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
An InputFormat that delegates behavior of paths to multiple other InputFormats.
DelegatingInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.DelegatingInputFormat
 
DelegatingMapper<K1,V1,K2,V2> - Class in org.apache.hadoop.mapred.lib
An Mapper that delegates behaviour of paths to multiple other mappers.
DelegatingMapper() - Constructor for class org.apache.hadoop.mapred.lib.DelegatingMapper
 
DelegatingMapper<K1,V1,K2,V2> - Class in org.apache.hadoop.mapreduce.lib.input
An Mapper that delegates behavior of paths to multiple other mappers.
DelegatingMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.input.DelegatingMapper
 
DelegatingRecordReader<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
This is a delegating RecordReader, which delegates the functionality to the underlying record reader in TaggedInputSplit
DelegatingRecordReader(InputSplit, TaskAttemptContext) - Constructor for class org.apache.hadoop.mapreduce.lib.input.DelegatingRecordReader
Constructs the DelegatingRecordReader.
DELEGATION_KEY_UPDATE_INTERVAL_DEFAULT - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
DELEGATION_KEY_UPDATE_INTERVAL_KEY - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
DELEGATION_TOKEN_MAX_LIFETIME_DEFAULT - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
DELEGATION_TOKEN_MAX_LIFETIME_KEY - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
DELEGATION_TOKEN_RENEW_INTERVAL_DEFAULT - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
DELEGATION_TOKEN_RENEW_INTERVAL_KEY - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
DelegationTokenIdentifier - Class in org.apache.hadoop.mapreduce.security.token.delegation
A delegation token identifier that is specific to MapReduce.
DelegationTokenIdentifier() - Constructor for class org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier
Create an empty delegation token identifier for reading into.
DelegationTokenIdentifier(Text, Text, Text) - Constructor for class org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier
Create a new delegation token identifier
DelegationTokenSecretManager - Class in org.apache.hadoop.mapreduce.security.token.delegation
A MapReduce specific delegation token secret manager.
DelegationTokenSecretManager(long, long, long, long) - Constructor for class org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenSecretManager
Create a secret manager
DelegationTokenSelector - Class in org.apache.hadoop.mapreduce.security.token.delegation
A delegation token that is specialized for MapReduce
DelegationTokenSelector() - Constructor for class org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenSelector
 
deleteLocalFiles() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. 
deleteLocalFiles(String) - Method in class org.apache.hadoop.mapred.JobConf
 
DEPENDENT_FAILED - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
 
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
 
destroy(String, long, boolean, boolean) - Static method in class org.apache.hadoop.mapreduce.util.ProcessTree
Destroy the process-tree.
destroyProcess(String, long, boolean) - Static method in class org.apache.hadoop.mapreduce.util.ProcessTree
Destroy the process.
destroyProcessGroup(String, long, boolean) - Static method in class org.apache.hadoop.mapreduce.util.ProcessTree
Destroy the process group.
determineCacheVisibilities(Configuration, Map<URI, FileStatus>) - Static method in class org.apache.hadoop.mapreduce.filecache.ClientDistributedCacheManager
Determines the visibilities of the distributed cache files and archives.
determineTimestamps(Configuration, Map<URI, FileStatus>) - Static method in class org.apache.hadoop.mapreduce.filecache.ClientDistributedCacheManager
Determines timestamps of files to be cached, and stores those in the configuration.
determineTimestampsAndCacheVisibilities(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.ClientDistributedCacheManager
Determines timestamps of files to be cached, and stores those in the configuration.
diagnostics - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Deprecated. 
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
 
disableChecksumValidation() - Method in class org.apache.hadoop.mapred.IFile.Reader
 
DISABLED_MEMORY_LIMIT - Static variable in class org.apache.hadoop.mapred.JobConf
A value which if set for memory related configuration options, indicates that the options are turned off.
displayJobList(JobStatus[]) - Method in class org.apache.hadoop.mapreduce.tools.CLI
 
displayJobList(JobStatus[], PrintWriter) - Method in class org.apache.hadoop.mapreduce.tools.CLI
 
displayName - Variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Deprecated. 
displayName - Variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Deprecated. 
displayTasks(JobID, String, String) - Method in class org.apache.hadoop.mapred.JobClient
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
DistributedCache - Class in org.apache.hadoop.filecache
Deprecated. 
DistributedCache() - Constructor for class org.apache.hadoop.filecache.DistributedCache
Deprecated.  
DistributedCache - Class in org.apache.hadoop.mapreduce.filecache
Deprecated. 
DistributedCache() - Constructor for class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated.  
done(TaskUmbilicalProtocol, Task.TaskReporter) - Method in class org.apache.hadoop.mapred.Task
 
done(TaskAttemptID) - Method in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Report that the task is successfully completed.
DOUBLE_VALUE_SUM - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
 
DOUBLE_VALUE_SUM - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
DoubleValueSum - Class in org.apache.hadoop.mapred.lib.aggregate
This class implements a value aggregator that sums up a sequence of double values.
DoubleValueSum() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.DoubleValueSum
 
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
doUpdates(MetricsContext) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleClientMetrics
 
downgrade(JobID) - Static method in class org.apache.hadoop.mapred.JobID
Downgrade a new JobID to an old one
downgrade(JobStatus) - Static method in class org.apache.hadoop.mapred.JobStatus
 
downgrade(TaskAttemptID) - Static method in class org.apache.hadoop.mapred.TaskAttemptID
Downgrade a new TaskAttemptID to an old one
downgrade(TaskCompletionEvent) - Static method in class org.apache.hadoop.mapred.TaskCompletionEvent
 
downgrade(TaskID) - Static method in class org.apache.hadoop.mapred.TaskID
Downgrade a new TaskID to an old one
DRIVER_CLASS_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
The JDBC Driver class name
DRIVER_CLASS_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
The JDBC Driver class name

E

emit(TupleWritable) - Method in class org.apache.hadoop.mapred.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.mapred.join.OverrideRecordReader
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
 
EMPTY_ARRAY - Static variable in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
EMPTY_TASK_SPLIT - Static variable in class org.apache.hadoop.mapreduce.split.JobSplit
 
emptyText - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
eof - Variable in class org.apache.hadoop.mapred.IFile.Reader
 
EOF_MARKER - Static variable in class org.apache.hadoop.mapred.IFile
 
equals(Object) - Method in class org.apache.hadoop.mapred.Counters.Counter
 
equals(Object) - Method in class org.apache.hadoop.mapred.Counters.Group
 
equals(Object) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Return true iff compareTo(other) retn true.
equals(Object) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounter
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
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.task.reduce.MapOutput
 
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.mapreduce.TaskReport
 
error - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
error - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Deprecated. 
Event - Class in org.apache.hadoop.mapreduce.jobhistory
 
Event() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.Event
Default constructor.
Event(EventType, Object) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.Event
All-args constructor.
event - Variable in class org.apache.hadoop.mapreduce.jobhistory.Event
Deprecated. 
Event.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for Event instances.
EventReader - Class in org.apache.hadoop.mapreduce.jobhistory
 
EventReader(FileSystem, Path) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.EventReader
Create a new Event Reader
EventReader(DataInputStream) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.EventReader
Create a new Event Reader
Events - Interface in org.apache.hadoop.mapreduce.jobhistory
 
Events.Callback - Interface in org.apache.hadoop.mapreduce.jobhistory
 
EventType - Enum in org.apache.hadoop.mapreduce.jobhistory
 
ExceptionReporter - Interface in org.apache.hadoop.mapreduce.task.reduce
An interface for reporting exceptions to other threads
EXECUTABLE - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
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
 
exitResetMode() - Method in class org.apache.hadoop.mapred.BackupStore
This function is called the ValuesIterator when a mark is called outside of a reset zone.
extend(double, int) - Method in class org.apache.hadoop.mapred.PeriodicStatsAccumulator
This method calls extendInternal at least once.
extendInternal(double, int) - Method in class org.apache.hadoop.mapred.PeriodicStatsAccumulator
adds a new reading to the current bucket.
extractOutputKeyValue(String, String, String, List<Integer>, List<Integer>, int, boolean, boolean) - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
extraData - Variable in class org.apache.hadoop.mapred.Task
 

F

FAILED - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
 
FAILED - Static variable in class org.apache.hadoop.mapred.JobStatus
 
failedDueToAttempt - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Deprecated. 
failedFetch() - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleClientMetrics
 
failedMaps - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Deprecated. 
failedReduces - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Deprecated. 
failedShuffleCounter - Variable in class org.apache.hadoop.mapred.Task
 
failJob(String) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
failTask(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.Job
Fail indicated task attempt.
fatalError(TaskAttemptID, String) - Method in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Report that the task encounted a fatal error.
fieldNames - Variable in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
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
This class implements a mapper/reducer class that can be used to perform field selections in a manner similar to unix cut.
FieldSelectionMapReduce() - Constructor for class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
 
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
 
FILE_NOT_FOUND - Static variable in interface org.apache.hadoop.mapred.MRConstants
 
FileAlreadyExistsException - Exception in org.apache.hadoop.mapred
Used when target file already exists for any operation and is not configured to be overwritten.
FileAlreadyExistsException() - Constructor for exception org.apache.hadoop.mapred.FileAlreadyExistsException
 
FileAlreadyExistsException(String) - Constructor for exception org.apache.hadoop.mapred.FileAlreadyExistsException
 
FileInputFormat<K,V> - Class in org.apache.hadoop.mapred
A base class for file-based InputFormat.
FileInputFormat() - Constructor for class org.apache.hadoop.mapred.FileInputFormat
 
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
 
FileInputFormat.Counter - Enum in org.apache.hadoop.mapred
Deprecated. 
FileInputFormat.Counter - Enum in org.apache.hadoop.mapreduce.lib.input
Deprecated. 
FileInputFormatCounter - Enum in org.apache.hadoop.mapreduce.lib.input
 
fileLength - Variable in class org.apache.hadoop.mapred.IFile.Reader
 
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
FileOutputCommitter(Path, JobContext) - 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
 
FileOutputFormat.Counter - Enum in org.apache.hadoop.mapred
Deprecated. 
FileOutputFormat.Counter - Enum in org.apache.hadoop.mapreduce.lib.output
Deprecated. 
FileOutputFormatCounter - Enum in org.apache.hadoop.mapreduce.lib.output
 
FileSplit - Class in org.apache.hadoop.mapred
A section of an input file.
FileSplit() - Constructor for class org.apache.hadoop.mapred.FileSplit
 
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
Constructs a split with host information
FileSplit(FileSplit) - Constructor for class org.apache.hadoop.mapred.FileSplit
 
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
FILESYSTEM_COUNTER_GROUP - Static variable in class org.apache.hadoop.mapred.Task
Name of the FileSystem counters' group
FileSystemCounter - Enum in org.apache.hadoop.mapreduce
 
FileSystemCounterGroup<C extends Counter> - Class in org.apache.hadoop.mapreduce.counters
An abstract class to provide common implementation of the filesystem counter group in both mapred and mapreduce packages.
FileSystemCounterGroup() - Constructor for class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
FileSystemCounterGroup.FSCounter - Class in org.apache.hadoop.mapreduce.counters
 
FileSystemCounterGroup.FSCounter(String, FileSystemCounter) - Constructor for class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup.FSCounter
 
fillBuffer(InputStream, byte[], boolean) - Method in class org.apache.hadoop.mapreduce.lib.input.CompressedSplitLineReader
 
fillJoinCollector(K) - Method in class org.apache.hadoop.mapred.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.mapred.join.OverrideRecordReader
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
 
filterCounterName(String) - Static method in class org.apache.hadoop.mapreduce.counters.Limits
 
filterGroupName(String) - Static method in class org.apache.hadoop.mapreduce.counters.Limits
 
filterName(String, int) - Static method in class org.apache.hadoop.mapreduce.counters.Limits
 
FilterOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
FilterOutputFormat is a convenience class that wraps OutputFormat.
FilterOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.FilterOutputFormat
 
FilterOutputFormat(OutputFormat<K, V>) - Constructor for class org.apache.hadoop.mapred.lib.FilterOutputFormat
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
FilterRecordWriter is a convenience wrapper class that implements RecordWriter.
FilterOutputFormat.FilterRecordWriter() - Constructor for class org.apache.hadoop.mapred.lib.FilterOutputFormat.FilterRecordWriter
 
FilterOutputFormat.FilterRecordWriter(RecordWriter<K, V>) - Constructor for class org.apache.hadoop.mapred.lib.FilterOutputFormat.FilterRecordWriter
 
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
 
findContainingJar(Class) - Static method in class org.apache.hadoop.mapred.JobConf
Find a jar that contains a class of the same name, if any.
findCounter(String, String) - Method in class org.apache.hadoop.mapred.Counters
 
findCounter(String, int, String) - Method in class org.apache.hadoop.mapred.Counters
Deprecated. use Counters.findCounter(String, String) instead
findCounter(String, String) - Method in class org.apache.hadoop.mapred.Counters.Group
 
findCounter(String, boolean) - Method in class org.apache.hadoop.mapred.Counters.Group
 
findCounter(String) - Method in class org.apache.hadoop.mapred.Counters.Group
 
findCounter(String, String) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
findCounter(String, boolean) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
findCounter(String) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
findCounter(String, String) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Find a counter, create one if necessary
findCounter(Enum<?>) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Find the counter for the given enum.
findCounter(String, FileSystemCounter) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Find the file system counter for the given scheme and enum.
findCounter(String, String) - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
Find a counter in the group.
findCounter(String, boolean) - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
Find a counter in the group
findCounter(String) - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
Find a counter in the group.
findCounter(String, String) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
findCounter(String, boolean) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
findCounter(String) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
findCounter(String, FileSystemCounter) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
findCounter(String, String) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
findCounter(String, boolean) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
findCounter(String) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
findSeparator(byte[], int, int, byte) - Static method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
 
findSeparator(byte[], int, int, byte) - Static method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
finish() - Method in class org.apache.hadoop.mapred.IFileOutputStream
Finishes writing data to the output stream, by writing the checksum bytes to the end.
finishedMaps - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Deprecated. 
finishedMaps - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Deprecated. 
finishedReduces - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Deprecated. 
finishedReduces - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Deprecated. 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Deprecated. 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Deprecated. 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Deprecated. 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Deprecated. 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Deprecated. 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
Deprecated. 
FIXED_RECORD_LENGTH - Static variable in class org.apache.hadoop.mapred.FixedLengthInputFormat
 
FIXED_RECORD_LENGTH - Static variable in class org.apache.hadoop.mapreduce.lib.input.FixedLengthInputFormat
 
FixedLengthInputFormat - Class in org.apache.hadoop.mapred
FixedLengthInputFormat is an input format used to read input files which contain fixed length records.
FixedLengthInputFormat() - Constructor for class org.apache.hadoop.mapred.FixedLengthInputFormat
 
FixedLengthInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
FixedLengthInputFormat is an input format used to read input files which contain fixed length records.
FixedLengthInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.FixedLengthInputFormat
 
FixedLengthRecordReader - Class in org.apache.hadoop.mapred
A reader to read fixed length records from a split.
FixedLengthRecordReader(Configuration, FileSplit, int) - Constructor for class org.apache.hadoop.mapred.FixedLengthRecordReader
 
FixedLengthRecordReader - Class in org.apache.hadoop.mapreduce.lib.input
A reader to read fixed length records from a split.
FixedLengthRecordReader(int) - Constructor for class org.apache.hadoop.mapreduce.lib.input.FixedLengthRecordReader
 
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
 
flush() - Method in interface org.apache.hadoop.mapred.MapOutputCollector
 
flush() - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer
 
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.
FOR_REDUCE_TASK - Static variable in interface org.apache.hadoop.mapred.MRConstants
The reduce task number for which this map output is being transferred
forName(String) - Static method in class org.apache.hadoop.mapred.JobID
Construct a JobId object from given string
forName(String) - Static method in class org.apache.hadoop.mapred.TaskAttemptID
Construct a TaskAttemptID object from given string
forName(String) - Static method in class org.apache.hadoop.mapred.TaskID
 
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
FRAMEWORK_NAME - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
FrameworkCounterGroup<T extends Enum<T>,C extends Counter> - Class in org.apache.hadoop.mapreduce.counters
An abstract class to provide common implementation for the framework counter group in both mapred and mapreduce packages.
FrameworkCounterGroup(Class<T>) - Constructor for class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
FrameworkCounterGroup.FrameworkCounter<T extends Enum<T>> - Class in org.apache.hadoop.mapreduce.counters
A counter facade for framework counters.
FrameworkCounterGroup.FrameworkCounter(T, String) - Constructor for class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup.FrameworkCounter
 
freeHost(MapHost) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
freq - Variable in class org.apache.hadoop.mapreduce.lib.partition.InputSampler.IntervalSampler
 
freq - Variable in class org.apache.hadoop.mapreduce.lib.partition.InputSampler.RandomSampler
 
FROM_MAP_TASK - Static variable in interface org.apache.hadoop.mapred.MRConstants
The map task from which the map output data is being transferred
fromAvro(List<Integer>) - Static method in class org.apache.hadoop.mapreduce.jobhistory.AvroArrayUtils
 
fromEscapedCompactString(String) - Static method in class org.apache.hadoop.mapred.Counters
Convert a stringified (by Counters.makeEscapedCompactString() counter representation into a counter object.
fs - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
fs - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
fsError(TaskAttemptID, String) - Method in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Report that the task encounted a local filesystem error.

G

gcUpdater - Variable in class org.apache.hadoop.mapred.Task
 
generateActualKey(K, V) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
Generate the actual key from the given key/value.
generateActualValue(K, V) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
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
 
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
Generate the file output file name based on the given key and the leaf file name.
generateHash(byte[], SecretKey) - Static method in class org.apache.hadoop.mapreduce.security.SecureShuffleUtils
Base64 encoded hash of msg
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
Generate the leaf name for the output file name.
generateValueAggregator(String) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
 
generateValueAggregator(String, long) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
GenericCounter - Class in org.apache.hadoop.mapreduce.counters
A generic counter implementation
GenericCounter() - Constructor for class org.apache.hadoop.mapreduce.counters.GenericCounter
 
GenericCounter(String, String) - Constructor for class org.apache.hadoop.mapreduce.counters.GenericCounter
 
GenericCounter(String, String, long) - Constructor for class org.apache.hadoop.mapreduce.counters.GenericCounter
 
get(int) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Get ith child InputSplit.
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.Event
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
 
get(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
 
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.
getAclName() - Method in enum org.apache.hadoop.mapred.QueueACL
 
getAclName() - Method in enum org.apache.hadoop.mapreduce.JobACL
Get the name of the ACL.
getAcls() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Gets the value of the 'acls' field
getAcls() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Gets the value of the 'acls' field.
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
Get the names of task trackers in the cluster.
getActiveTrackers() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Get all active trackers in cluster.
getAggregatorDescriptors(Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
getAllCompletedTaskAttempts() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getAllJobs() - Method in class org.apache.hadoop.mapred.JobClient
Get the jobs that are submitted.
getAllJobs() - Method in class org.apache.hadoop.mapreduce.Cluster
Deprecated. Use Cluster.getAllJobStatuses() instead.
getAllJobs() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Get all the jobs submitted.
getAllJobStatuses() - Method in class org.apache.hadoop.mapreduce.Cluster
Get job status for all jobs in the cluster.
getAllTaskAttempts() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
 
getAllTasks() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getAllTaskTypes() - Static method in class org.apache.hadoop.mapreduce.TaskID
 
getAMInfos() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getAndClearKnownMaps() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapHost
 
getAppAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStartedEvent
 
getAppAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.AMInfo
 
getApplicationAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Gets the value of the 'applicationAttemptId' field
getApplicationAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Gets the value of the 'applicationAttemptId' field.
getApplicationId() - Method in class org.apache.hadoop.mapreduce.v2.LogParams
 
getArchiveClassPaths(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use JobContext.getArchiveClassPaths() instead
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
 
getArchiveClassPaths() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the archive entries in classpath as an array of Path
getArchiveTimestamps(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use JobContext.getArchiveTimestamps() instead
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
 
getArchiveTimestamps() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the timestamps of the archives.
getArchiveVisibilities(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Get the booleans on whether the archives are public or not.
getAssignedJobID() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
 
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'attemptId' field
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'attemptId' field.
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the attempt id
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'attemptId' field
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'attemptId' field.
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the attempt id
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Gets the value of the 'attemptId' field
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Gets the value of the 'attemptId' field.
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Get the task attempt id
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Gets the value of the 'attemptId' field
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Gets the value of the 'attemptId' field.
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'attemptId' field
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'attemptId' field.
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.
getAvataar() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Gets the value of the 'avataar' field
getAvataar() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Gets the value of the 'avataar' field.
getAvataar() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the avataar
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
getBaseRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
 
getBaseRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.MultipleSequenceFileOutputFormat
 
getBaseRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.MultipleTextOutputFormat
 
getBaseUrl() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapHost
 
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
Get the names of task trackers in the cluster.
getBlacklistedTrackers() - Method in class org.apache.hadoop.mapred.ClusterStatus
Get the number of blacklisted task trackers in the cluster.
getBlacklistedTrackers() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Get all blacklisted trackers in cluster.
getBlackListedTrackersInfo() - Method in class org.apache.hadoop.mapred.ClusterStatus
Gets the list of blacklisted trackers along with reasons for blacklisting.
getBlackListReport() - Method in class org.apache.hadoop.mapred.ClusterStatus.BlackListInfo
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
 
getBlockIndex(BlockLocation[], long) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
getBoundingValsQuery() - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
 
getBundle(String) - Static method in class org.apache.hadoop.mapreduce.util.ResourceBundles
Get a resource bundle
getCacheArchives(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use JobContext.getCacheArchives() instead
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
 
getCacheArchives() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get cache archives set in the Configuration
getCacheFiles(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use JobContext.getCacheFiles() instead
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
 
getCacheFiles() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get cache files set in the Configuration
getChainElementConf(Configuration, String) - Static method in class org.apache.hadoop.mapreduce.lib.chain.Chain
Creates a Configuration for the Map or Reduce in the chain.
getChecksum() - Method in class org.apache.hadoop.mapred.IFileInputStream
 
getChildQueues(String) - Method in class org.apache.hadoop.mapred.JobClient
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.
getChildQueues(String) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Returns immediate children of queueName.
getChildren() - Method in class org.apache.hadoop.mapred.JobQueueInfo
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.Event
 
getClassSchema() - Static method in enum org.apache.hadoop.mapreduce.jobhistory.EventType
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
 
getClassSchema() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
 
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
Get the information of the current state of the cleanup tasks of a job.
getClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'clockSplits' field
getClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'clockSplits' field.
getClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
 
getClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'clockSplits' field
getClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'clockSplits' field.
getClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
 
getClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'clockSplits' field
getClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'clockSplits' field.
getClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
 
getCluster() - Method in class org.apache.hadoop.mapreduce.Job
 
getClusterHandle() - Method in class org.apache.hadoop.mapred.JobClient
Get a handle to the Cluster
getClusterMetrics() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Get the current status of the cluster
getClusterStatus() - Method in class org.apache.hadoop.mapred.JobClient
Get status information about the Map-Reduce cluster.
getClusterStatus(boolean) - Method in class org.apache.hadoop.mapred.JobClient
Get status information about the Map-Reduce cluster.
getClusterStatus() - Method in class org.apache.hadoop.mapreduce.Cluster
Get current cluster status.
getCodec() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getCollector(String, Reporter) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Gets the output collector for a named output.
getCollector(String, String, Reporter) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Gets the output collector for a multi named output.
getCombineCollector() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getCombinerClass() - Method in class org.apache.hadoop.mapred.JobConf
Get the user-defined combiner class used to combine map-outputs before being sent to the reducers.
getCombinerClass() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
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
 
getCombinerClass() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the combiner class for the job.
getCombinerKeyGroupingComparator() - Method in class org.apache.hadoop.mapred.JobConf
Get the user defined WritableComparable comparator for grouping keys of inputs to the combiner.
getCombinerKeyGroupingComparator() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the user defined RawComparator comparator for grouping keys of inputs to the combiner.
getCombinerKeyGroupingComparator() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getCombinerKeyGroupingComparator() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getCombinerKeyGroupingComparator() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the user defined RawComparator comparator for grouping keys of inputs to the combiner.
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
 
getCommittedTaskPath(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Compute the path where the output of a committed task is stored until the entire job is committed.
getCommittedTaskPath(TaskAttemptContext, Path) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
 
getCommittedTaskPath(int, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Compute the path where the output of a committed task is stored until the entire job is committed for a specific application attempt.
getCommittedTaskPath(int, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.PartialFileOutputCommitter
 
getComparator() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
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.
getCompressedLength() - Method in class org.apache.hadoop.mapred.IFile.Writer
 
getCompressMapOutput() - Method in class org.apache.hadoop.mapred.JobConf
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?
getConditions() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getConf() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
getConf() - Method in class org.apache.hadoop.mapred.MapOutputFile
 
getConf() - Method in class org.apache.hadoop.mapred.Task
 
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
 
getConfiguration() - Method in interface org.apache.hadoop.mapred.RunningJob
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.mapreduce.task.JobContextImpl
Return the configuration for the job.
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
 
getContainerId() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Gets the value of the 'containerId' field
getContainerId() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Gets the value of the 'containerId' field.
getContainerId() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStartedEvent
 
getContainerId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.AMInfo
 
getContainerId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getContainerId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Gets the value of the 'containerId' field
getContainerId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Gets the value of the 'containerId' field.
getContainerId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the ContainerId
getContainerId() - Method in class org.apache.hadoop.mapreduce.v2.LogParams
 
getCopyPhase() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getCounter() - Method in class org.apache.hadoop.mapred.Counters.Counter
 
getCounter(Enum<?>) - Method in class org.apache.hadoop.mapred.Counters
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
 
getCounter(int, String) - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated. use Counters.Group.findCounter(String) instead
getCounter(Counters, String, String) - Method in class org.apache.hadoop.mapred.JobClient
 
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(String, String) - Method in class org.apache.hadoop.mapred.Task.TaskReporter
 
getCounter(Enum<?>) - Method in class org.apache.hadoop.mapred.Task.TaskReporter
 
getCounter(Enum<?>) - Method in class org.apache.hadoop.mapred.TaskAttemptContextImpl
 
getCounter(String, String) - Method in class org.apache.hadoop.mapred.TaskAttemptContextImpl
 
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.StatusReporter
 
getCounter(String, String) - Method in class org.apache.hadoop.mapreduce.StatusReporter
 
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 class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl
 
getCounter(String, String) - Method in class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl
 
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
Get the counter for the given name and create it if it doesn't exist.
getCounterGroupName(String, String) - Static method in class org.apache.hadoop.mapreduce.util.ResourceBundles
Get the counter group display name
getCounterName(String, String, String) - Static method in class org.apache.hadoop.mapreduce.util.ResourceBundles
Get the counter display name
getCounterNameMax() - Static method in class org.apache.hadoop.mapreduce.counters.Limits
 
getCounters() - Method in interface org.apache.hadoop.mapred.RunningJob
Gets the counters for this job.
getCounters() - Method in class org.apache.hadoop.mapred.TaskReport
 
getCounters() - Method in class org.apache.hadoop.mapred.TaskStatus
Get task's counters.
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
 
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
 
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'counters' field
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'counters' field.
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'counters' field
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'counters' field.
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Gets the value of the 'counters' field
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Gets the value of the 'counters' field.
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'counters' field
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'counters' field.
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Gets the value of the 'counters' field
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Gets the value of the 'counters' field.
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
Get task counters
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Gets the value of the 'counters' field
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Gets the value of the 'counters' field.
getCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent
Get task counters
getCountersEnabled(JobConf) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
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.
getCountersMax() - Static method in class org.apache.hadoop.mapreduce.counters.Limits
 
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.
getCounts() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
Gets the value of the 'counts' field
getCounts() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Gets the value of the 'counts' field.
getCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'cpuUsages' field
getCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'cpuUsages' field.
getCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
 
getCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'cpuUsages' field
getCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'cpuUsages' field.
getCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
 
getCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'cpuUsages' field
getCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'cpuUsages' field.
getCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
 
getCredentials() - Method in class org.apache.hadoop.mapred.JobConf
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
 
getCredentials() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
 
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.CombineFileRecordReaderWrapper
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.DelegatingRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.LineRecordReader
 
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 class org.apache.hadoop.mapreduce.task.MapContextImpl
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.task.TaskInputOutputContextImpl
Get the current key.
getCurrentKey() - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Get the current key.
getCurrentStatus() - Method in class org.apache.hadoop.mapreduce.TaskReport
The current status
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.CombineFileRecordReaderWrapper
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.DelegatingRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.LineRecordReader
 
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 class org.apache.hadoop.mapreduce.task.MapContextImpl
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.task.TaskInputOutputContextImpl
Get the current value.
getCurrentValue() - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Get the current value.
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStartedEvent
 
getDatum() - Method in interface org.apache.hadoop.mapreduce.jobhistory.HistoryEvent
Return the Avro datum wrapped by this.
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChangeEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInitedEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChangeEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChangeEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChangedEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletionEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.NormalizedResourceEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStartedEvent
 
getDatum() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdatedEvent
 
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
Get status information about the max available Maps in the cluster.
getDefaultReduces() - Method in class org.apache.hadoop.mapred.JobClient
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
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
Return an iterator wrapping the JoinCollector.
getDelegate() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader
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
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(Text) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Get a new delegation token.
getDelegationToken(Credentials, String) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
Deprecated. Use Credentials.getToken(org.apache.hadoop.io.Text) instead, this method is included for compatibility against Hadoop-1
getDelegationTokens(Configuration, Credentials) - Static method in class org.apache.hadoop.mapreduce.filecache.ClientDistributedCacheManager
For each archive or cache file - get the corresponding delegation token
getDependentJobs() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
getDependingJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
 
getDescription() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapOutput
 
getDiagnosticInfo() - Method in class org.apache.hadoop.mapred.TaskStatus
 
getDiagnostics() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Gets the value of the 'diagnostics' field
getDiagnostics() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Gets the value of the 'diagnostics' field.
getDiagnostics() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletionEvent
Retrieves diagnostics information preserved in the history file
getDiagnostics() - Method in class org.apache.hadoop.mapreduce.TaskReport
A list of error messages.
getDisplayName() - Method in class org.apache.hadoop.mapred.Counters.Counter
 
getDisplayName() - Method in class org.apache.hadoop.mapred.Counters.Group
 
getDisplayName() - Method in interface org.apache.hadoop.mapreduce.Counter
Get the display name of the counter.
getDisplayName() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
getDisplayName() - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
Get the display name of the group.
getDisplayName() - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup.FSCounter
 
getDisplayName() - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
getDisplayName() - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup.FrameworkCounter
 
getDisplayName() - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
getDisplayName() - Method in class org.apache.hadoop.mapreduce.counters.GenericCounter
 
getDisplayName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
Gets the value of the 'displayName' field
getDisplayName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Gets the value of the 'displayName' field.
getDisplayName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
Gets the value of the 'displayName' field
getDisplayName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Gets the value of the 'displayName' field.
getEnd() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit
 
getEntry(MapFile.Reader[], Partitioner<K, V>, K, V) - Static method in class org.apache.hadoop.mapred.MapFileOutputFormat
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
 
getError() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
 
getError() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'error' field
getError() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'error' field.
getError() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the error string
getError() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Gets the value of the 'error' field
getError() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Gets the value of the 'error' field.
getError() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
Get the error string
getErrorInfo() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getEvent() - Method in class org.apache.hadoop.mapreduce.jobhistory.Event.Builder
Gets the value of the 'event' field
getEvent() - Method in class org.apache.hadoop.mapreduce.jobhistory.Event
Gets the value of the 'event' field.
getEventId() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Returns event Id.
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStartedEvent
Get the attempt id
getEventType() - Method in interface org.apache.hadoop.mapreduce.jobhistory.HistoryEvent
Return this event's type.
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
 
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChangeEvent
 
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInitedEvent
Get the event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChangeEvent
Get the event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChangeEvent
 
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChangedEvent
Get the event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletionEvent
Get the event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.NormalizedResourceEvent
 
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Get the event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
Get the event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent
Get event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStartedEvent
Get the event type
getEventType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdatedEvent
Get the event type
getExecutable(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Get the URI of the application's executable.
getFailedAttemptID() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
Get the attempt id due to which the task failed
getFailedDueToAttempt() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Gets the value of the 'failedDueToAttempt' field
getFailedDueToAttempt() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Gets the value of the 'failedDueToAttempt' field.
getFailedDueToAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
 
getFailedJobList() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getFailedJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
 
getFailedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Gets the value of the 'failedMaps' field
getFailedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Gets the value of the 'failedMaps' field.
getFailedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
Get the number of failed maps for the job
getFailedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getFailedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Gets the value of the 'failedReduces' field
getFailedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Gets the value of the 'failedReduces' field.
getFailedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
Get the number of failed reducers for the job
getFailedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getFailedShuffleCounter() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getFailureInfo() - Method in interface org.apache.hadoop.mapred.RunningJob
Get failure info for the job.
getFailureInfo() - Method in class org.apache.hadoop.mapreduce.JobStatus
Gets any available info on the reason of failure of the job.
getFetchFailedMaps() - Method in class org.apache.hadoop.mapred.TaskStatus
Get the list of maps from which output-fetches failed.
getFieldNames() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getFileBlockLocations(FileSystem, FileStatus) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
 
getFileClassPaths(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use JobContext.getFileClassPaths() instead
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
 
getFileClassPaths() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the file entries in classpath as an array of Path
getFileStatus(Configuration, URI) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
getFileStatuses() - Method in class org.apache.hadoop.mapred.LocatedFileStatusFetcher
Start executing and return FileStatuses based on the parameters specified
getFileSystem() - Method in class org.apache.hadoop.mapreduce.Cluster
Get the file system where job-specific files are stored
getFileSystemCounter() - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup.FSCounter
 
getFileSystemCounterNames(String) - Static method in class org.apache.hadoop.mapred.Task
Counters to measure the usage of the different file systems.
getFilesystemName() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
A MapReduce system always operates on a single filesystem.
getFileTimestamps(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use JobContext.getFileTimestamps() instead
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
 
getFileTimestamps() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the timestamps of the files.
getFileVisibilities(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Get the booleans on whether the files are public or not.
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
getFinishedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Gets the value of the 'finishedMaps' field
getFinishedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Gets the value of the 'finishedMaps' field.
getFinishedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
Get the number of finished maps for the job
getFinishedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getFinishedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Gets the value of the 'finishedMaps' field
getFinishedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Gets the value of the 'finishedMaps' field.
getFinishedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletionEvent
Get the number of finished maps
getFinishedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Gets the value of the 'finishedReduces' field
getFinishedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Gets the value of the 'finishedReduces' field.
getFinishedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
Get the number of finished reducers for the job
getFinishedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getFinishedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Gets the value of the 'finishedReduces' field
getFinishedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Gets the value of the 'finishedReduces' field.
getFinishedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletionEvent
Get the number of finished reduces
getFinishTime() - Method in class org.apache.hadoop.mapred.TaskStatus
Get task finish time.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.Job
Get finish time of the job.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Gets the value of the 'finishTime' field
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Gets the value of the 'finishTime' field.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
Get the job finish time
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
 
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Gets the value of the 'finishTime' field
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Gets the value of the 'finishTime' field.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletionEvent
Get the job finish time
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'finishTime' field
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'finishTime' field.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the attempt finish time
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'finishTime' field
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'finishTime' field.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the finish time of the attempt
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Gets the value of the 'finishTime' field
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Gets the value of the 'finishTime' field.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Get the attempt finish time
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'finishTime' field
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'finishTime' field.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the finish time
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Gets the value of the 'finishTime' field
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Gets the value of the 'finishTime' field.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
Get the finish time of the attempt
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Gets the value of the 'finishTime' field
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Gets the value of the 'finishTime' field.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent
Get the task finish time
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated.Builder
Gets the value of the 'finishTime' field
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
Gets the value of the 'finishTime' field.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdatedEvent
Get the task finish time
getFinishTime() - Method in class org.apache.hadoop.mapreduce.JobStatus
Get the finish time of the job.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.TaskReport
Get finish time of task.
getForcedJobStateOnShutDown() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStartedEvent
 
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
 
getFrameworkGroupId(String) - Static method in class org.apache.hadoop.mapreduce.counters.CounterGroupFactory
Get the id of a framework group
getFs() - Method in class org.apache.hadoop.mapred.JobClient
Get a filesystem handle.
getFsStatistics(Path, Configuration) - Static method in class org.apache.hadoop.mapred.Task
Gets a handle to the Statistics instance based on the scheme associated with path.
getGrayListedTaskTrackerCount() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of graylisted trackers in the cluster.
getGraylistedTrackerNames() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. 
getGraylistedTrackers() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. 
getGroup(String) - Method in class org.apache.hadoop.mapred.Counters
 
getGroup(String) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
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
 
getGroupingComparator() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the user defined RawComparator comparator for grouping keys of inputs to the reduce.
getGroupName() - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup.FrameworkCounter
 
getGroupNameMax() - Static method in class org.apache.hadoop.mapreduce.counters.Limits
 
getGroupNames() - Method in class org.apache.hadoop.mapred.Counters
 
getGroupNames() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Returns the names of all counter classes.
getGroups() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters.Builder
Gets the value of the 'groups' field
getGroups() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
Gets the value of the 'groups' field.
getGroupsMax() - Static method in class org.apache.hadoop.mapreduce.counters.Limits
 
getHistoryFile() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getHistoryUrl() - Method in interface org.apache.hadoop.mapred.RunningJob
Get the url where history file is archived.
getHistoryUrl() - Method in class org.apache.hadoop.mapreduce.Job
 
getHost() - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'hostname' field
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'hostname' field.
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the host name
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'hostname' field
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'hostname' field.
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the name of the host where the attempt ran
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Gets the value of the 'hostname' field
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Gets the value of the 'hostname' field.
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Get the host where the attempt executed
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'hostname' field
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'hostname' field.
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the name of the host where the attempt executed
getHostName() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapHost
 
getHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Gets the value of the 'httpPort' field
getHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Gets the value of the 'httpPort' field.
getHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the HTTP port
getID() - Method in interface org.apache.hadoop.mapred.RunningJob
Get the job identifier.
getId() - Method in class org.apache.hadoop.mapreduce.ID
returns the int which represents the identifier
getIncludeAllCounters() - Method in class org.apache.hadoop.mapred.TaskStatus
 
getIndex(int) - Method in class org.apache.hadoop.mapred.SpillRecord
Get spill offsets for given partition.
getIndex(Configuration, String) - Static method in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
getInputBoundingQuery() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
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
 
getInputDirRecursive(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
getInputFieldNames() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getInputFile(int) - Method in class org.apache.hadoop.mapred.MapOutputFile
Return a local reduce input file created earlier
getInputFile(int) - Method in class org.apache.hadoop.mapred.MROutputFiles
Return a local reduce input file created earlier
getInputFileBasedOutputFileName(JobConf, String) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
Generate the outfile name based on a given anme and the input file name.
getInputFileForWrite(TaskID, long) - Method in class org.apache.hadoop.mapred.MapOutputFile
Create a local reduce input file name.
getInputFileForWrite(TaskID, long) - Method in class org.apache.hadoop.mapred.MROutputFiles
Create a local reduce input file name.
getInputFormat() - Method in class org.apache.hadoop.mapred.JobConf
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
 
getInputFormatClass() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the InputFormat class for the job.
getInputOrderBy() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getInputPathFilter(JobConf) - Static method in class org.apache.hadoop.mapred.FileInputFormat
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
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
 
getInputSplit() - Method in interface org.apache.hadoop.mapred.Reporter
Get the InputSplit object for a map.
getInputSplit() - Method in class org.apache.hadoop.mapred.Task.TaskReporter
 
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.
getInputSplit() - Method in class org.apache.hadoop.mapreduce.task.MapContextImpl
Get the input split for this map.
getInputTableName() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
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 and a given Configuration.
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(JobStatus, Configuration) - Static method in class org.apache.hadoop.mapreduce.Job
Creates a new Job with no particular Cluster and given Configuration and JobStatus.
getInstance(Cluster) - Static method in class org.apache.hadoop.mapreduce.Job
Deprecated. Use Job.getInstance()
getInstance(Cluster, Configuration) - Static method in class org.apache.hadoop.mapreduce.Job
Deprecated. Use Job.getInstance(Configuration)
getInstance(Cluster, JobStatus, Configuration) - Static method in class org.apache.hadoop.mapreduce.Job
Creates a new Job with no particular Cluster and given Configuration and JobStatus.
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.
getIsMap() - Method in class org.apache.hadoop.mapred.TaskStatus
 
getJar() - Method in class org.apache.hadoop.mapred.JobConf
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
 
getJar() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the pathname of the job's jar.
getJarUnpackPattern() - Method in class org.apache.hadoop.mapred.JobConf
Get the pattern for jar contents to unpack on the tasktracker
getJob(JobID) - Method in class org.apache.hadoop.mapred.JobClient
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
 
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.jobhistory.JobSubmittedEvent
Get the acls configured for the job
getJobACLs() - Method in class org.apache.hadoop.mapreduce.JobStatus
Get the job acls.
getJobAttemptPath(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Compute the path where the output of a given job attempt will be placed.
getJobAttemptPath(JobContext, Path) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Compute the path where the output of a given job attempt will be placed.
getJobAttemptPath(int) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Compute the path where the output of a given job attempt will be placed.
getJobClient() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
 
getJobConf() - Method in interface org.apache.hadoop.mapred.JobContext
Get the job Configuration
getJobConf() - Method in class org.apache.hadoop.mapred.JobContextImpl
Get the job Configuration
getJobConf() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
 
getJobConf() - Method in class org.apache.hadoop.mapred.MapOutputCollector.Context
 
getJobConf() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getJobConf() - Method in interface org.apache.hadoop.mapred.TaskAttemptContext
 
getJobConf() - Method in class org.apache.hadoop.mapred.TaskAttemptContextImpl
 
getJobConfPath() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getJobConfPath() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Gets the value of the 'jobConfPath' field
getJobConfPath() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Gets the value of the 'jobConfPath' field.
getJobConfPath() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the Path for the Job Configuration file
getJobConfPath(Path) - Static method in class org.apache.hadoop.mapreduce.JobSubmissionFiles
Get the job conf path.
getJobCounters(JobID) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Grab the current job counters
getJobDir(JobID) - Static method in class org.apache.hadoop.mapred.TaskLog
Get the user log directory for the job jobid.
getJobDistCacheArchives(Path) - Static method in class org.apache.hadoop.mapreduce.JobSubmissionFiles
Get the job distributed cache archives path.
getJobDistCacheFiles(Path) - Static method in class org.apache.hadoop.mapreduce.JobSubmissionFiles
Get the job distributed cache files path.
getJobDistCacheLibjars(Path) - Static method in class org.apache.hadoop.mapreduce.JobSubmissionFiles
Get the job distributed cache libjars path.
getJobEndNotificationURI() - Method in class org.apache.hadoop.mapred.JobConf
Get the uri to be invoked in-order to send a notification after the job has completed (success/failure).
getJobFile() - Method in class org.apache.hadoop.mapred.JobProfile
Get the configuration file for the job.
getJobFile() - Method in interface org.apache.hadoop.mapred.RunningJob
Get the path of the submitted job configuration.
getJobFile() - Method in class org.apache.hadoop.mapred.Task
 
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.
getJobHistoryDir() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Gets the directory location of the completed job history files.
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.JobProfile
Get the job id.
getJobId() - Method in class org.apache.hadoop.mapred.JobProfile
Deprecated. use getJobID() instead
getJobId() - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated. use getJobID instead
getJobID() - Method in class org.apache.hadoop.mapred.JobStatus
 
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.Task
Get the job name for this task.
getJobID() - Method in class org.apache.hadoop.mapred.TaskAttemptID
 
getJobID() - Method in class org.apache.hadoop.mapred.TaskID
 
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.JobFinished.Builder
Gets the value of the 'jobid' field
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Gets the value of the 'jobid' field.
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
Get the Job ID
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
Gets the value of the 'jobid' field
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Gets the value of the 'jobid' field.
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChangeEvent
Get the Job ID
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Gets the value of the 'jobid' field
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Gets the value of the 'jobid' field.
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInitedEvent
Get the job ID
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange.Builder
Gets the value of the 'jobid' field
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
Gets the value of the 'jobid' field.
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChangeEvent
Get the Job ID
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange.Builder
Gets the value of the 'jobid' field
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
Gets the value of the 'jobid' field.
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChangeEvent
Get the Job ID
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged.Builder
Gets the value of the 'jobid' field
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
Gets the value of the 'jobid' field.
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChangedEvent
Get the Job Id
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Gets the value of the 'jobid' field
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Gets the value of the 'jobid' field.
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the Job Id
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Gets the value of the 'jobid' field
getJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Gets the value of the 'jobid' field.
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletionEvent
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.security.token.JobTokenIdentifier
Get the jobid
getJobID() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the unique ID for the job.
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
getJobIDsPattern(String, Integer) - Static method in class org.apache.hadoop.mapred.JobID
Deprecated. 
getJobJar(Path) - Static method in class org.apache.hadoop.mapreduce.JobSubmissionFiles
Get the job jar path.
getJobLocalDir() - Method in class org.apache.hadoop.mapred.JobConf
Get job-specific shared directory for use as scratch space
getJobName() - Method in class org.apache.hadoop.mapred.JobConf
Get the user-specified job name.
getJobName() - Method in class org.apache.hadoop.mapred.JobProfile
Get the user-specified job name.
getJobName() - Method in interface org.apache.hadoop.mapred.RunningJob
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
 
getJobName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Gets the value of the 'jobName' field
getJobName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Gets the value of the 'jobName' field.
getJobName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
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.mapreduce.task.JobContextImpl
Get the user-specified job name.
getJobPriority() - Method in class org.apache.hadoop.mapred.JobConf
Get the JobPriority for this job.
getJobPriority() - Method in class org.apache.hadoop.mapred.JobStatus
Return the priority of the job
getJobQueueName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getJobQueueName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange.Builder
Gets the value of the 'jobQueueName' field
getJobQueueName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
Gets the value of the 'jobQueueName' field.
getJobQueueName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChangeEvent
Get the new Job queue name
getJobQueueName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Gets the value of the 'jobQueueName' field
getJobQueueName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Gets the value of the 'jobQueueName' field.
getJobQueueName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the Job queue name
getJobRunState(int) - Static method in class org.apache.hadoop.mapred.JobStatus
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
 
getJobSetupCleanupNeeded() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get whether job-setup and job-cleanup is needed for the job
getJobsFromQueue(String) - Method in class org.apache.hadoop.mapred.JobClient
Gets all the jobs which were added to particular Job Queue
getJobSplitFile(Path) - Static method in class org.apache.hadoop.mapreduce.JobSubmissionFiles
 
getJobSplitMetaFile(Path) - Static method in class org.apache.hadoop.mapreduce.JobSubmissionFiles
 
getJobState() - Method in interface org.apache.hadoop.mapred.RunningJob
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 interface org.apache.hadoop.mapred.RunningJob
Returns a snapshot of the current status, JobStatus, of the Job.
getJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Gets the value of the 'jobStatus' field
getJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Gets the value of the 'jobStatus' field.
getJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged.Builder
Gets the value of the 'jobStatus' field
getJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
Gets the value of the 'jobStatus' field.
getJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Gets the value of the 'jobStatus' field
getJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Gets the value of the 'jobStatus' field.
getJobStatus(JobID) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Grab a handle to a job that is already known to the JobTracker.
getJobStatuses() - Method in class org.apache.hadoop.mapreduce.QueueInfo
Get the jobs submitted to queue
getJobSubmitter(FileSystem, ClientProtocol) - Method in class org.apache.hadoop.mapreduce.Job
Only for mocking via unit tests.
getJobToken(Credentials) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
 
getJobTokenSecret() - Method in class org.apache.hadoop.mapred.Task
Get the job token secret
getJobTrackerState() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. 
getJobTrackerStatus() - Method in class org.apache.hadoop.mapred.ClusterStatus
Get the JobTracker's status.
getJobTrackerStatus() - Method in class org.apache.hadoop.mapreduce.Cluster
Get the JobTracker's status.
getJobTrackerStatus() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Get the JobTracker's status.
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
Should the temporary files for failed tasks be kept?
getKeepTaskFilesPattern() - Method in class org.apache.hadoop.mapred.JobConf
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.mapred.MapTask.MapOutputBuffer.MRResultIterator
 
getKey() - Method in interface org.apache.hadoop.mapred.RawKeyValueIterator
Gets the current raw key.
getKey() - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup.FrameworkCounter
 
getKey() - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
getKeyClass() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
 
getKeyClass() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
The class of key that must be passed to SequenceFileRecordReader.next(Object, Object)..
getKeyClass() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
getKeyClassName() - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
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
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
Get the KeyFieldBasedPartitioner options
getKeyFieldPartitionerOption(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
Get the KeyFieldBasedPartitioner options
getKind() - Method in class org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier
 
getKind() - Method in class org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier
getKind() - Method in class org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier.Renewer
 
getLatestAMInfo() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getLaunchTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getLaunchTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
Gets the value of the 'launchTime' field
getLaunchTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Gets the value of the 'launchTime' field.
getLaunchTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChangeEvent
Get the Job launch time
getLaunchTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Gets the value of the 'launchTime' field
getLaunchTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Gets the value of the 'launchTime' field.
getLaunchTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInitedEvent
Get the launch time
getLeafQueueNames() - Method in class org.apache.hadoop.mapred.QueueManager
Return the set of leaf level queues configured in the system to which jobs are submitted.
getLength() - Method in class org.apache.hadoop.mapred.FileSplit
The number of bytes in the file to process.
getLength() - Method in class org.apache.hadoop.mapred.IFile.Reader
 
getLength() - Method in interface org.apache.hadoop.mapred.InputSplit
Get the total number of bytes in the data of the InputSplit.
getLength() - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Return the aggregate length of all child InputSplits currently added.
getLength(int) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Get the length of ith child InputSplit.
getLength() - Method in class org.apache.hadoop.mapred.Merger.Segment
 
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.mapreduce.task.reduce.InMemoryReader
 
getLengths() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns an array containing the lengths of the files in the split
getLocalCacheArchives(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use JobContext.getLocalCacheArchives() instead
getLocalCacheArchives() - Method in interface org.apache.hadoop.mapreduce.JobContext
Deprecated. the array returned only includes the items the were downloaded. There is no way to map this to what is returned by JobContext.getCacheArchives().
getLocalCacheArchives() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getLocalCacheArchives() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getLocalCacheArchives() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Return the path array of the localized caches
getLocalCacheFiles(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use JobContext.getLocalCacheFiles() instead
getLocalCacheFiles() - Method in interface org.apache.hadoop.mapreduce.JobContext
Deprecated. the array returned only includes the items the were downloaded. There is no way to map this to what is returned by JobContext.getCacheFiles().
getLocalCacheFiles() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getLocalCacheFiles() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getLocalCacheFiles() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Return the path array of the localized files
getLocalDirAllocator() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getLocalDirs() - Method in class org.apache.hadoop.mapred.JobConf
 
getLocalFS() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getLocality() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Gets the value of the 'locality' field
getLocality() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Gets the value of the 'locality' field.
getLocality() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the locality
getLocalMapFiles() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getLocalPath(String) - Method in class org.apache.hadoop.mapred.JobConf
Constructs a local file name.
getLocation(int) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
getLocations from ith InputSplit.
getLocation(int) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
getLocations from ith InputSplit.
getLocations() - Method in class org.apache.hadoop.mapred.FileSplit
 
getLocations() - Method in interface org.apache.hadoop.mapred.InputSplit
Get the list of hostnames where the input split is located.
getLocations() - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Collect a set of hosts from all child InputSplits.
getLocations() - Method in class org.apache.hadoop.mapred.MultiFileSplit
 
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
 
getLogFileParams(JobID, TaskAttemptID) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Gets the location of the log file for a job if no taskAttemptId is specified, otherwise gets the log location for the taskAttemptId.
getLogParams(JobID, TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.Cluster
Get log parameters for the specified jobID or taskAttemptID
getLowerClause() - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat.DataDrivenDBInputSplit
 
getMapCompletionEvents(JobID, int, int, TaskAttemptID) - Method in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Called by a reduce task to get the map output locations for finished maps.
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.JobFinished.Builder
Gets the value of the 'mapCounters' field
getMapCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Gets the value of the 'mapCounters' field.
getMapCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
Get the Map counters for the job
getMapCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getMapDebugScript() - Method in class org.apache.hadoop.mapred.JobConf
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.mapred.TaskStatus
Get map phase finish time for the task.
getMapFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getMapFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'mapFinishTime' field
getMapFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'mapFinishTime' field.
getMapFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the map phase finish time
getMapId() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapOutput
 
getMapOutputCompressorClass(Class<? extends CompressionCodec>) - Method in class org.apache.hadoop.mapred.JobConf
Get the CompressionCodec for compressing the map outputs.
getMapOutputFile() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getMapOutputFile() - Method in class org.apache.hadoop.mapred.Task
 
getMapOutputKeyClass() - Method in class org.apache.hadoop.mapred.JobConf
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
 
getMapOutputKeyClass() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the key class for the map output data.
getMapOutputValueClass() - Method in class org.apache.hadoop.mapred.JobConf
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
 
getMapOutputValueClass() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the value class for the map output data.
getMapper() - Method in class org.apache.hadoop.mapred.MapRunner
 
getMapperClass() - Method in class org.apache.hadoop.mapred.JobConf
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
 
getMapperClass() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the Mapper class for the job.
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.
getMapProgress() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getMapredJobID() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
 
getMapredJobId() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
getMapRunnerClass() - Method in class org.apache.hadoop.mapred.JobConf
Get the MapRunnable class for the job.
getMapsForHost(MapHost) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
getMapSlotCapacity() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the total number of map slots in the cluster.
getMapSpeculativeExecution() - Method in class org.apache.hadoop.mapred.JobConf
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
getMapTask() - Method in class org.apache.hadoop.mapred.MapOutputCollector.Context
 
getMapTaskCompletionEvents() - Method in class org.apache.hadoop.mapred.MapTaskCompletionEventsUpdate
 
getMapTaskReports(JobID) - Method in class org.apache.hadoop.mapred.JobClient
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
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
getMasterAddress(Configuration) - Static method in class org.apache.hadoop.mapred.Master
 
getMasterPrincipal(Configuration) - Static method in class org.apache.hadoop.mapred.Master
 
getMasterUserName(Configuration) - Static method in class org.apache.hadoop.mapred.Master
 
getMaxMapAttempts() - Method in class org.apache.hadoop.mapred.JobConf
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
 
getMaxMapAttempts() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
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.
getMaxMapTaskFailuresPercent() - Method in class org.apache.hadoop.mapred.JobConf
Get the maximum percentage of map tasks that can fail without the job being aborted.
getMaxMapTasks() - Method in class org.apache.hadoop.mapred.ClusterStatus
Get the maximum capacity for running map tasks in the cluster.
getMaxMemory() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. 
getMaxPhysicalMemoryForTask() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated. this variable is deprecated and nolonger in use.
getMaxReduceAttempts() - Method in class org.apache.hadoop.mapred.JobConf
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
 
getMaxReduceAttempts() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
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.
getMaxReduceTaskFailuresPercent() - Method in class org.apache.hadoop.mapred.JobConf
Get the maximum percentage of reduce tasks that can fail without the job being aborted.
getMaxReduceTasks() - Method in class org.apache.hadoop.mapred.ClusterStatus
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.
getMaxStringSize() - Method in class org.apache.hadoop.mapred.TaskStatus
Testcases can override TaskStatus.getMaxStringSize() to control the max-size of strings in TaskStatus.
getMaxTaskFailuresPerTracker() - Method in class org.apache.hadoop.mapred.JobConf
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.mapreduce.jobhistory.NormalizedResourceEvent
the normalized memory
getMemoryForMapTask() - Method in class org.apache.hadoop.mapred.JobConf
Get memory required to run a map task of the job, in MB.
getMemoryForReduceTask() - Method in class org.apache.hadoop.mapred.JobConf
Get memory required to run a reduce task of the job, in MB.
getMergedMapOutputsCounter() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getMergePhase() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
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
 
getMinSplitSize(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Get the minimum split size
getMRv2LogDir() - Static method in class org.apache.hadoop.mapred.TaskLog
 
getName() - Method in class org.apache.hadoop.mapred.Counters.Counter
 
getName() - Method in class org.apache.hadoop.mapred.Counters.Group
 
getName() - Method in interface org.apache.hadoop.mapreduce.Counter
 
getName() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
getName() - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
Get the internal name of the group
getName() - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup.FSCounter
 
getName() - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
getName() - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup.FrameworkCounter
 
getName() - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
getName() - Method in class org.apache.hadoop.mapreduce.counters.GenericCounter
 
getName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
Gets the value of the 'name' field
getName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Gets the value of the 'name' field.
getName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
Gets the value of the 'name' field
getName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Gets the value of the 'name' field.
getName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters.Builder
Gets the value of the 'name' field
getName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
Gets the value of the 'name' field.
getNamedOutputFormatClass(JobConf, String) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Returns the named output OutputFormat.
getNamedOutputKeyClass(JobConf, String) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Returns the key class for a named output.
getNamedOutputs() - Method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Returns iterator with the defined name outputs.
getNamedOutputsList(JobConf) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Returns list of channel names.
getNamedOutputValueClass(JobConf, String) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Returns the value class for a named output.
getNeededMem() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getNewJobID() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Allocate a name for the job.
getNextEvent() - Method in class org.apache.hadoop.mapreduce.jobhistory.EventReader
Get the next event from the stream
getNextRecordRange() - Method in class org.apache.hadoop.mapred.TaskStatus
Get the next record range which is going to be processed by Task.
getNode() - Method in class org.apache.hadoop.mapred.join.Parser.NodeToken
 
getNode() - Method in class org.apache.hadoop.mapred.join.Parser.Token
 
getNode() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.NodeToken
 
getNode() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Token
 
getNodeId() - Method in class org.apache.hadoop.mapreduce.v2.LogParams
 
getNodeManagerHost() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Gets the value of the 'nodeManagerHost' field
getNodeManagerHost() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Gets the value of the 'nodeManagerHost' field.
getNodeManagerHost() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStartedEvent
 
getNodeManagerHost() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.AMInfo
 
getNodeManagerHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Gets the value of the 'nodeManagerHttpPort' field
getNodeManagerHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Gets the value of the 'nodeManagerHttpPort' field.
getNodeManagerHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStartedEvent
 
getNodeManagerHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.AMInfo
 
getNodeManagerPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Gets the value of the 'nodeManagerPort' field
getNodeManagerPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Gets the value of the 'nodeManagerPort' field.
getNodeManagerPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStartedEvent
 
getNodeManagerPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.AMInfo
 
getNum() - Method in class org.apache.hadoop.mapred.join.Parser.NumToken
 
getNum() - Method in class org.apache.hadoop.mapred.join.Parser.Token
 
getNum() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.NumToken
 
getNum() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Token
 
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.
getNumExcludedNodes() - Method in class org.apache.hadoop.mapred.ClusterStatus
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
getNumKnownMapOutputs() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapHost
 
getNumLinesPerSplit(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
Get the number of lines per split
getNumMaps() - Method in class org.apache.hadoop.mapred.ReduceTask
 
getNumMapTasks() - Method in class org.apache.hadoop.mapred.JobConf
Get configured the number of reduce tasks for this job.
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
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
 
getNumReduceTasks() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get configured the number of reduce tasks for this job.
getNumReservedSlots() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getNumSlots() - Method in class org.apache.hadoop.mapred.TaskStatus
 
getNumSlotsRequired() - Method in class org.apache.hadoop.mapred.Task
 
getNumTasksToExecutePerJvm() - Method in class org.apache.hadoop.mapred.JobConf
Get the number of tasks that a spawned JVM should execute
getNumUsedSlots() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
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
getOperations() - Method in class org.apache.hadoop.mapreduce.QueueAclsInfo
Get opearations allowed on queue.
getOutputCommitter() - Method in class org.apache.hadoop.mapred.JobConf
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 class org.apache.hadoop.mapreduce.task.TaskInputOutputContextImpl
 
getOutputCommitter() - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Get the OutputCommitter for the task-attempt.
getOutputCompressionType(JobConf) - Static method in class org.apache.hadoop.mapred.SequenceFileOutputFormat
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.
getOutputFieldCount() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getOutputFieldNames() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getOutputFile() - Method in class org.apache.hadoop.mapred.MapOutputFile
Return the path to local map output file created earlier
getOutputFile() - Method in class org.apache.hadoop.mapred.MROutputFiles
Return the path to local map output file created earlier
getOutputFileForWrite(long) - Method in class org.apache.hadoop.mapred.MapOutputFile
Create a local map output file name.
getOutputFileForWrite(long) - Method in class org.apache.hadoop.mapred.MROutputFiles
Create a local map output file name.
getOutputFileForWriteInVolume(Path) - Method in class org.apache.hadoop.mapred.MapOutputFile
Create a local map output file name on the same volume.
getOutputFileForWriteInVolume(Path) - Method in class org.apache.hadoop.mapred.MROutputFiles
Create a local map output file name on the same volume.
getOutputFormat() - Method in class org.apache.hadoop.mapred.JobConf
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
 
getOutputFormatClass() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the OutputFormat class for the job.
getOutputIndexFile() - Method in class org.apache.hadoop.mapred.MapOutputFile
Return the path to a local map output index file created earlier
getOutputIndexFile() - Method in class org.apache.hadoop.mapred.MROutputFiles
Return the path to a local map output index file created earlier
getOutputIndexFileForWrite(long) - Method in class org.apache.hadoop.mapred.MapOutputFile
Create a local map output index file name.
getOutputIndexFileForWrite(long) - Method in class org.apache.hadoop.mapred.MROutputFiles
Create a local map output index file name.
getOutputIndexFileForWriteInVolume(Path) - Method in class org.apache.hadoop.mapred.MapOutputFile
Create a local map output index file name on the same volume.
getOutputIndexFileForWriteInVolume(Path) - Method in class org.apache.hadoop.mapred.MROutputFiles
Create a local map output index file name on the same volume.
getOutputKeyClass() - Method in class org.apache.hadoop.mapred.JobConf
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.mapreduce.task.JobContextImpl
Get the key class for the job output data.
getOutputKeyComparator() - Method in class org.apache.hadoop.mapred.JobConf
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.
getOutputSize() - Method in class org.apache.hadoop.mapred.TaskStatus
Returns the number of bytes of output from this map.
getOutputStream(int) - Method in class org.apache.hadoop.mapred.BackupStore
For writing the first key and value bytes directly from the value iterators, pass the current underlying output stream
getOutputStream() - Method in class org.apache.hadoop.mapred.IFile.Writer
 
getOutputTableName() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getOutputValueClass() - Method in class org.apache.hadoop.mapred.JobConf
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.mapreduce.task.JobContextImpl
Get the value class for job outputs.
getOutputValueGroupingComparator() - Method in class org.apache.hadoop.mapred.JobConf
Get the user defined WritableComparable comparator for grouping keys of inputs to the reduce.
getOwner() - Method in class org.apache.hadoop.mapreduce.v2.LogParams
 
getParseException() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser
Get the parse exception, if any.
getPartition(K2, V2, int) - Method in class org.apache.hadoop.mapred.lib.HashPartitioner
Use Object.hashCode() to partition.
getPartition(K2, V2, int) - Method in interface org.apache.hadoop.mapred.Partitioner
Get the paritition number for a given key (hence record) given the total number of partitions i.e.
getPartition() - Method in class org.apache.hadoop.mapred.Task
Get the index of this task within the job.
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
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
 
getPartitionerClass() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the Partitioner class for the job.
getPartitionFile(JobConf) - Static method in class org.apache.hadoop.mapred.lib.TotalOrderPartitioner
Deprecated. Use TotalOrderPartitioner.getPartitionFile(Configuration) instead
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
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
getPhase() - Method in class org.apache.hadoop.mapred.Task
Return current phase of the task.
getPhase() - Method in class org.apache.hadoop.mapred.TaskStatus
Get current phase of this task.
getPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'physMemKbytes' field
getPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'physMemKbytes' field.
getPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
 
getPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'physMemKbytes' field
getPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'physMemKbytes' field.
getPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
 
getPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'physMemKbytes' field
getPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'physMemKbytes' field.
getPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
 
getPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'port' field
getPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'port' field.
getPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the tracker rpc port
getPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'port' field
getPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'port' field.
getPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the tracker rpc port
getPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'port' field
getPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'port' field.
getPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the rpc port for the host where the attempt executed
getPos() - Method in class org.apache.hadoop.mapred.FixedLengthRecordReader
 
getPos() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Unsupported (returns zero in all cases).
getPos() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Request position from proxied RR.
getPos() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
 
getPos() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
return the amount of data processed
getPos() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
getPos() - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBRecordReader
 
getPos() - Method in class org.apache.hadoop.mapred.LineRecordReader
 
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
 
getPos() - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
 
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.mapreduce.lib.input.FixedLengthRecordReader
 
getPosition() - Method in class org.apache.hadoop.mapred.IFile.Reader
 
getPosition() - Method in class org.apache.hadoop.mapred.IFileInputStream
 
getPosition() - Method in class org.apache.hadoop.mapred.Merger.Segment
 
getPosition() - Method in class org.apache.hadoop.mapreduce.task.reduce.InMemoryReader
 
getPrefix(boolean) - Static method in class org.apache.hadoop.mapreduce.lib.chain.Chain
Returns the prefix to use for the configuration of the chain depending if it is for a Mapper or a Reducer.
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
 
getPriority() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange.Builder
Gets the value of the 'priority' field
getPriority() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
Gets the value of the 'priority' field.
getPriority() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChangeEvent
Get the job priority
getPriority() - Method in class org.apache.hadoop.mapreduce.JobStatus
Return the priority of the job
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
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
 
getProfileEnabled() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get whether the task profiling is enabled.
getProfileParams() - Method in class org.apache.hadoop.mapred.JobConf
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
 
getProfileParams() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the profiler configuration arguments.
getProfileTaskRange(boolean) - Method in class org.apache.hadoop.mapred.JobConf
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
 
getProfileTaskRange(boolean) - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the range of maps or reduces to profile.
getProgress() - Method in class org.apache.hadoop.mapred.FixedLengthRecordReader
 
getProgress() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Report progress as the minimum of all child RR progress.
getProgress() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Request progress from proxied RR.
getProgress() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
 
getProgress() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
return progress based on the amount of data processed so far.
getProgress() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
getProgress() - Method in class org.apache.hadoop.mapred.LineRecordReader
Get the progress within the split
getProgress() - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.MRResultIterator
 
getProgress() - Method in interface org.apache.hadoop.mapred.RawKeyValueIterator
Gets the Progress object; this has a float (0.0 - 1.0) indicating the bytes processed by the iterator 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 interface org.apache.hadoop.mapred.Reporter
Get the progress of the task.
getProgress() - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
Return the progress within the input split
getProgress() - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
 
getProgress() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
Return the progress within the input split
getProgress() - Method in class org.apache.hadoop.mapred.Task
 
getProgress() - Method in class org.apache.hadoop.mapred.Task.TaskReporter
 
getProgress() - Method in class org.apache.hadoop.mapred.TaskAttemptContextImpl
 
getProgress() - Method in class org.apache.hadoop.mapred.TaskStatus
 
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.CombineFileRecordReaderWrapper
 
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.DelegatingRecordReader
 
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthRecordReader
 
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.LineRecordReader
Get the progress within the split
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.lib.map.WrappedMapper.Context
 
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
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.mapreduce.StatusReporter
Get the current progress.
getProgress() - Method in class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl.DummyReporter
 
getProgress() - Method in class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl
 
getProgress() - Method in interface org.apache.hadoop.mapreduce.TaskAttemptContext
The current progress of the task attempt.
getProgress() - Method in class org.apache.hadoop.mapreduce.TaskReport
The amount completed, between zero and one.
getProgressible() - Method in interface org.apache.hadoop.mapred.JobContext
Get the progress mechanism for reporting progress.
getProgressible() - Method in class org.apache.hadoop.mapred.JobContextImpl
Get the progress mechanism for reporting progress.
getProgressible() - Method in interface org.apache.hadoop.mapred.TaskAttemptContext
 
getProgressible() - Method in class org.apache.hadoop.mapred.TaskAttemptContextImpl
 
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.mapreduce.JobStatus
Get queue name
getQueue(String) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Gets scheduling information associated with the particular Job queue
getQueueAclsForCurrentUser() - Method in class org.apache.hadoop.mapred.JobClient
Gets the Queue ACLs for current user
getQueueAclsForCurrentUser() - Method in class org.apache.hadoop.mapreduce.Cluster
Gets the Queue ACLs for current user
getQueueAclsForCurrentUser() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Gets the Queue ACLs for current user
getQueueAdmins(String) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Get the administrators of the given job-queue.
getQueueChildren() - Method in class org.apache.hadoop.mapreduce.QueueInfo
Get immediate children.
getQueueInfo(String) - Method in class org.apache.hadoop.mapred.JobClient
Gets the queue information associated to a particular Job Queue
getQueueName() - Method in class org.apache.hadoop.mapred.JobConf
Return the name of the queue to which this job is submitted.
getQueueName() - Method in class org.apache.hadoop.mapred.JobProfile
Get the name of the queue to which the 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
getQueues() - Method in class org.apache.hadoop.mapred.JobClient
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.
getQueues() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Gets set of Queues associated with the Job Tracker
getQueueState() - Method in class org.apache.hadoop.mapred.JobQueueInfo
Deprecated. 
getRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'rackname' field
getRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'rackname' field.
getRackName() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the rack name
getRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'rackname' field
getRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'rackname' field.
getRackName() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the rack name of the node where the attempt ran
getRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Gets the value of the 'rackname' field
getRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Gets the value of the 'rackname' field.
getRackName() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Get the rackname where the attempt executed
getRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'rackname' field
getRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'rackname' field.
getRackName() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the rack name of the node where the attempt ran
getRawDataLength() - Method in class org.apache.hadoop.mapred.Merger.Segment
 
getRawLength() - Method in class org.apache.hadoop.mapred.IFile.Writer
 
getReaders(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.mapred.MapFileOutputFormat
Open the output generated by this format.
getReaders(Configuration, Path) - Static method in class org.apache.hadoop.mapred.SequenceFileOutputFormat
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
 
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
Gets the reason for which the tasktracker was blacklisted.
getRecordLength(Configuration) - Static method in class org.apache.hadoop.mapred.FixedLengthInputFormat
Get record length value
getRecordLength(Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthInputFormat
Get record length value
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.FileInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.FixedLengthInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in interface org.apache.hadoop.mapred.InputFormat
Get the RecordReader for the given InputSplit.
getRecordReader(InputSplit, JobConf, Reporter) - Method in interface org.apache.hadoop.mapred.join.ComposableInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.join.CompositeInputFormat
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
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
This is not implemented yet.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.CombineSequenceFileInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.CombineTextInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
Get the RecordReader for the given InputSplit.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.DelegatingInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.NLineInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.MultiFileInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.SequenceFileAsTextInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter
Create a record reader for the given split
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.SequenceFileInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.TextInputFormat
 
getRecordReaderQueue() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
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.mapred.FileOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.db.DBOutputFormat
Get the RecordWriter for the given job.
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.FilterOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.LazyOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
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
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.MapFileOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in interface org.apache.hadoop.mapred.OutputFormat
Get the RecordWriter for the given job.
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.SequenceFileOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.mapred.TextOutputFormat
 
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.
getReduceCombineInputCounter() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getReduceCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Gets the value of the 'reduceCounters' field
getReduceCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Gets the value of the 'reduceCounters' field.
getReduceCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
Get the reduce counters for the job
getReduceCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getReduceDebugScript() - Method in class org.apache.hadoop.mapred.JobConf
Get the reduce task's debug Script
getReduceFinished() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer.SummarizedJob
Get number of reducers that finished
getReduceId() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getReduceProgress() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getReducerClass() - Method in class org.apache.hadoop.mapred.JobConf
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
 
getReducerClass() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the Reducer class for the job.
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.
getReduceShuffleBytes() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getReduceSlotCapacity() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the total number of reduce slots in the cluster.
getReduceSpeculativeExecution() - Method in class org.apache.hadoop.mapred.JobConf
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
getReduceTask() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getReduceTaskReports(JobID) - Method in class org.apache.hadoop.mapred.JobClient
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
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
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
 
getReportDetails() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueHistogram
 
getReporter() - Method in class org.apache.hadoop.mapred.MapOutputCollector.Context
 
getReporter() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
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.
getReservedMem() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getReservedReduceSlots() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of reserved reduce slots in the cluster.
getRootQueues() - Method in class org.apache.hadoop.mapred.JobClient
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.
getRootQueues() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Gets the root level queues.
getRunningJobList() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getRunningJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
 
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.
getRunningTaskAttemptIds() - Method in class org.apache.hadoop.mapreduce.TaskReport
Get the running task attempt IDs for this task
getRunningTaskAttempts() - Method in class org.apache.hadoop.mapred.TaskReport
Get the running task attempt IDs for this task
getRunState() - Method in class org.apache.hadoop.mapred.JobStatus
 
getRunState() - Method in class org.apache.hadoop.mapred.TaskStatus
 
getSample(InputFormat<K, V>, JobConf) - Method in class org.apache.hadoop.mapred.lib.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>, JobConf) - Method in class org.apache.hadoop.mapred.lib.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>, JobConf) - Method in interface org.apache.hadoop.mapred.lib.InputSampler.Sampler
For a given job, collect and return a subset of the keys from the input data.
getSample(InputFormat<K, V>, JobConf) - Method in class org.apache.hadoop.mapred.lib.InputSampler.SplitSampler
From each split sampled, take the first numSamples / numSplits records.
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.
getSchedulerInfo(String) - Method in class org.apache.hadoop.mapred.QueueManager
Return the scheduler information configured for this queue.
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.
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.Event
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
 
getSchema() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
 
getScheme() - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup.FSCounter
 
getSecretKey(Credentials, Text) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
auxiliary method to get user's secret keys..
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
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
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
Get the information of the current state of the setup tasks of a job.
getShuffledMapsCounter() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getShuffleFinishTime() - Method in class org.apache.hadoop.mapred.TaskStatus
Get shuffle finish time for the task.
getShuffleFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getShuffleFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'shuffleFinishTime' field
getShuffleFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'shuffleFinishTime' field.
getShuffleFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the finish time of the shuffle phase
getShufflePort() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getShufflePort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Gets the value of the 'shufflePort' field
getShufflePort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Gets the value of the 'shufflePort' field.
getShufflePort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the shuffle port
getShuffleSecret() - Method in class org.apache.hadoop.mapred.Task
Get the secret key used to authenticate the shuffle
getShuffleSecretKey(Credentials) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
 
getSize() - Method in class org.apache.hadoop.mapred.IFileInputStream
 
getSize() - Method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat.WritableValueBytes
 
getSize() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapOutput
 
getSkipOutputPath(Configuration) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Get the directory to which skipped records are written.
getSkipRanges() - Method in class org.apache.hadoop.mapred.Task
Get skipRanges.
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
 
getSortComparator() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the RawComparator comparator used to compare keys.
getSortFinishTime() - Method in class org.apache.hadoop.mapred.TaskStatus
Get sort finish time for the task,.
getSortFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getSortFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'sortFinishTime' field
getSortFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'sortFinishTime' field.
getSortFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the finish time of the sort phase
getSortPhase() - Method in class org.apache.hadoop.mapred.MapTask
 
getSpeculativeExecution() - Method in class org.apache.hadoop.mapred.JobConf
Should speculative execution be used for this job? Defaults to true.
getSpilledRecordsCounter() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getSpillFile(int) - Method in class org.apache.hadoop.mapred.MapOutputFile
Return a local map spill file created earlier.
getSpillFile(int) - Method in class org.apache.hadoop.mapred.MROutputFiles
Return a local map spill file created earlier.
getSpillFileForWrite(int, long) - Method in class org.apache.hadoop.mapred.MapOutputFile
Create a local map spill file name.
getSpillFileForWrite(int, long) - Method in class org.apache.hadoop.mapred.MROutputFiles
Create a local map spill file name.
getSpillIndexFile(int) - Method in class org.apache.hadoop.mapred.MapOutputFile
Return a local map spill index file created earlier
getSpillIndexFile(int) - Method in class org.apache.hadoop.mapred.MROutputFiles
Return a local map spill index file created earlier
getSpillIndexFileForWrite(int, long) - Method in class org.apache.hadoop.mapred.MapOutputFile
Create a local map spill index file name.
getSpillIndexFileForWrite(int, long) - Method in class org.apache.hadoop.mapred.MROutputFiles
Create a local map spill index file name.
getSplit() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getSplitHosts(BlockLocation[], long, long, NetworkTopology) - Method in class org.apache.hadoop.mapred.FileInputFormat
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
 
getSplitLocations() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Gets the value of the 'splitLocations' field
getSplitLocations() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Gets the value of the 'splitLocations' field.
getSplitLocations() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStartedEvent
Get the split locations, applicable for map tasks
getSplits(JobConf, int) - Method in class org.apache.hadoop.mapred.FileInputFormat
Splits files returned by FileInputFormat.listStatus(JobConf) when they're too big.
getSplits(JobConf, int) - Method in interface org.apache.hadoop.mapred.InputFormat
Logically split the set of input files for the job.
getSplits(JobConf, int) - Method in class org.apache.hadoop.mapred.join.CompositeInputFormat
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
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
Logically split the set of input files for the job.
getSplits(JobConf, int) - Method in class org.apache.hadoop.mapred.lib.DelegatingInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.mapred.lib.NLineInputFormat
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
 
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.DelegatingInputFormat
 
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.
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.mapred.JobClient
Fetch the staging area directory for the application
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.
getStagingAreaDir() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Get a hint from the JobTracker where job-specific files are to be placed.
getStagingDir(Cluster, Configuration) - Static method in class org.apache.hadoop.mapreduce.JobSubmissionFiles
Initializes the staging directory and returns the path.
getStart() - Method in class org.apache.hadoop.mapred.FileSplit
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.
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.mapred.TaskStatus
Get start time of the task.
getStartTime() - Method in class org.apache.hadoop.mapreduce.Job
Get start time of the job.
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Gets the value of the 'startTime' field
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Gets the value of the 'startTime' field.
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStartedEvent
 
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.AMInfo
 
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
 
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Gets the value of the 'startTime' field
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Gets the value of the 'startTime' field.
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the start time
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Gets the value of the 'startTime' field
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Gets the value of the 'startTime' field.
getStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStartedEvent
Get the start time of the task
getStartTime() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getStartTime() - Method in class org.apache.hadoop.mapreduce.TaskReport
Get start time of task.
getState() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
 
getState() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
 
getState() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getState() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'state' field
getState() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'state' field.
getState() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the state string
getState() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'state' field
getState() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'state' field.
getState() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the state string
getState() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Gets the value of the 'state' field
getState() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Gets the value of the 'state' field.
getState() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Get the state string
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
 
getState() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapHost
 
getState() - Method in class org.apache.hadoop.mapreduce.TaskReport
The most recent state, reported by the Reporter.
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
 
getStateString() - Method in class org.apache.hadoop.mapred.TaskStatus
 
getStatus() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getStatus() - Method in class org.apache.hadoop.mapreduce.Job
 
getStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInitedEvent
Get the status
getStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChangedEvent
Get the event status
getStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletionEvent
Get the status
getStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'status' field
getStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'status' field.
getStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Gets the value of the 'status' field
getStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Gets the value of the 'status' field.
getStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Gets the value of the 'status' field
getStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Gets the value of the 'status' field.
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 class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl
Get the last set status message.
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.
getStr() - Method in class org.apache.hadoop.mapred.join.Parser.StrToken
 
getStr() - Method in class org.apache.hadoop.mapred.join.Parser.Token
 
getStr() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.StrToken
 
getStr() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Token
 
getSubmitTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getSubmitTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
Gets the value of the 'submitTime' field
getSubmitTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Gets the value of the 'submitTime' field.
getSubmitTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChangeEvent
Get the Job submit time
getSubmitTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Gets the value of the 'submitTime' field
getSubmitTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Gets the value of the 'submitTime' field.
getSubmitTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the submit time
getSuccessfulAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
 
getSuccessfulAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Gets the value of the 'successfulAttemptId' field
getSuccessfulAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Gets the value of the 'successfulAttemptId' field.
getSuccessfulJobList() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getSuccessfulJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
 
getSuccessfulTaskAttempt() - Method in class org.apache.hadoop.mapred.TaskReport
Get the attempt ID that took this task to completion
getSuccessfulTaskAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent
Get successful task attempt id
getSuccessfulTaskAttemptId() - Method in class org.apache.hadoop.mapreduce.TaskReport
Get the attempt ID that took this task to completion
getSum() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.DoubleValueSum
 
getSum() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueSum
 
getSymlink(Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. symlinks are always created.
getSymlink() - Method in interface org.apache.hadoop.mapreduce.JobContext
Deprecated. 
getSymlink() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getSymlink() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getSymlink() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
This method checks to see if symlinks are to be create for the localized cache files in the current working directory
getSystemDir() - Method in class org.apache.hadoop.mapred.JobClient
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.
getSystemDir() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Grab the jobtracker system directory path where job-specific files are to be placed.
getTableName() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getTask() - Method in class org.apache.hadoop.mapred.JvmTask
 
getTask(JvmContext) - Method in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Called when a child task process starts, to get its task.
getTaskAttemptID() - Method in interface org.apache.hadoop.mapred.TaskAttemptContext
 
getTaskAttemptID() - Method in class org.apache.hadoop.mapred.TaskAttemptContextImpl
Get the taskAttemptID.
getTaskAttemptId() - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Returns task id.
getTaskAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the attempt id
getTaskAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the attempt 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 class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl
Get the unique name for this task attempt.
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. 
getTaskAttemptPath(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
getTaskAttemptPath(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Compute the path where the output of a task attempt is stored until that task is committed.
getTaskAttemptPath(TaskAttemptContext, Path) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Compute the path where the output of a task attempt is stored until that task is committed.
getTaskCleanupNeeded() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get whether task-cleanup is needed for the job
getTaskCleanupNeeded() - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper.Context
 
getTaskCleanupNeeded() - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer.Context
 
getTaskCleanupNeeded() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get whether task-cleanup is needed for the job
getTaskCompletionEvents(int) - Method in interface org.apache.hadoop.mapred.RunningJob
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.
getTaskCompletionEvents(int) - Method in class org.apache.hadoop.mapreduce.Job
Get events indicating completion (success/failure) of component tasks.
getTaskCompletionEvents(JobID, int, int) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Get task completion events for the jobid, starting from fromEventId.
getTaskCounters() - Method in class org.apache.hadoop.mapreduce.TaskReport
A table of counters.
getTaskDiagnostics(TaskAttemptID) - Method in interface org.apache.hadoop.mapred.RunningJob
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.
getTaskDiagnostics(TaskAttemptID) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Get the diagnostics for a given task in a given job
getTaskID() - Method in class org.apache.hadoop.mapred.Task
 
getTaskID() - Method in class org.apache.hadoop.mapred.TaskAttemptID
 
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
The string of the task id.
getTaskID() - Method in class org.apache.hadoop.mapred.TaskReport
The id of the task.
getTaskID() - Method in class org.apache.hadoop.mapred.TaskStatus
 
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
 
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'taskid' field
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'taskid' field.
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the task ID
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'taskid' field
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'taskid' field.
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the Task ID
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Gets the value of the 'taskid' field
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Gets the value of the 'taskid' field.
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Get the task ID
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Gets the value of the 'taskid' field
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Gets the value of the 'taskid' field.
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the task id
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'taskid' field
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'taskid' field.
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the task id
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Gets the value of the 'taskid' field
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Gets the value of the 'taskid' field.
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
Get the task id
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Gets the value of the 'taskid' field
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Gets the value of the 'taskid' field.
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent
Get task id
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Gets the value of the 'taskid' field
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Gets the value of the 'taskid' field.
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStartedEvent
Get the task id
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated.Builder
Gets the value of the 'taskid' field
getTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
Gets the value of the 'taskid' field.
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdatedEvent
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.mapreduce.TaskReport
The string of the task ID.
getTaskID() - Method in class org.apache.hadoop.mapreduce.TaskReport
The ID of the task.
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. 
getTaskLogFile(TaskAttemptID, boolean, TaskLog.LogName) - Static method in class org.apache.hadoop.mapred.TaskLog
 
getTaskLogLength(JobConf) - Static method in class org.apache.hadoop.mapred.TaskLog
Get the desired maximum length of task's logs.
getTaskLogsUrl(String, JobHistoryParser.TaskAttemptInfo) - Static method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer
Return the TaskLogsUrl of a particular TaskAttempt
getTaskLogURL(TaskAttemptID, String) - Static method in class org.apache.hadoop.mapreduce.tools.CLI
 
getTaskLogUrl(String, String, String, String) - Static method in class org.apache.hadoop.mapreduce.util.HostUtil
Construct the taskLogUrl
getTaskOutputFilter(JobConf) - Static method in class org.apache.hadoop.mapred.JobClient
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.
getTaskReports(JobID, TaskType) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Grab a bunch of info on the tasks that make up the 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
Returns enum Status.SUCESS or Status.FAILURE.
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
 
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'taskStatus' field
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'taskStatus' field.
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the task status
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'taskStatus' field
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'taskStatus' field.
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the task status
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Gets the value of the 'taskStatus' field
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Gets the value of the 'taskStatus' field.
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Get the task status
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the task status
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
Get the task status
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent
Get task status
getTaskTracker() - Method in class org.apache.hadoop.mapred.TaskStatus
 
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
getTaskTrackerExpiryInterval() - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
 
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
Get the number of task trackers in the cluster.
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo
 
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'taskType' field
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'taskType' field.
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.NormalizedResourceEvent
the tasktype for the event.
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'taskType' field
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'taskType' field.
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Gets the value of the 'taskType' field
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Gets the value of the 'taskType' field.
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Gets the value of the 'taskType' field
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Gets the value of the 'taskType' field.
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'taskType' field
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'taskType' field.
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Gets the value of the 'taskType' field
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Gets the value of the 'taskType' field.
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Gets the value of the 'taskType' field
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Gets the value of the 'taskType' field.
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent
Get task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Gets the value of the 'taskType' field
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Gets the value of the 'taskType' field.
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStartedEvent
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
getThreadState() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getTimestamp(Configuration, URI) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
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.JobFinished.Builder
Gets the value of the 'totalCounters' field
getTotalCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Gets the value of the 'totalCounters' field.
getTotalCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
Get the counters for the job
getTotalCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
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
 
getTotalMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Gets the value of the 'totalMaps' field
getTotalMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Gets the value of the 'totalMaps' field.
getTotalMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInitedEvent
Get the total number of maps
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
 
getTotalReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Gets the value of the 'totalReduces' field
getTotalReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Gets the value of the 'totalReduces' field.
getTotalReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInitedEvent
Get the total number of reduces
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
Gets the blacklisted tasktracker's name.
getTrackerName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getTrackerName() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Gets the value of the 'trackerName' field
getTrackerName() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Gets the value of the 'trackerName' field.
getTrackerName() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the tracker name
getTrackingURL() - Method in interface org.apache.hadoop.mapred.RunningJob
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
Get the tasktracker expiry interval for the cluster
getType() - Method in class org.apache.hadoop.mapred.join.Parser.Token
 
getType() - Method in class org.apache.hadoop.mapreduce.jobhistory.Event.Builder
Gets the value of the 'type' field
getType() - Method in class org.apache.hadoop.mapreduce.jobhistory.Event
Gets the value of the 'type' field.
getType() - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Token
 
getUberized() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getUberized() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Gets the value of the 'uberized' field
getUberized() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Gets the value of the 'uberized' field.
getUberized() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInitedEvent
Get whether the job's map and reduce stages were combined
getUmbilical() - Method in class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
getUnderlyingCounter() - Method in class org.apache.hadoop.mapred.Counters.Counter
 
getUnderlyingCounter() - Method in interface org.apache.hadoop.mapreduce.Counter
 
getUnderlyingCounter() - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup.FSCounter
 
getUnderlyingCounter() - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup.FrameworkCounter
 
getUnderlyingCounter() - Method in class org.apache.hadoop.mapreduce.counters.GenericCounter
 
getUnderlyingGroup() - Method in class org.apache.hadoop.mapred.Counters.Group
 
getUnderlyingGroup() - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
 
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
 
getURL() - Method in class org.apache.hadoop.mapred.JobProfile
Get the link to the web-ui for details of the job.
getUsedMem() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getUsedMemory() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated. 
getUseNewMapper() - Method in class org.apache.hadoop.mapred.JobConf
Should the framework use the new context-object code for running the mapper?
getUseNewReducer() - Method in class org.apache.hadoop.mapred.JobConf
Should the framework use the new context-object code for running the reducer?
getUser() - Method in class org.apache.hadoop.mapred.JobConf
Get the reported username for this job.
getUser() - Method in class org.apache.hadoop.mapred.JobProfile
Get the user id.
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 class org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier
getUser() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the reported username for this job.
getUsername() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
getUserName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Gets the value of the 'userName' field
getUserName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Gets the value of the 'userName' field.
getUserName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the user name
getUsername() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
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.mapred.Counters.Counter
 
getValue() - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.MRResultIterator
 
getValue() - Method in interface org.apache.hadoop.mapred.RawKeyValueIterator
Gets the current raw value.
getValue() - Method in interface org.apache.hadoop.mapreduce.Counter
What is the current value of this counter?
getValue() - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup.FSCounter
 
getValue() - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup.FrameworkCounter
 
getValue() - Method in class org.apache.hadoop.mapreduce.counters.GenericCounter
 
getValue() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
Gets the value of the 'value' field
getValue() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Gets the value of the 'value' field.
getValue() - Method in enum org.apache.hadoop.mapreduce.JobStatus.State
 
getValue() - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
getValue(String, String, String, T) - Static method in class org.apache.hadoop.mapreduce.util.ResourceBundles
Get a resource given bundle name and key
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
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.mapred.PeriodicStatsAccumulator
 
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.mapreduce.task.ReduceContextImpl
Iterate through the values for the current key, reusing the same value object, which is stored in the context.
getVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Gets the value of the 'vMemKbytes' field
getVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Gets the value of the 'vMemKbytes' field.
getVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
 
getVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Gets the value of the 'vMemKbytes' field
getVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Gets the value of the 'vMemKbytes' field.
getVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
 
getVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Gets the value of the 'vMemKbytes' field
getVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Gets the value of the 'vMemKbytes' field.
getVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
 
getWaitingJobList() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getWaitingJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
 
getWorkflowAdjacencies() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Gets the value of the 'workflowAdjacencies' field
getWorkflowAdjacencies() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Gets the value of the 'workflowAdjacencies' field.
getWorkflowAdjacencies() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the adjacencies of the workflow
getWorkflowId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Gets the value of the 'workflowId' field
getWorkflowId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Gets the value of the 'workflowId' field.
getWorkflowId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the id of the workflow
getWorkflowName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Gets the value of the 'workflowName' field
getWorkflowName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Gets the value of the 'workflowName' field.
getWorkflowName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the name of the workflow
getWorkflowNodeName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Gets the value of the 'workflowNodeName' field
getWorkflowNodeName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Gets the value of the 'workflowNodeName' field.
getWorkflowNodeName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the node name of the workflow
getWorkflowTags() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Gets the value of the 'workflowTags' field
getWorkflowTags() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Gets the value of the 'workflowTags' field.
getWorkflowTags() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the workflow tags
getWorkingDirectory() - Method in class org.apache.hadoop.mapred.JobConf
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
 
getWorkingDirectory() - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Get the current working directory for the default file system.
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(TaskAttemptContext, Path) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
getWorkPath() - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Get the directory that the task should write results into.
getWriteAllCounters() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Get the "writeAllCounters" option
GROUP - Static variable in class org.apache.hadoop.mapreduce.lib.map.RegexMapper
 
GROUP_COMPARATOR_CLASS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
groups - Variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
Deprecated. 


H

HADOOP_WORK_DIR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
handleEvent(HistoryEvent) - Method in interface org.apache.hadoop.mapreduce.jobhistory.HistoryEventHandler
 
handleEvent(HistoryEvent) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser
 
has(int) - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Return true if tuple has an element at the position provided.
hasAccess(String, QueueACL, UserGroupInformation) - Method in class org.apache.hadoop.mapred.QueueManager
Return true if the given user is part of the ACL for the given QueueACL name for the given queue.
hasAcls() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Checks whether the 'acls' field has been set
hasApplicationAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Checks whether the 'applicationAttemptId' field has been set
hasAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'attemptId' field has been set
hasAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'attemptId' field has been set
hasAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Checks whether the 'attemptId' field has been set
hasAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Checks whether the 'attemptId' field has been set
hasAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'attemptId' field has been set
hasAvataar() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Checks whether the 'avataar' field has been set
hasClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'clockSplits' field has been set
hasClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'clockSplits' field has been set
hasClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'clockSplits' field has been set
hasContainerId() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Checks whether the 'containerId' field has been set
hasContainerId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Checks whether the 'containerId' field has been set
hasCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'counters' field has been set
hasCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'counters' field has been set
hasCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Checks whether the 'counters' field has been set
hasCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'counters' field has been set
hasCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Checks whether the 'counters' field has been set
hasCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Checks whether the 'counters' field has been set
hasCounts() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
Checks whether the 'counts' field has been set
hasCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'cpuUsages' field has been set
hasCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'cpuUsages' field has been set
hasCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'cpuUsages' field has been set
hasDiagnostics() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Checks whether the 'diagnostics' field has been set
hasDisplayName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
Checks whether the 'displayName' field has been set
hasDisplayName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
Checks whether the 'displayName' field has been set
hasError() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'error' field has been set
hasError() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Checks whether the 'error' field has been set
hasEvent() - Method in class org.apache.hadoop.mapreduce.jobhistory.Event.Builder
Checks whether the 'event' field has been set
hasFailedDueToAttempt() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Checks whether the 'failedDueToAttempt' field has been set
hasFailedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Checks whether the 'failedMaps' field has been set
hasFailedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Checks whether the 'failedReduces' field has been set
hasFinishedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Checks whether the 'finishedMaps' field has been set
hasFinishedMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Checks whether the 'finishedMaps' field has been set
hasFinishedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Checks whether the 'finishedReduces' field has been set
hasFinishedReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Checks whether the 'finishedReduces' field has been set
hasFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Checks whether the 'finishTime' field has been set
hasFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Checks whether the 'finishTime' field has been set
hasFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'finishTime' field has been set
hasFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'finishTime' field has been set
hasFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Checks whether the 'finishTime' field has been set
hasFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'finishTime' field has been set
hasFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Checks whether the 'finishTime' field has been set
hasFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Checks whether the 'finishTime' field has been set
hasFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated.Builder
Checks whether the 'finishTime' field has been set
hasGroups() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters.Builder
Checks whether the 'groups' field has been set
hashCode() - Method in class org.apache.hadoop.mapred.Counters.Counter
 
hashCode() - Method in class org.apache.hadoop.mapred.Counters.Group
 
hashCode() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
 
hashCode() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounter
 
hashCode() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
hashCode() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
 
hashCode() - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
hashCode() - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
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.task.reduce.MapOutput
 
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.mapreduce.TaskReport
 
hashFromString(String, SecretKey) - Static method in class org.apache.hadoop.mapreduce.security.SecureShuffleUtils
Aux util to calculate hash of a String
hasHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'hostname' field has been set
hasHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'hostname' field has been set
hasHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Checks whether the 'hostname' field has been set
hasHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'hostname' field has been set
HashPartitioner<K2,V2> - Class in org.apache.hadoop.mapred.lib
Partition keys by their Object.hashCode().
HashPartitioner() - Constructor for class org.apache.hadoop.mapred.lib.HashPartitioner
 
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
 
hasHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Checks whether the 'httpPort' field has been set
hasJobConfPath() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Checks whether the 'jobConfPath' field has been set
hasJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Checks whether the 'jobid' field has been set
hasJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
Checks whether the 'jobid' field has been set
hasJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Checks whether the 'jobid' field has been set
hasJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange.Builder
Checks whether the 'jobid' field has been set
hasJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange.Builder
Checks whether the 'jobid' field has been set
hasJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged.Builder
Checks whether the 'jobid' field has been set
hasJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Checks whether the 'jobid' field has been set
hasJobid() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Checks whether the 'jobid' field has been set
hasJobName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Checks whether the 'jobName' field has been set
hasJobQueueName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange.Builder
Checks whether the 'jobQueueName' field has been set
hasJobQueueName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Checks whether the 'jobQueueName' field has been set
hasJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Checks whether the 'jobStatus' field has been set
hasJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged.Builder
Checks whether the 'jobStatus' field has been set
hasJobStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Checks whether the 'jobStatus' field has been set
hasLaunchTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
Checks whether the 'launchTime' field has been set
hasLaunchTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Checks whether the 'launchTime' field has been set
hasLocality() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Checks whether the 'locality' field has been set
hasMapCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Checks whether the 'mapCounters' field has been set
hasMapFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'mapFinishTime' field has been set
hasName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
Checks whether the 'name' field has been set
hasName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
Checks whether the 'name' field has been set
hasName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters.Builder
Checks whether the 'name' field has been set
hasNext() - Method in class org.apache.hadoop.mapred.BackupStore
 
hasNext() - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
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
Return true if it is possible that this could emit more values.
hasNext() - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
 
hasNext() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
hasNext() - Method in class org.apache.hadoop.mapred.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.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
 
hasNodeManagerHost() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Checks whether the 'nodeManagerHost' field has been set
hasNodeManagerHttpPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Checks whether the 'nodeManagerHttpPort' field has been set
hasNodeManagerPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Checks whether the 'nodeManagerPort' field has been set
hasPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'physMemKbytes' field has been set
hasPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'physMemKbytes' field has been set
hasPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'physMemKbytes' field has been set
hasPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'port' field has been set
hasPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'port' field has been set
hasPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'port' field has been set
hasPriority() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange.Builder
Checks whether the 'priority' field has been set
hasRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'rackname' field has been set
hasRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'rackname' field has been set
hasRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Checks whether the 'rackname' field has been set
hasRackname() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'rackname' field has been set
hasReduceCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Checks whether the 'reduceCounters' field has been set
hasShuffleFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'shuffleFinishTime' field has been set
hasShufflePort() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Checks whether the 'shufflePort' field has been set
hasSortFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'sortFinishTime' field has been set
hasSplitLocations() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Checks whether the 'splitLocations' field has been set
hasStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Checks whether the 'startTime' field has been set
hasStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Checks whether the 'startTime' field has been set
hasStartTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Checks whether the 'startTime' field has been set
hasState() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'state' field has been set
hasState() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'state' field has been set
hasState() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Checks whether the 'state' field has been set
hasStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'status' field has been set
hasStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Checks whether the 'status' field has been set
hasStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Checks whether the 'status' field has been set
hasSubmitTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
Checks whether the 'submitTime' field has been set
hasSubmitTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Checks whether the 'submitTime' field has been set
hasSuccessfulAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Checks whether the 'successfulAttemptId' field has been set
hasTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'taskid' field has been set
hasTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'taskid' field has been set
hasTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Checks whether the 'taskid' field has been set
hasTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Checks whether the 'taskid' field has been set
hasTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'taskid' field has been set
hasTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Checks whether the 'taskid' field has been set
hasTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Checks whether the 'taskid' field has been set
hasTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Checks whether the 'taskid' field has been set
hasTaskid() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated.Builder
Checks whether the 'taskid' field has been set
hasTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'taskStatus' field has been set
hasTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'taskStatus' field has been set
hasTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Checks whether the 'taskStatus' field has been set
hasTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'taskType' field has been set
hasTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'taskType' field has been set
hasTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Checks whether the 'taskType' field has been set
hasTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Checks whether the 'taskType' field has been set
hasTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'taskType' field has been set
hasTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Checks whether the 'taskType' field has been set
hasTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Checks whether the 'taskType' field has been set
hasTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Checks whether the 'taskType' field has been set
hasTotalCounters() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Checks whether the 'totalCounters' field has been set
hasTotalMaps() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Checks whether the 'totalMaps' field has been set
hasTotalReduces() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Checks whether the 'totalReduces' field has been set
hasTrackerName() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Checks whether the 'trackerName' field has been set
hasType() - Method in class org.apache.hadoop.mapreduce.jobhistory.Event.Builder
Checks whether the 'type' field has been set
hasUberized() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Checks whether the 'uberized' field has been set
hasUserName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Checks whether the 'userName' field has been set
hasValue() - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
Checks whether the 'value' field has been set
hasVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Checks whether the 'vMemKbytes' field has been set
hasVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Checks whether the 'vMemKbytes' field has been set
hasVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Checks whether the 'vMemKbytes' field has been set
hasWorkflowAdjacencies() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Checks whether the 'workflowAdjacencies' field has been set
hasWorkflowId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Checks whether the 'workflowId' field has been set
hasWorkflowName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Checks whether the 'workflowName' field has been set
hasWorkflowNodeName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Checks whether the 'workflowNodeName' field has been set
hasWorkflowTags() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Checks whether the 'workflowTags' field has been set
headerPattern - Static variable in class org.apache.hadoop.mapreduce.tools.CLI
 
HistoryEvent - Interface in org.apache.hadoop.mapreduce.jobhistory
Interface for event wrapper classes.
HistoryEventHandler - Interface in org.apache.hadoop.mapreduce.jobhistory
 
HistoryViewer - Class in org.apache.hadoop.mapreduce.jobhistory
HistoryViewer is used to parse and view the JobHistory files
HistoryViewer(String, Configuration, boolean) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer
Constructs the HistoryViewer object
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
hostname - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
hostname - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
hostname - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Deprecated. 
hostname - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
HostUtil - Class in org.apache.hadoop.mapreduce.util
 
HostUtil() - Constructor for class org.apache.hadoop.mapreduce.util.HostUtil
 
HTTP_HEADER_NAME - Static variable in class org.apache.hadoop.mapreduce.task.reduce.ShuffleHeader
Header info of the shuffle http request/response
HTTP_HEADER_REPLY_URL_HASH - Static variable in class org.apache.hadoop.mapreduce.security.SecureShuffleUtils
 
HTTP_HEADER_URL_HASH - Static variable in class org.apache.hadoop.mapreduce.security.SecureShuffleUtils
 
HTTP_HEADER_VERSION - Static variable in class org.apache.hadoop.mapreduce.task.reduce.ShuffleHeader
 
httpPort - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Deprecated. 

I

ID - Class in org.apache.hadoop.mapred
A general identifier, which internally stores the id as an integer.
ID(int) - Constructor for class org.apache.hadoop.mapred.ID
constructs an ID object from the given int
ID() - Constructor for class org.apache.hadoop.mapred.ID
 
id() - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
Return the position in the collector this class occupies.
id() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Return the position in the collector this class occupies.
id - Variable in class org.apache.hadoop.mapred.join.Parser.Node
 
id() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
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.
ID - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
ident - Variable in class org.apache.hadoop.mapred.join.Parser.Node
 
ident - Variable in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
IdentityMapper<K,V> - Class in org.apache.hadoop.mapred.lib
Implements the identity function, mapping inputs directly to outputs.
IdentityMapper() - Constructor for class org.apache.hadoop.mapred.lib.IdentityMapper
 
IdentityReducer<K,V> - Class in org.apache.hadoop.mapred.lib
Performs no reduction, writing all input values directly to the output.
IdentityReducer() - Constructor for class org.apache.hadoop.mapred.lib.IdentityReducer
 
idFormat - Static variable in class org.apache.hadoop.mapreduce.JobID
 
idFormat - Static variable in class org.apache.hadoop.mapreduce.TaskID
 
idWithinJob() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
idx - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
idx - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
IFile - Class in org.apache.hadoop.mapred
IFile is the simple format for the intermediate map-outputs in Map-Reduce.
IFile() - Constructor for class org.apache.hadoop.mapred.IFile
 
IFile.Reader<K,V> - Class in org.apache.hadoop.mapred
IFile.Reader to read intermediate map-outputs.
IFile.Reader(Configuration, FileSystem, Path, CompressionCodec, Counters.Counter) - Constructor for class org.apache.hadoop.mapred.IFile.Reader
Construct an IFile Reader.
IFile.Reader(Configuration, FSDataInputStream, long, CompressionCodec, Counters.Counter) - Constructor for class org.apache.hadoop.mapred.IFile.Reader
Construct an IFile Reader.
IFile.Writer<K,V> - Class in org.apache.hadoop.mapred
IFile.Writer to write out intermediate map-outputs.
IFile.Writer(Configuration, FileSystem, Path, Class<K>, Class<V>, CompressionCodec, Counters.Counter) - Constructor for class org.apache.hadoop.mapred.IFile.Writer
 
IFile.Writer(Counters.Counter) - Constructor for class org.apache.hadoop.mapred.IFile.Writer
 
IFile.Writer(Configuration, FSDataOutputStream, Class<K>, Class<V>, CompressionCodec, Counters.Counter) - Constructor for class org.apache.hadoop.mapred.IFile.Writer
 
IFile.Writer(Configuration, FileSystem, Path) - Constructor for class org.apache.hadoop.mapred.IFile.Writer
 
IFileInputStream - Class in org.apache.hadoop.mapred
A checksum input stream, used for IFiles.
IFileInputStream(InputStream, long, Configuration) - Constructor for class org.apache.hadoop.mapred.IFileInputStream
Create a checksum input stream that reads
IFileOutputStream - Class in org.apache.hadoop.mapred
A Checksum output stream.
IFileOutputStream(OutputStream) - Constructor for class org.apache.hadoop.mapred.IFileOutputStream
Create a checksum output stream that writes the bytes to the given stream.
incrAllCounters(CounterGroupBase<Counters.Counter>) - Method in class org.apache.hadoop.mapred.Counters.Group
 
incrAllCounters(Counters) - Method in class org.apache.hadoop.mapred.Counters
Increments multiple counters by their amounts in another Counters instance.
incrAllCounters(CounterGroupBase<T>) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
incrAllCounters(AbstractCounters<C, G>) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Increments multiple counters by their amounts in another Counters instance.
incrAllCounters(CounterGroupBase<T>) - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
Increment all counters by a group of counters
incrAllCounters(CounterGroupBase<C>) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
incrAllCounters(CounterGroupBase<C>) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
incrCounter(Enum<?>, long) - Method in class org.apache.hadoop.mapred.Counters
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
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.
incrCounter(Enum, long) - Method in class org.apache.hadoop.mapred.Task.TaskReporter
 
incrCounter(String, String, long) - Method in class org.apache.hadoop.mapred.Task.TaskReporter
 
incrCounters() - Method in class org.apache.hadoop.mapreduce.counters.Limits
 
increment(long) - Method in class org.apache.hadoop.mapred.Counters.Counter
 
increment(long) - Method in interface org.apache.hadoop.mapreduce.Counter
Increment this counter by the given value
increment(long) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup.FSCounter
 
increment(long) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup.FrameworkCounter
 
increment(long) - Method in class org.apache.hadoop.mapreduce.counters.GenericCounter
 
INDEX_CACHE_MEMORY_LIMIT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
IndexRecord - Class in org.apache.hadoop.mapred
 
IndexRecord() - Constructor for class org.apache.hadoop.mapred.IndexRecord
 
IndexRecord(long, long, long) - Constructor for class org.apache.hadoop.mapred.IndexRecord
 
init(JobConf) - Method in class org.apache.hadoop.mapred.JobClient
Connect to the default cluster
init(MapOutputCollector.Context) - Method in interface org.apache.hadoop.mapred.MapOutputCollector
 
init(MapOutputCollector.Context) - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer
 
init(ShuffleConsumerPlugin.Context<K, V>) - Method in interface org.apache.hadoop.mapred.ShuffleConsumerPlugin
 
init(Configuration) - Static method in class org.apache.hadoop.mapreduce.counters.Limits
 
init(ShuffleConsumerPlugin.Context) - Method in class org.apache.hadoop.mapreduce.task.reduce.Shuffle
 
initialize(JobConf, JobID, Reporter, boolean) - Method in class org.apache.hadoop.mapred.Task
 
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.CombineFileRecordReaderWrapper
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.DelegatingRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthRecordReader
 
initialize(Configuration, long, long, Path) - Method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthRecordReader
 
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.LineRecordReader
 
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.
initializeInterval() - Method in class org.apache.hadoop.mapred.PeriodicStatsAccumulator
initializes the state variables to be ready for a new interval
initNextRecordReader() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
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.
InMemoryReader<K,V> - Class in org.apache.hadoop.mapreduce.task.reduce
IFile.InMemoryReader to read map-outputs present in-memory.
InMemoryReader(MergeManagerImpl<K, V>, TaskAttemptID, byte[], int, int, Configuration) - Constructor for class org.apache.hadoop.mapreduce.task.reduce.InMemoryReader
 
InMemoryWriter<K,V> - Class in org.apache.hadoop.mapreduce.task.reduce
 
InMemoryWriter(BoundedByteArrayOutputStream) - Constructor for class org.apache.hadoop.mapreduce.task.reduce.InMemoryWriter
 
InnerJoinRecordReader<K extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.hadoop.mapred.join
Full inner join.
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
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
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
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_DIR - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
INPUT_DIR_RECURSIVE - Static variable in class org.apache.hadoop.mapred.FileInputFormat
 
INPUT_DIR_RECURSIVE - 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
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_FORMAT_CLASS_ATTR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
INPUT_ORDER_BY_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
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
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
Input table name
INPUT_TABLE_NAME_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Input table name
inputBytes(long) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleClientMetrics
 
inputCounter - Variable in class org.apache.hadoop.mapred.Task.CombinerRunner
 
inputFile - Variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
InputFormat<K,V> - Interface in org.apache.hadoop.mapred
InputFormat describes the input-specification for a Map-Reduce job.
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
 
InputSampler<K,V> - Class in org.apache.hadoop.mapred.lib
 
InputSampler(JobConf) - Constructor for class org.apache.hadoop.mapred.lib.InputSampler
 
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.mapred.lib
Sample from s splits at regular intervals.
InputSampler.IntervalSampler(double) - Constructor for class org.apache.hadoop.mapred.lib.InputSampler.IntervalSampler
Create a new IntervalSampler sampling all splits.
InputSampler.IntervalSampler(double, int) - Constructor for class org.apache.hadoop.mapred.lib.InputSampler.IntervalSampler
Create a new IntervalSampler.
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.mapred.lib
Sample from random points in the input.
InputSampler.RandomSampler(double, int) - Constructor for class org.apache.hadoop.mapred.lib.InputSampler.RandomSampler
Create a new RandomSampler sampling all splits.
InputSampler.RandomSampler(double, int, int) - Constructor for class org.apache.hadoop.mapred.lib.InputSampler.RandomSampler
Create a new RandomSampler.
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.mapred.lib
Interface to sample using an InputFormat.
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.mapred.lib
Samples the first n records from s splits.
InputSampler.SplitSampler(int) - Constructor for class org.apache.hadoop.mapred.lib.InputSampler.SplitSampler
Create a SplitSampler sampling all splits.
InputSampler.SplitSampler(int, int) - Constructor for class org.apache.hadoop.mapred.lib.InputSampler.SplitSampler
Create a new SplitSampler.
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.
InputSplit - Interface in org.apache.hadoop.mapred
InputSplit represents the data to be processed by an individual Mapper.
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
 
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
 
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
 
InvalidJobConfException(String, Throwable) - Constructor for exception org.apache.hadoop.mapred.InvalidJobConfException
 
InvalidJobConfException(Throwable) - Constructor for exception org.apache.hadoop.mapred.InvalidJobConfException
 
InverseMapper<K,V> - Class in org.apache.hadoop.mapred.lib
A Mapper that swaps keys and values.
InverseMapper() - Constructor for class org.apache.hadoop.mapred.lib.InverseMapper
 
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
 
IO_SORT_FACTOR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
IO_SORT_MB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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
 
isAlive(String) - Static method in class org.apache.hadoop.mapreduce.util.ProcessTree
Is the process with PID pid still alive? This method assumes that isAlive is called on a pid that was alive not too long ago, and hence assumes no chance of pid-wrapping-around.
isBlacklisted() - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
Whether tracker is blacklisted
isComplete() - Method in interface org.apache.hadoop.mapred.RunningJob
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
 
isFrameworkGroup(String) - Static method in class org.apache.hadoop.mapreduce.counters.CounterGroupFactory
Check whether a group name is a name of a framework group (including the filesystem group).
isJobComplete() - Method in class org.apache.hadoop.mapreduce.JobStatus
Returns true if the status is for a completed job.
isJobDirValid(Path, FileSystem) - Static method in class org.apache.hadoop.mapred.JobClient
Checks if the job directory is clean and has all the required components for (re) starting the job
isMap - Variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
isMap() - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
Deprecated. 
isMap() - Method in class org.apache.hadoop.mapreduce.TaskID
Deprecated. 
isMapTask() - Method in class org.apache.hadoop.mapred.MapTask
 
isMapTask() - Method in class org.apache.hadoop.mapred.ReduceTask
 
isMapTask() - Method in class org.apache.hadoop.mapred.Task
 
isMapTask() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
isMultiNamedOutput(JobConf, String) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Returns if a named output is multiple.
isPrimaryMapOutput() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapOutput
 
isProcessGroupAlive(String) - Static method in class org.apache.hadoop.mapreduce.util.ProcessTree
Is the process group with still alive? This method assumes that isAlive is called on a pid that was alive not too long ago, and hence assumes no chance of pid-wrapping-around.
isReady() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
isRecoverySupported() - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
isRecoverySupported() - Method in class org.apache.hadoop.mapred.OutputCommitter
This method implements the new interface by calling the old method.
isRecoverySupported() - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
 
isRecoverySupported() - Method in class org.apache.hadoop.mapreduce.OutputCommitter
Is task output recovery supported for restarting jobs? If task output recovery is supported, job restart can be done more efficiently.
isRetired() - Method in interface org.apache.hadoop.mapred.RunningJob
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.
isSetsidAvailable - Static variable in class org.apache.hadoop.mapreduce.util.ProcessTree
 
isSkipping() - Method in class org.apache.hadoop.mapred.Task
Is Task in skipping mode.
isSplitable(FileSystem, Path) - Method in class org.apache.hadoop.mapred.FileInputFormat
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.FixedLengthInputFormat
 
isSplitable(FileSystem, Path) - Method in class org.apache.hadoop.mapred.KeyValueTextInputFormat
 
isSplitable(JobContext, Path) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
Subclasses should avoid overriding this method and should instead only override CombineFileInputFormat.isSplitable(FileSystem, Path).
isSplitable(FileSystem, Path) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
 
isSplitable(FileSystem, Path) - Method in class org.apache.hadoop.mapred.TextInputFormat
 
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.FixedLengthInputFormat
 
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
Check if the job completed successfully.
isSuccessful() - Method in class org.apache.hadoop.mapreduce.Job
Check if the job completed successfully.
isUber() - Method in class org.apache.hadoop.mapreduce.Job
 
isUber() - Method in class org.apache.hadoop.mapreduce.JobStatus
Whether job running in uber mode
iterator() - Method in class org.apache.hadoop.mapred.Counters.Group
 
iterator() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
iterator() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
 
iterator() - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
iterator() - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
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 - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JAR_UNPACK_PATTERN - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
jc - Variable in class org.apache.hadoop.mapred.join.CompositeRecordReader
 
jc - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
jc - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
JhCounter - Class in org.apache.hadoop.mapreduce.jobhistory
 
JhCounter() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Default constructor.
JhCounter(CharSequence, CharSequence, Long) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JhCounter
All-args constructor.
JhCounter.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for JhCounter instances.
JhCounterGroup - Class in org.apache.hadoop.mapreduce.jobhistory
 
JhCounterGroup() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Default constructor.
JhCounterGroup(CharSequence, CharSequence, List<JhCounter>) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
All-args constructor.
JhCounterGroup.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for JhCounterGroup instances.
JhCounters - Class in org.apache.hadoop.mapreduce.jobhistory
 
JhCounters() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JhCounters
Default constructor.
JhCounters(CharSequence, List<JhCounterGroup>) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JhCounters
All-args constructor.
JhCounters.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for JhCounters instances.
Job - Class in org.apache.hadoop.mapred.jobcontrol
 
Job(JobConf, ArrayList<?>) - Constructor for class org.apache.hadoop.mapred.jobcontrol.Job
Construct a job.
Job(JobConf) - Constructor for class org.apache.hadoop.mapred.jobcontrol.Job
 
job - Variable in class org.apache.hadoop.mapred.Task.CombinerRunner
 
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
 
JOB_ACL_MODIFY_JOB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_ACL_VIEW_JOB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_AM_ACCESS_DISABLED - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
AM ACL disabled.
JOB_CANCEL_DELEGATION_TOKEN - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_CONF_FILE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_DIR_PERMISSION - Static variable in class org.apache.hadoop.mapreduce.JobSubmissionFiles
 
JOB_FILE_PERMISSION - Static variable in class org.apache.hadoop.mapreduce.JobSubmissionFiles
 
JOB_JAR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_JOBTRACKER_ID - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_LOCAL_DIR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_NAME - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_NAMENODES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_SPLIT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_SPLIT_METAINFO - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_SUBMIT_DIR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_SUBMITHOST - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_SUBMITHOSTADDR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_TAGS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_TOKEN_HDFS_FILE - Static variable in class org.apache.hadoop.mapreduce.security.TokenCache
file name used on HDFS for generated job token
JOB_TOKEN_TRACKING_IDS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_TOKEN_TRACKING_IDS_ENABLED - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_TOKENS_FILENAME - Static variable in class org.apache.hadoop.mapreduce.security.TokenCache
conf setting for job tokens cache file name
JOB_UBERTASK_ENABLE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_UBERTASK_MAXBYTES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_UBERTASK_MAXMAPS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JOB_UBERTASK_MAXREDUCES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JobACL - Enum in org.apache.hadoop.mapreduce
Job related ACLs
jobACLNeeded - Variable in enum org.apache.hadoop.mapred.Operation
 
JobACLsManager - Class in org.apache.hadoop.mapred
 
JobACLsManager(Configuration) - Constructor for class org.apache.hadoop.mapred.JobACLsManager
 
jobCleanup - Variable in class org.apache.hadoop.mapred.Task
 
JobClient - Class in org.apache.hadoop.mapred
JobClient is the primary interface for the user-job to interact with the cluster.
JobClient() - Constructor for class org.apache.hadoop.mapred.JobClient
Create a job client.
JobClient(JobConf) - Constructor for class org.apache.hadoop.mapred.JobClient
Build a job client with the given JobConf, and connect to the default cluster
JobClient(Configuration) - Constructor for class org.apache.hadoop.mapred.JobClient
Build a job client with the given Configuration, and connect to the default cluster
JobClient(InetSocketAddress, Configuration) - Constructor for class org.apache.hadoop.mapred.JobClient
Build a job client, connect to the indicated job tracker.
JobClient.TaskStatusFilter - Enum in org.apache.hadoop.mapred
 
JobConf - Class in org.apache.hadoop.mapred
A map/reduce job configuration.
JobConf() - Constructor for class org.apache.hadoop.mapred.JobConf
Construct a map/reduce job configuration.
JobConf(Class) - Constructor for class org.apache.hadoop.mapred.JobConf
Construct a map/reduce job configuration.
JobConf(Configuration) - Constructor for class org.apache.hadoop.mapred.JobConf
Construct a map/reduce job configuration.
JobConf(Configuration, Class) - Constructor for class org.apache.hadoop.mapred.JobConf
Construct a map/reduce job configuration.
JobConf(String) - Constructor for class org.apache.hadoop.mapred.JobConf
Construct a map/reduce configuration.
JobConf(Path) - Constructor for class org.apache.hadoop.mapred.JobConf
Construct a map/reduce configuration.
JobConf(boolean) - Constructor for class org.apache.hadoop.mapred.JobConf
A new map/reduce configuration where the behavior of reading from the default resources can be turned off.
JobConfigurable - Interface in org.apache.hadoop.mapred
That what may be configured.
jobConfPath - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Deprecated. 
JobContext - Interface in org.apache.hadoop.mapred
 
jobContext - Variable in class org.apache.hadoop.mapred.Task
 
JobContext - Interface in org.apache.hadoop.mapreduce
A read-only view of the job that is provided to the tasks while they are running.
JobContextImpl - Class in org.apache.hadoop.mapred
 
JobContextImpl(JobConf, JobID, Progressable) - Constructor for class org.apache.hadoop.mapred.JobContextImpl
 
JobContextImpl(JobConf, JobID) - Constructor for class org.apache.hadoop.mapred.JobContextImpl
 
JobContextImpl - Class in org.apache.hadoop.mapreduce.task
A read-only view of the job that is provided to the tasks while they are running.
JobContextImpl(Configuration, JobID) - Constructor for class org.apache.hadoop.mapreduce.task.JobContextImpl
 
JobControl - Class in org.apache.hadoop.mapred.jobcontrol
 
JobControl(String) - Constructor for class org.apache.hadoop.mapred.jobcontrol.JobControl
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
 
JobEndNotifier - Class in org.apache.hadoop.mapred
 
JobEndNotifier() - Constructor for class org.apache.hadoop.mapred.JobEndNotifier
 
JobFinished - Class in org.apache.hadoop.mapreduce.jobhistory
 
JobFinished() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Default constructor.
JobFinished(CharSequence, Long, Integer, Integer, Integer, Integer, JhCounters, JhCounters, JhCounters) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobFinished
All-args constructor.
JobFinished.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for JobFinished instances.
JobFinishedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record successful completion of job
JobFinishedEvent(JobID, long, int, int, int, int, Counters, Counters, Counters) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
Create an event to record successful job completion
JobHistoryParser - Class in org.apache.hadoop.mapreduce.jobhistory
Default Parser for the JobHistory files.
JobHistoryParser(FileSystem, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser
Create a job history parser for the given history file using the given file system
JobHistoryParser(FileSystem, Path) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser
Create the job history parser for the given history file using the given file system
JobHistoryParser(FSDataInputStream) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser
Create the history parser based on the input stream
JobHistoryParser.AMInfo - Class in org.apache.hadoop.mapreduce.jobhistory
Stores AM information
JobHistoryParser.AMInfo() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.AMInfo
Create a AM Info which will store AM level information on a history parse.
JobHistoryParser.AMInfo(ApplicationAttemptId, long, ContainerId, String, int, int) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.AMInfo
 
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
 
JobID - Class in org.apache.hadoop.mapred
JobID represents the immutable and unique identifier for the job.
JobID(String, int) - Constructor for class org.apache.hadoop.mapred.JobID
Constructs a JobID object
JobID() - Constructor for class org.apache.hadoop.mapred.JobID
 
jobid - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Deprecated. 
jobid - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Deprecated. 
jobid - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Deprecated. 
jobid - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
Deprecated. 
jobid - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
Deprecated. 
jobid - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
Deprecated. 
jobid - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Deprecated. 
jobid - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
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_REGEX - Static variable in class org.apache.hadoop.mapreduce.JobID
 
JobInfoChange - Class in org.apache.hadoop.mapreduce.jobhistory
 
JobInfoChange() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Default constructor.
JobInfoChange(CharSequence, Long, Long) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
All-args constructor.
JobInfoChange.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for JobInfoChange instances.
JobInfoChangeEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record changes in the submit and launch time of a job
JobInfoChangeEvent(JobID, long, long) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobInfoChangeEvent
Create a event to record the submit and launch time of a job
JobInited - Class in org.apache.hadoop.mapreduce.jobhistory
 
JobInited() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobInited
Default constructor.
JobInited(CharSequence, Long, Integer, Integer, CharSequence, Boolean) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobInited
All-args constructor.
JobInited.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for JobInited instances.
JobInitedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record the initialization of a job
JobInitedEvent(JobID, long, int, int, String, boolean) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobInitedEvent
Create an event to record job initialization
JobInProgress - Class in org.apache.hadoop.mapred
 
JobInProgress() - Constructor for class org.apache.hadoop.mapred.JobInProgress
 
JobInProgress.Counter - Enum in org.apache.hadoop.mapred
Deprecated. Provided for compatibility. Use JobCounter instead.
jobName - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Deprecated. 
JobPriority - Enum in org.apache.hadoop.mapred
Used to describe the priority of the running job.
JobPriority - Enum in org.apache.hadoop.mapreduce
Used to describe the priority of the running job.
JobPriorityChange - Class in org.apache.hadoop.mapreduce.jobhistory
 
JobPriorityChange() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
Default constructor.
JobPriorityChange(CharSequence, CharSequence) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
All-args constructor.
JobPriorityChange.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for JobPriorityChange instances.
JobPriorityChangeEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record the change of priority of a job
JobPriorityChangeEvent(JobID, JobPriority) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChangeEvent
Generate an event to record changes in Job priority
JobProfile - Class in org.apache.hadoop.mapred
A JobProfile is a MapReduce primitive.
JobProfile() - Constructor for class org.apache.hadoop.mapred.JobProfile
Construct an empty JobProfile.
JobProfile(String, JobID, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobProfile
Construct a JobProfile the userid, jobid, job config-file, job-details url and job name.
JobProfile(String, JobID, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobProfile
Construct a JobProfile the userid, jobid, job config-file, job-details url and job name.
JobProfile(String, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobProfile
Deprecated. use JobProfile(String, JobID, String, String, String) instead
JobQueueChange - Class in org.apache.hadoop.mapreduce.jobhistory
 
JobQueueChange() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
Default constructor.
JobQueueChange(CharSequence, CharSequence) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
All-args constructor.
JobQueueChange.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for JobQueueChange instances.
JobQueueChangeEvent - Class in org.apache.hadoop.mapreduce.jobhistory
 
JobQueueChangeEvent(JobID, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobQueueChangeEvent
 
JobQueueInfo - Class in org.apache.hadoop.mapred
Class that contains the information regarding the Job Queues which are maintained by the Hadoop Map/Reduce framework.
JobQueueInfo() - Constructor for class org.apache.hadoop.mapred.JobQueueInfo
Default constructor for Job Queue Info.
JobQueueInfo(String, String) - Constructor for class org.apache.hadoop.mapred.JobQueueInfo
Construct a new JobQueueInfo object using the queue name and the scheduling information passed.
jobQueueName - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
Deprecated. 
jobQueueName - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Deprecated. 
jobRunStateForCleanup - Variable in class org.apache.hadoop.mapred.Task
 
jobSetup - Variable in class org.apache.hadoop.mapred.Task
 
JobSplit - Class in org.apache.hadoop.mapreduce.split
This class groups the fundamental classes associated with reading/writing splits.
JobSplit() - Constructor for class org.apache.hadoop.mapreduce.split.JobSplit
 
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
 
JobSplitWriter - Class in org.apache.hadoop.mapreduce.split
The class that is used by the Job clients to write splits (both the meta and the raw bytes parts)
JobSplitWriter() - Constructor for class org.apache.hadoop.mapreduce.split.JobSplitWriter
 
JobStatus - Class in org.apache.hadoop.mapred
Describes the current status of a job.
JobStatus() - Constructor for class org.apache.hadoop.mapred.JobStatus
 
JobStatus(JobID, float, float, float, int) - Constructor for class org.apache.hadoop.mapred.JobStatus
Deprecated. 
JobStatus(JobID, float, float, int) - Constructor for class org.apache.hadoop.mapred.JobStatus
Deprecated. 
JobStatus(JobID, float, float, float, int, JobPriority) - Constructor for class org.apache.hadoop.mapred.JobStatus
Deprecated. 
JobStatus(JobID, float, float, float, float, int, JobPriority) - 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
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
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
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
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, int, JobPriority, String, String, String, String, boolean) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, int, JobPriority, String, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, int, JobPriority, String, String, String, String, String, boolean) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
jobStatus - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Deprecated. 
jobStatus - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
Deprecated. 
jobStatus - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Deprecated. 
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(JobID, float, float, float, float, JobStatus.State, JobPriority, String, String, String, String, String) - Constructor for class org.apache.hadoop.mapreduce.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, JobStatus.State, JobPriority, String, String, String, String, String, boolean) - 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
JobStatusChanged - Class in org.apache.hadoop.mapreduce.jobhistory
 
JobStatusChanged() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
Default constructor.
JobStatusChanged(CharSequence, CharSequence) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
All-args constructor.
JobStatusChanged.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for JobStatusChanged instances.
JobStatusChangedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record the change of status for a job
JobStatusChangedEvent(JobID, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobStatusChangedEvent
Create an event to record the change in the Job Status
jobsToComplete() - Method in class org.apache.hadoop.mapred.JobClient
Get the jobs that are not completed and not failed.
JobSubmissionFiles - Class in org.apache.hadoop.mapreduce
A utility to manage job submission files.
JobSubmissionFiles() - Constructor for class org.apache.hadoop.mapreduce.JobSubmissionFiles
 
jobSubmit(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Submit a job to the Map-Reduce framework.
JobSubmitted - Class in org.apache.hadoop.mapreduce.jobhistory
 
JobSubmitted() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Default constructor.
JobSubmitted(CharSequence, CharSequence, CharSequence, Long, CharSequence, Map<CharSequence, CharSequence>, CharSequence, CharSequence, CharSequence, CharSequence, CharSequence, CharSequence) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
All-args constructor.
JobSubmitted.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for JobSubmitted instances.
JobSubmittedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record the submission of a job
JobSubmittedEvent(JobID, String, String, long, String, Map<JobACL, AccessControlList>, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Create an event to record job submission
JobSubmittedEvent(JobID, String, String, long, String, Map<JobACL, AccessControlList>, String, String, String, String, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Create an event to record job submission
JobSubmittedEvent(JobID, String, String, long, String, Map<JobACL, AccessControlList>, String, String, String, String, String, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Create an event to record job submission
JobTokenIdentifier - Class in org.apache.hadoop.mapreduce.security.token
The token identifier for job token
JobTokenIdentifier() - Constructor for class org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier
Default constructor
JobTokenIdentifier(Text) - Constructor for class org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier
Create a job token identifier from a jobid
JobTokenIdentifier.Renewer - Class in org.apache.hadoop.mapreduce.security.token
 
JobTokenIdentifier.Renewer() - Constructor for class org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier.Renewer
 
JobTokenSecretManager - Class in org.apache.hadoop.mapreduce.security.token
SecretManager for job token.
JobTokenSecretManager() - Constructor for class org.apache.hadoop.mapreduce.security.token.JobTokenSecretManager
Default constructor
JobTokenSelector - Class in org.apache.hadoop.mapreduce.security.token
Look through tokens to find the first job token that matches the service and return it.
JobTokenSelector() - Constructor for class org.apache.hadoop.mapreduce.security.token.JobTokenSelector
 
JobTracker - Class in org.apache.hadoop.mapred
JobTracker is no longer used since M/R 2.x.
JobTracker() - Constructor for class org.apache.hadoop.mapred.JobTracker
 
JobTracker.State - Enum in org.apache.hadoop.mapred
State is no longer used since M/R 2.x.
JobUnsuccessfulCompletion - Class in org.apache.hadoop.mapreduce.jobhistory
 
JobUnsuccessfulCompletion() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Default constructor.
JobUnsuccessfulCompletion(CharSequence, Long, Integer, Integer, CharSequence, CharSequence) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
All-args constructor.
JobUnsuccessfulCompletion.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for JobUnsuccessfulCompletion instances.
JobUnsuccessfulCompletionEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record Failed and Killed completion of jobs
JobUnsuccessfulCompletionEvent(JobID, long, int, int, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletionEvent
Create an event to record unsuccessful completion (killed/failed) of jobs
JobUnsuccessfulCompletionEvent(JobID, long, int, int, String, Iterable<String>) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletionEvent
Create an event to record unsuccessful completion (killed/failed) of jobs
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
Base class for Composite joins returning Tuples of arbitrary Writables.
JoinRecordReader(int, JobConf, int, Class<? extends WritableComparator>) - Constructor for class org.apache.hadoop.mapred.join.JoinRecordReader
 
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
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
 
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
 
JT_AVG_BLACKLIST_THRESHOLD - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_HEARTBEAT_INTERVAL_MIN - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_HEARTBEAT_INTERVAL_MIN_DEFAULT - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_HEARTBEATS_IN_SECOND - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_HEARTBEATS_SCALING_FACTOR - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_HOSTS_EXCLUDE_FILENAME - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_HOSTS_FILENAME - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_HTTP_ADDRESS - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_INSTRUMENTATION - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_IPC_ADDRESS - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_IPC_HANDLER_COUNT - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_JOBHISTORY_BLOCK_SIZE - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_JOBHISTORY_CACHE_SIZE - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_JOBHISTORY_COMPLETED_LOCATION - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_JOBHISTORY_LOCATION - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_JOBHISTORY_MAXAGE - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_JOBHISTORY_TASKPROGRESS_NUMBER_SPLITS - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_JOBINIT_THREADS - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_KEYTAB_FILE - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_MAX_JOB_SPLIT_METAINFO_SIZE - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_MAX_MAPMEMORY_MB - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_MAX_REDUCEMEMORY_MB - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_MAX_TRACKER_BLACKLISTS - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_PERSIST_JOBSTATUS - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_PERSIST_JOBSTATUS_DIR - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_PERSIST_JOBSTATUS_HOURS - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_PLUGINS - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_RESTART_ENABLED - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_RETIREJOB_CACHE_SIZE - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_RETIREJOBS - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_RUNNINGTASKS_PER_JOB - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_STAGING_AREA_ROOT - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_SUPERGROUP - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
Deprecated. Use MR_SUPERGROUP instead
JT_SYSTEM_DIR - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_TASK_ALLOC_PAD_FRACTION - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_TASK_SCHEDULER - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_TASKCACHE_LEVELS - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_TASKS_PER_JOB - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_TRACKER_EXPIRY_INTERVAL - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JT_USER_NAME - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
JTConfig - Interface in org.apache.hadoop.mapreduce.server.jobtracker
Place holder for JobTracker server-level configuration.
JVM_NUMTASKS_TORUN - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
JvmTask - Class in org.apache.hadoop.mapred
Task abstraction that can be serialized, implements the writable interface.
JvmTask(Task, boolean) - Constructor for class org.apache.hadoop.mapred.JvmTask
 
JvmTask() - Constructor for class org.apache.hadoop.mapred.JvmTask
 

K

keepTaskFiles(JobConf) - Method in class org.apache.hadoop.mapred.Task
 
key() - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
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
Clone the key at the head of this RecordReader into the object provided.
key() - Method in class org.apache.hadoop.mapred.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.mapred.join.CompositeRecordReader
Clone the key at the top of this RR into the given object.
key() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Return the key at the head of this RR.
key(K) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
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_COMPARATOR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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
This comparator implementation provides a subset of the features provided by the Unix/GNU Sort.
KeyFieldBasedComparator() - Constructor for class org.apache.hadoop.mapred.lib.KeyFieldBasedComparator
 
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
Defines a way to partition keys based on certain key fields (also see KeyFieldBasedComparator.
KeyFieldBasedPartitioner() - Constructor for class org.apache.hadoop.mapred.lib.KeyFieldBasedPartitioner
 
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
This class treats a line in the input as a key/value pair separated by a separator character.
KeyValueLineRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.mapred.KeyValueLineRecordReader
 
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
An InputFormat for plain text files.
KeyValueTextInputFormat() - Constructor for class org.apache.hadoop.mapred.KeyValueTextInputFormat
 
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
 
kids - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
KILLED - Static variable in class org.apache.hadoop.mapred.JobStatus
 
killJob() - Method in interface org.apache.hadoop.mapred.RunningJob
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
 
killJob(JobID) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Kill the indicated job
killProcess(String) - Static method in class org.apache.hadoop.mapreduce.util.ProcessTree
Sends kill signal to process, forcefully terminating the process.
killProcessGroup(String) - Static method in class org.apache.hadoop.mapreduce.util.ProcessTree
Sends kill signal to all process belonging to same process group, forcefully terminating the process group.
killTask(TaskAttemptID, boolean) - Method in interface org.apache.hadoop.mapred.RunningJob
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, boolean) - Method in class org.apache.hadoop.mapreduce.Job
Kill indicated task attempt.
killTask(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.Job
Kill indicated task attempt.
killTask(TaskAttemptID, boolean) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Kill indicated task attempt.
KIND_NAME - Static variable in class org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier
 

L

launchTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Deprecated. 
launchTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Deprecated. 
LazyOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
A Convenience class that creates output lazily.
LazyOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.LazyOutputFormat
 
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
 
lDirAlloc - Variable in class org.apache.hadoop.mapred.Task
 
LEFT_OFFSET_PROPERTY_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
 
LimitExceededException - Exception in org.apache.hadoop.mapreduce.counters
 
LimitExceededException(String) - Constructor for exception org.apache.hadoop.mapreduce.counters.LimitExceededException
 
LimitExceededException(LimitExceededException) - Constructor for exception org.apache.hadoop.mapreduce.counters.LimitExceededException
 
limits() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
 
Limits - Class in org.apache.hadoop.mapreduce.counters
 
Limits() - Constructor for class org.apache.hadoop.mapreduce.counters.Limits
 
LineRecordReader - Class in org.apache.hadoop.mapred
Treats keys as offset in file and value as line.
LineRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.mapred.LineRecordReader
 
LineRecordReader(Configuration, FileSplit, byte[]) - Constructor for class org.apache.hadoop.mapred.LineRecordReader
 
LineRecordReader(InputStream, long, long, int) - Constructor for class org.apache.hadoop.mapred.LineRecordReader
 
LineRecordReader(InputStream, long, long, int, byte[]) - Constructor for class org.apache.hadoop.mapred.LineRecordReader
 
LineRecordReader(InputStream, long, long, Configuration) - Constructor for class org.apache.hadoop.mapred.LineRecordReader
 
LineRecordReader(InputStream, long, long, Configuration, byte[]) - Constructor for class org.apache.hadoop.mapred.LineRecordReader
 
LineRecordReader - Class in org.apache.hadoop.mapreduce.lib.input
Treats keys as offset in file and value as line.
LineRecordReader() - Constructor for class org.apache.hadoop.mapreduce.lib.input.LineRecordReader
 
LineRecordReader(byte[]) - Constructor for class org.apache.hadoop.mapreduce.lib.input.LineRecordReader
 
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.  
LineRecordReader.LineReader(InputStream, Configuration, byte[]) - Constructor for class org.apache.hadoop.mapred.LineRecordReader.LineReader
Deprecated.  
LINES_PER_MAP - Static variable in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
 
LIST_STATUS_NUM_THREADS - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
listStatus(JobConf) - Method in class org.apache.hadoop.mapred.FileInputFormat
List input directories.
listStatus(JobConf) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
List input directories.
listStatus(JobConf) - Method in class org.apache.hadoop.mapred.SequenceFileInputFormat
 
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
 
loadResources() - Static method in class org.apache.hadoop.mapreduce.util.ConfigUtil
Adds all the deprecated keys.
loadTokens(String, JobConf) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
Deprecated. Use Credentials.readTokenStorageFile(org.apache.hadoop.fs.Path, org.apache.hadoop.conf.Configuration) instead, this method is included for compatibility against Hadoop-1.
loadTokens(String, Configuration) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
Deprecated. Use Credentials.readTokenStorageFile(org.apache.hadoop.fs.Path, org.apache.hadoop.conf.Configuration) instead, this method is included for compatibility against Hadoop-1.
LOCAL_DIR - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
LOCAL_FRAMEWORK_NAME - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
locality - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Deprecated. 
localizeConfiguration(JobConf) - Method in class org.apache.hadoop.mapred.MapTask
 
localizeConfiguration(JobConf) - Method in class org.apache.hadoop.mapred.ReduceTask
Localize the given JobConf to be specific for this task.
localizeConfiguration(JobConf) - Method in class org.apache.hadoop.mapred.Task
Localize the given JobConf to be specific for this task.
localizeCounterName(String) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup.FSCounter
 
localRunnerNotification(JobConf, JobStatus) - Static method in class org.apache.hadoop.mapred.JobEndNotifier
 
LocatedFileStatusFetcher - Class in org.apache.hadoop.mapred
Utility class to fetch block locations for specified Input paths using a configured number of threads.
LocatedFileStatusFetcher(Configuration, Path[], boolean, PathFilter, boolean) - Constructor for class org.apache.hadoop.mapred.LocatedFileStatusFetcher
 
log(Log) - Method in class org.apache.hadoop.mapred.Counters
Logs the current counter values.
LOG - Static variable in class org.apache.hadoop.mapred.FileInputFormat
 
LOG - Static variable in class org.apache.hadoop.mapred.FileOutputCommitter
 
LOG - Static variable in class org.apache.hadoop.mapred.IFileInputStream
 
LOG - Static variable in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
 
LOG - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
LOG - Static variable in class org.apache.hadoop.mapreduce.counters.AbstractCounters
 
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
 
LogParams - Class in org.apache.hadoop.mapreduce.v2
 
LogParams(String, String, String, String) - Constructor for class org.apache.hadoop.mapreduce.v2.LogParams
 
logSpec() - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
 
logSpec() - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
LONG_VALUE_MAX - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
 
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
 
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
 
LONG_VALUE_SUM - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
LongSumReducer<K> - Class in org.apache.hadoop.mapred.lib
A Reducer that sums long values.
LongSumReducer() - Constructor for class org.apache.hadoop.mapred.lib.LongSumReducer
 
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
This class implements a value aggregator that maintain the maximum of a sequence of long values.
LongValueMax() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.LongValueMax
 
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
This class implements a value aggregator that maintain the minimum of a sequence of long values.
LongValueMin() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.LongValueMin
 
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
This class implements a value aggregator that sums up a sequence of long values.
LongValueSum() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.LongValueSum
 
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

M

main(String[]) - Static method in class org.apache.hadoop.mapred.JobClient
 
main(String[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
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.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.mapreduce.util.ConfigUtil
 
makeCompactString() - Method in class org.apache.hadoop.mapred.Counters
 
makeEscapedCompactString() - Method in class org.apache.hadoop.mapred.Counters.Counter
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
 
makeEscapedCompactString() - Method in class org.apache.hadoop.mapred.Counters
Represent the counter in a textual format that can be converted back to its object form
makeSplit(Path, long, long, String[]) - Method in class org.apache.hadoop.mapred.FileInputFormat
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(K1, V1, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Do nothing.
map(K1, V1, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorMapper
the map function.
map(K1, V1, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorReducer
Do nothing.
map(Object, Object, OutputCollector, Reporter) - Method in class org.apache.hadoop.mapred.lib.ChainMapper
Chains the map(...) methods of the Mappers in the chain.
map(K1, V1, OutputCollector<K2, V2>, Reporter) - Method in class org.apache.hadoop.mapred.lib.DelegatingMapper
 
map(K, V, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
The identify function.
map(K, V, OutputCollector<K, V>, Reporter) - Method in class org.apache.hadoop.mapred.lib.IdentityMapper
The identify function.
map(K, V, OutputCollector<V, K>, Reporter) - Method in class org.apache.hadoop.mapred.lib.InverseMapper
The inverse function.
map(K, Text, OutputCollector<Text, LongWritable>, Reporter) - Method in class org.apache.hadoop.mapred.lib.RegexMapper
 
map(K, Text, OutputCollector<Text, LongWritable>, Reporter) - Method in class org.apache.hadoop.mapred.lib.TokenCountMapper
 
map(K1, V1, OutputCollector<K2, V2>, Reporter) - Method in interface org.apache.hadoop.mapred.Mapper
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_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
 
MAP_CLASS_ATTR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_COMBINE_MIN_SPILLS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_CPU_VCORES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_DEBUG_SCRIPT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_ENV - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_FAILURES_MAX_PERCENT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_INPUT_FILE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_INPUT_PATH - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_INPUT_START - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_JAVA_OPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_LOG_LEVEL - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_MAX_ATTEMPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_MEMORY_MB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_OUTPUT_COLLECTOR_CLASS_ATTR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_OUTPUT_COMPRESS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_OUTPUT_COMPRESS_CODEC - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_OUTPUT_INDEX_RECORD_LENGTH - Static variable in class org.apache.hadoop.mapred.MapTask
The size of each record in the index file for the map-outputs.
MAP_OUTPUT_KEY_CLASS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_OUTPUT_KEY_FIELD_SEPERATOR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_OUTPUT_KEY_VALUE_SPEC - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
MAP_OUTPUT_LENGTH - Static variable in interface org.apache.hadoop.mapred.MRConstants
The custom http header used for the map output length.
MAP_OUTPUT_VALUE_CLASS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_SKIP_INCR_PROC_COUNT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_SKIP_MAX_RECORDS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_SORT_SPILL_PERCENT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAP_SPECULATIVE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MapAttemptFinished - Class in org.apache.hadoop.mapreduce.jobhistory
 
MapAttemptFinished() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Default constructor.
MapAttemptFinished(CharSequence, CharSequence, CharSequence, CharSequence, Long, Long, CharSequence, Integer, CharSequence, CharSequence, JhCounters, List<Integer>, List<Integer>, List<Integer>, List<Integer>) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
All-args constructor.
MapAttemptFinished.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for MapAttemptFinished instances.
MapAttemptFinishedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record successful completion of a map attempt
MapAttemptFinishedEvent(TaskAttemptID, TaskType, String, long, long, String, int, String, String, Counters, int[][]) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Create an event for successful completion of map attempts
MapAttemptFinishedEvent(TaskAttemptID, TaskType, String, long, long, String, String, Counters) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Deprecated. please use the constructor with an additional argument, an array of splits arrays instead. See ProgressSplitsBlock for an explanation of the meaning of that parameter. Create an event for successful completion of map attempts
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.
MapContextImpl<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce.task
The context that is given to the Mapper.
MapContextImpl(Configuration, TaskAttemptID, RecordReader<KEYIN, VALUEIN>, RecordWriter<KEYOUT, VALUEOUT>, OutputCommitter, StatusReporter, InputSplit) - Constructor for class org.apache.hadoop.mapreduce.task.MapContextImpl
 
mapCounters - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Deprecated. 
MapFileOutputFormat - Class in org.apache.hadoop.mapred
An OutputFormat that writes MapFiles.
MapFileOutputFormat() - Constructor for class org.apache.hadoop.mapred.MapFileOutputFormat
 
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
 
mapFinishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
MapHost - Class in org.apache.hadoop.mapreduce.task.reduce
 
MapHost(String, String) - Constructor for class org.apache.hadoop.mapreduce.task.reduce.MapHost
 
MapHost.State - Enum in org.apache.hadoop.mapreduce.task.reduce
 
MAPMEMORY_MB - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
MapOutput<K,V> - Class in org.apache.hadoop.mapreduce.task.reduce
 
MapOutput(TaskAttemptID, long, boolean) - Constructor for class org.apache.hadoop.mapreduce.task.reduce.MapOutput
 
MapOutput.MapOutputComparator<K,V> - Class in org.apache.hadoop.mapreduce.task.reduce
 
MapOutput.MapOutputComparator() - Constructor for class org.apache.hadoop.mapreduce.task.reduce.MapOutput.MapOutputComparator
 
MapOutputCollector<K,V> - Interface in org.apache.hadoop.mapred
 
MapOutputCollector.Context - Class in org.apache.hadoop.mapred
 
MapOutputCollector.Context(MapTask, JobConf, Task.TaskReporter) - Constructor for class org.apache.hadoop.mapred.MapOutputCollector.Context
 
MapOutputFile - Class in org.apache.hadoop.mapred
Manipulate the working area for the transient store for maps and reduces.
MapOutputFile() - Constructor for class org.apache.hadoop.mapred.MapOutputFile
 
mapOutputFile - Variable in class org.apache.hadoop.mapred.Task
 
mapOutputFile - Variable in class org.apache.hadoop.mapreduce.task.reduce.MergeManagerImpl
 
Mapper<K1,V1,K2,V2> - Interface in org.apache.hadoop.mapred
Maps input key/value pairs to a set of intermediate key/value pairs.
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
 
MAPPER_INPUT_KEY_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
MAPPER_INPUT_VALUE_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
MAPPER_OUTPUT_KEY_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
MAPPER_OUTPUT_VALUE_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
mapProgress() - Method in class org.apache.hadoop.mapred.JobStatus
 
mapProgress() - Method in interface org.apache.hadoop.mapred.RunningJob
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_ADMIN_USER_ENV - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAPRED_ADMIN_USER_SHELL - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAPRED_IFILE_READAHEAD - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
Configuration key to enable/disable IFile readahead.
MAPRED_IFILE_READAHEAD_BYTES - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
Configuration key to set the IFile readahead length in bytes.
MAPRED_JOB_MAP_MEMORY_MB_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
MAPRED_JOB_REDUCE_MEMORY_MB_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
MAPRED_LOCAL_DIR_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Property name for the configuration property mapreduce.cluster.local.dir
MAPRED_MAP_ADMIN_JAVA_OPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAPRED_MAP_TASK_ENV - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the environment of the child map tasks.
MAPRED_MAP_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
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
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 virtual memory available to the map tasks (in kilo-bytes). This has been deprecated and will no longer have any effect.
MAPRED_REDUCE_ADMIN_JAVA_OPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAPRED_REDUCE_TASK_ENV - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the environment of the child reduce tasks.
MAPRED_REDUCE_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
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
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 virtual memory available to the reduce tasks (in kilo-bytes). This has been deprecated and will no longer have any effect.
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.MAPREDUCE_JOB_MAP_MEMORY_MB_PROPERTY and JobConf.MAPREDUCE_JOB_REDUCE_MEMORY_MB_PROPERTY
MAPRED_TASK_ULIMIT - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. Configuration key to set the maximum virtual memory available to the child map and reduce tasks (in kilo-bytes). This has been deprecated and will no longer have any effect.
MAPREDUCE_APP_SUBMISSION_CROSS_PLATFORM - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
MAPREDUCE_APPLICATION_CLASSPATH - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
CLASSPATH for all YARN MapReduce applications.
MAPREDUCE_APPLICATION_FRAMEWORK_PATH - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Path to MapReduce framework archive
MAPREDUCE_CLIENT_RETRY_POLICY_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.mapred.JobClient
 
MAPREDUCE_CLIENT_RETRY_POLICY_ENABLED_KEY - Static variable in class org.apache.hadoop.mapred.JobClient
 
MAPREDUCE_CLIENT_RETRY_POLICY_SPEC_DEFAULT - Static variable in class org.apache.hadoop.mapred.JobClient
 
MAPREDUCE_CLIENT_RETRY_POLICY_SPEC_KEY - Static variable in class org.apache.hadoop.mapred.JobClient
 
MAPREDUCE_DELEGATION_KIND - Static variable in class org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier
 
MAPREDUCE_JOB_CLASSLOADER - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAPREDUCE_JOB_CLASSLOADER_SYSTEM_CLASSES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAPREDUCE_JOB_CREDENTIALS_BINARY - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAPREDUCE_JOB_DIR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAPREDUCE_JOB_SHUFFLE_PROVIDER_SERVICES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
A comma-separated list of services that function as ShuffleProvider aux-services (in addition to the built-in ShuffleHandler).
MAPREDUCE_JOB_USER_CLASSPATH_FIRST - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAPREDUCE_MINICLUSTER_CONTROL_RESOURCE_MONITORING - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
Whether users are explicitly trying to control resource monitoring configuration for the MiniMRCluster.
MAPREDUCE_RECOVER_JOB - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
MAPREDUCE_V2_CHILD_CLASS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MapReduceBase - Class in org.apache.hadoop.mapred
Base class for Mapper and Reducer implementations.
MapReduceBase() - Constructor for class org.apache.hadoop.mapred.MapReduceBase
 
MapRunnable<K1,V1,K2,V2> - Interface in org.apache.hadoop.mapred
Expert: Generic interface for Mappers.
MapRunner<K1,V1,K2,V2> - Class in org.apache.hadoop.mapred
Default MapRunnable implementation.
MapRunner() - Constructor for class org.apache.hadoop.mapred.MapRunner
 
MapTask - Class in org.apache.hadoop.mapred
A Map task.
MapTask() - Constructor for class org.apache.hadoop.mapred.MapTask
 
MapTask(String, TaskAttemptID, int, JobSplit.TaskSplitIndex, int) - Constructor for class org.apache.hadoop.mapred.MapTask
 
MapTask.MapOutputBuffer<K,V> - Class in org.apache.hadoop.mapred
 
MapTask.MapOutputBuffer() - Constructor for class org.apache.hadoop.mapred.MapTask.MapOutputBuffer
 
MapTask.MapOutputBuffer.BlockingBuffer - Class in org.apache.hadoop.mapred
Inner class managing the spill of serialized records to disk.
MapTask.MapOutputBuffer.BlockingBuffer() - Constructor for class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.BlockingBuffer
 
MapTask.MapOutputBuffer.Buffer - Class in org.apache.hadoop.mapred
 
MapTask.MapOutputBuffer.Buffer() - Constructor for class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.Buffer
 
MapTask.MapOutputBuffer.InMemValBytes - Class in org.apache.hadoop.mapred
Inner class wrapping valuebytes, used for appendRaw.
MapTask.MapOutputBuffer.InMemValBytes() - Constructor for class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.InMemValBytes
 
MapTask.MapOutputBuffer.MRResultIterator - Class in org.apache.hadoop.mapred
 
MapTask.MapOutputBuffer.MRResultIterator(int, int) - Constructor for class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.MRResultIterator
 
MapTask.MapOutputBuffer.SpillThread - Class in org.apache.hadoop.mapred
 
MapTask.MapOutputBuffer.SpillThread() - Constructor for class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.SpillThread
 
MapTaskCompletionEventsUpdate - Class in org.apache.hadoop.mapred
A class that represents the communication between the tasktracker and child tasks w.r.t the map task completion events.
MapTaskCompletionEventsUpdate() - Constructor for class org.apache.hadoop.mapred.MapTaskCompletionEventsUpdate
 
MapTaskCompletionEventsUpdate(TaskCompletionEvent[], boolean) - Constructor for class org.apache.hadoop.mapred.MapTaskCompletionEventsUpdate
 
mark() - Method in class org.apache.hadoop.mapred.BackupStore
 
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
markAvailable() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapHost
Called when the node is done with its penalty or done copying.
markBusy() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapHost
 
markPenalized() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapHost
 
markRecord() - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.BlockingBuffer
Mark end of record.
Master - Class in org.apache.hadoop.mapred
 
Master() - Constructor for class org.apache.hadoop.mapred.Master
 
Master.State - Enum in org.apache.hadoop.mapred
 
MASTER_ADDRESS - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
MASTER_USER_NAME - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
MAX_BLOCK_LOCATIONS_DEFAULT - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
MAX_BLOCK_LOCATIONS_KEY - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
MAX_COUNTER_LIMIT - Static variable in class org.apache.hadoop.mapred.Counters
 
MAX_GROUP_LIMIT - Static variable in class org.apache.hadoop.mapred.Counters
 
MAX_LINE_LENGTH - Static variable in class org.apache.hadoop.mapreduce.lib.input.LineRecordReader
 
MAX_NUM_UNIQUE_VALUES - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
 
MAX_SHUFFLE_FETCH_RETRY_DELAY - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAX_TASK_FAILURES_PER_TRACKER - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MAX_TRIE_DEPTH - Static variable in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
maxSplitsSampled - Variable in class org.apache.hadoop.mapreduce.lib.partition.InputSampler.IntervalSampler
 
maxSplitsSampled - Variable in class org.apache.hadoop.mapreduce.lib.partition.InputSampler.RandomSampler
 
maxSplitsSampled - Variable in class org.apache.hadoop.mapreduce.lib.partition.InputSampler.SplitSampler
 
MD5_LEN - Static variable in class org.apache.hadoop.mapred.SequenceFileInputFilter.MD5Filter
 
MD5_LEN - Static variable in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.MD5Filter
 
merge(Configuration, FileSystem, Class<K>, Class<V>, CompressionCodec, Path[], boolean, int, Path, RawComparator<K>, Progressable, Counters.Counter, Counters.Counter, Progress) - Static method in class org.apache.hadoop.mapred.Merger
 
merge(Configuration, FileSystem, Class<K>, Class<V>, CompressionCodec, Path[], boolean, int, Path, RawComparator<K>, Progressable, Counters.Counter, Counters.Counter, Counters.Counter, Progress) - Static method in class org.apache.hadoop.mapred.Merger
 
merge(Configuration, FileSystem, Class<K>, Class<V>, List<Merger.Segment<K, V>>, int, Path, RawComparator<K>, Progressable, Counters.Counter, Counters.Counter, Progress) - Static method in class org.apache.hadoop.mapred.Merger
 
merge(Configuration, FileSystem, Class<K>, Class<V>, List<Merger.Segment<K, V>>, int, Path, RawComparator<K>, Progressable, boolean, Counters.Counter, Counters.Counter, Progress) - Static method in class org.apache.hadoop.mapred.Merger
 
merge(Configuration, FileSystem, Class<K>, Class<V>, CompressionCodec, List<Merger.Segment<K, V>>, int, Path, RawComparator<K>, Progressable, boolean, Counters.Counter, Counters.Counter, Progress, TaskType) - Static method in class org.apache.hadoop.mapred.Merger
 
merge(Configuration, FileSystem, Class<K>, Class<V>, List<Merger.Segment<K, V>>, int, int, Path, RawComparator<K>, Progressable, boolean, Counters.Counter, Counters.Counter, Progress) - Static method in class org.apache.hadoop.mapred.Merger
 
merge(Configuration, FileSystem, Class<K>, Class<V>, CompressionCodec, List<Merger.Segment<K, V>>, int, int, Path, RawComparator<K>, Progressable, boolean, Counters.Counter, Counters.Counter, Progress) - Static method in class org.apache.hadoop.mapred.Merger
 
MERGED_OUTPUT_PREFIX - Static variable in class org.apache.hadoop.mapred.Task
 
mergedMapOutputsCounter - Variable in class org.apache.hadoop.mapred.Task
 
MergeManager<K,V> - Interface in org.apache.hadoop.mapreduce.task.reduce
An interface for a reduce side merge that works with the default Shuffle implementation.
MergeManagerImpl<K,V> - Class in org.apache.hadoop.mapreduce.task.reduce
 
MergeManagerImpl(TaskAttemptID, JobConf, FileSystem, LocalDirAllocator, Reporter, CompressionCodec, Class<? extends Reducer>, Task.CombineOutputCollector<K, V>, Counters.Counter, Counters.Counter, Counters.Counter, ExceptionReporter, Progress, MapOutputFile) - Constructor for class org.apache.hadoop.mapreduce.task.reduce.MergeManagerImpl
 
Merger - Class in org.apache.hadoop.mapred
Merger is an utility class used by the Map and Reduce tasks for merging both their memory and disk segments
Merger() - Constructor for class org.apache.hadoop.mapred.Merger
 
Merger.Segment<K,V> - Class in org.apache.hadoop.mapred
 
Merger.Segment(Configuration, FileSystem, Path, CompressionCodec, boolean) - Constructor for class org.apache.hadoop.mapred.Merger.Segment
 
Merger.Segment(Configuration, FileSystem, Path, CompressionCodec, boolean, Counters.Counter) - Constructor for class org.apache.hadoop.mapred.Merger.Segment
 
Merger.Segment(Configuration, FileSystem, Path, CompressionCodec, boolean, Counters.Counter, long) - Constructor for class org.apache.hadoop.mapred.Merger.Segment
 
Merger.Segment(Configuration, FileSystem, Path, long, long, CompressionCodec, boolean) - Constructor for class org.apache.hadoop.mapred.Merger.Segment
 
Merger.Segment(Configuration, FileSystem, Path, long, long, CompressionCodec, boolean, Counters.Counter) - Constructor for class org.apache.hadoop.mapred.Merger.Segment
 
Merger.Segment(IFile.Reader<K, V>, boolean) - Constructor for class org.apache.hadoop.mapred.Merger.Segment
 
Merger.Segment(IFile.Reader<K, V>, boolean, long) - Constructor for class org.apache.hadoop.mapred.Merger.Segment
 
Merger.Segment(IFile.Reader<K, V>, boolean, Counters.Counter) - Constructor for class org.apache.hadoop.mapred.Merger.Segment
 
monitorAndPrintJob(JobConf, RunningJob) - Method in class org.apache.hadoop.mapred.JobClient
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.
MR_ACLS_ENABLED - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
MR_ADMINS - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
MR_AM_ADMIN_COMMAND_OPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Admin command opts passed to the MR app master.
MR_AM_ADMIN_USER_ENV - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_AM_COMMAND_OPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Command line arguments passed to the MR app master.
MR_AM_COMMIT_WINDOW_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Defines a time window in milliseconds for output committer operations.
MR_AM_COMMITTER_CANCEL_TIMEOUT_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
How long to wait in milliseconds for the output committer to cancel an operation when the job is being killed
MR_AM_CONTAINERLAUNCHER_THREAD_COUNT_LIMIT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Upper limit on the number of threads user to launch containers in the app master.
MR_AM_CPU_VCORES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
The number of virtual cores the MR app master needs.
MR_AM_CREATE_JH_INTERMEDIATE_BASE_DIR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Boolean.
MR_AM_ENV - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_AM_HISTORY_COMPLETE_EVENT_FLUSH_TIMEOUT_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_AM_HISTORY_JOB_COMPLETE_UNFLUSHED_MULTIPLIER - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_AM_HISTORY_MAX_UNFLUSHED_COMPLETE_EVENTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_AM_HISTORY_USE_BATCHED_FLUSH_QUEUE_SIZE_THRESHOLD - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_AM_IGNORE_BLACKLISTING_BLACKLISTED_NODE_PERECENT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Ignore blacklisting if a certain percentage of nodes have been blacklisted
MR_AM_JOB_CLIENT_PORT_RANGE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Range of ports that the MapReduce AM can use when binding.
MR_AM_JOB_CLIENT_THREAD_COUNT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Number of threads to handle job client RPC requests.
MR_AM_JOB_NODE_BLACKLISTING_ENABLE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Enable blacklisting of nodes in the job.
MR_AM_JOB_RECOVERY_ENABLE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Enable job recovery.
MR_AM_JOB_RECOVERY_ENABLE_DEFAULT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_AM_JOB_REDUCE_PREEMPTION_LIMIT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Limit on the number of reducers that can be preempted to ensure that at least one map task can run if it needs to.
MR_AM_JOB_REDUCE_RAMPUP_UP_LIMIT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Limit reduces starting until a certain percentage of maps have finished.
MR_AM_JOB_SPECULATOR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
The class that should be used for speculative execution calculations.
MR_AM_LOG_BACKUPS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_AM_LOG_KB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_AM_LOG_LEVEL - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Root Logging level passed to the MR app master.
MR_AM_MAX_ATTEMPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
The maximum number of application attempts.
MR_AM_NUM_PROGRESS_SPLITS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
The number of splits when reporting progress in MR
MR_AM_PREFIX - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_AM_SECURITY_SERVICE_AUTHORIZATION_CLIENT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_AM_SECURITY_SERVICE_AUTHORIZATION_TASK_UMBILICAL - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_AM_STAGING_DIR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
The staging directory for map reduce.
MR_AM_TASK_ESTIMATOR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Class used to estimate task resource needs.
MR_AM_TASK_ESTIMATOR_EXPONENTIAL_RATE_ENABLE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
true if the smoothing rate should be exponential.
MR_AM_TASK_ESTIMATOR_SMOOTH_LAMBDA_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
The lambda value in the smoothing function of the task estimator.
MR_AM_TASK_LISTENER_THREAD_COUNT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
The number of threads used to handle task RPC calls.
MR_AM_TO_RM_HEARTBEAT_INTERVAL_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
How often the AM should send heartbeats to the RM.
MR_AM_TO_RM_WAIT_INTERVAL_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
If contact with RM is lost, the AM will wait MR_AM_TO_RM_WAIT_INTERVAL_MS milliseconds before aborting.
MR_AM_VMEM_MB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
The amount of memory the MR app master needs.
MR_APPLICATION_TYPE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_CLIENT_MAX_RETRIES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
The number of client retries to the RM/HS before throwing exception.
MR_CLIENT_TO_AM_IPC_MAX_RETRIES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
The number of client retries to the AM - before reconnecting to the RM to fetch Application State.
MR_CLIENT_TO_AM_IPC_MAX_RETRIES_ON_TIMEOUTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
The number of client retries on socket timeouts to the AM - before reconnecting to the RM to fetch Application Status.
MR_JOB_END_NOTIFICATION_MAX_ATTEMPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_JOB_END_NOTIFICATION_MAX_RETRY_INTERVAL - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_JOB_END_NOTIFICATION_PROXY - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_JOB_END_NOTIFICATION_TIMEOUT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_JOB_END_NOTIFICATION_URL - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Job end notification.
MR_JOB_END_RETRY_ATTEMPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_JOB_END_RETRY_INTERVAL - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_PREFIX - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
MR_SUPERGROUP - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
Deprecated. 
MRConfig - Interface in org.apache.hadoop.mapreduce
Place holder for cluster level configuration keys.
MRConstants - Interface in org.apache.hadoop.mapred
Some handy constants
MRJobConfig - Interface in org.apache.hadoop.mapreduce
 
MROutputFiles - Class in org.apache.hadoop.mapred
Manipulate the working area for the transient store for maps and reduces.
MROutputFiles() - Constructor for class org.apache.hadoop.mapred.MROutputFiles
 
MultiFileInputFormat<K,V> - Class in org.apache.hadoop.mapred
An abstract InputFormat that returns MultiFileSplit's in MultiFileInputFormat.getSplits(JobConf, int) method.
MultiFileInputFormat() - Constructor for class org.apache.hadoop.mapred.MultiFileInputFormat
 
MultiFileSplit - Class in org.apache.hadoop.mapred
A sub-collection of input files.
MultiFileSplit(JobConf, Path[], long[]) - Constructor for class org.apache.hadoop.mapred.MultiFileSplit
 
MultiFilterRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.join
Base class for Composite join returning values derived from multiple sources, but generally not tuples.
MultiFilterRecordReader(int, JobConf, int, Class<? extends WritableComparator>) - Constructor for class org.apache.hadoop.mapred.join.MultiFilterRecordReader
 
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
Proxy the JoinCollector, but include callback to emit.
MultiFilterRecordReader.MultiFilterDelegationIterator() - Constructor for class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
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
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.mapred.lib.MultipleInputs
 
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
This abstract class extends the FileOutputFormat, allowing to write the output data to different output files.
MultipleOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.MultipleOutputFormat
 
MultipleOutputs - Class in org.apache.hadoop.mapred.lib
The MultipleOutputs class simplifies writting to additional outputs other than the job default output via the OutputCollector passed to the map() and reduce() methods of the Mapper and Reducer implementations.
MultipleOutputs(JobConf) - Constructor for class org.apache.hadoop.mapred.lib.MultipleOutputs
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
This class extends the MultipleOutputFormat, allowing to write the output data to different output files in sequence file output format.
MultipleSequenceFileOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.MultipleSequenceFileOutputFormat
 
MultipleTextOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
This class extends the MultipleOutputFormat, allowing to write the output data to different output files in Text output format.
MultipleTextOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.MultipleTextOutputFormat
 
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
Multithreaded implementation for @link org.apache.hadoop.mapred.MapRunnable.
MultithreadedMapRunner() - Constructor for class org.apache.hadoop.mapred.lib.MultithreadedMapRunner
 
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

name - Variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Deprecated. 
name - Variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Deprecated. 
name - Variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
Deprecated. 
NATURAL_ORDER - Static variable in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
needAdditionalRecordAfterSplit() - Method in class org.apache.hadoop.mapreduce.lib.input.CompressedSplitLineReader
 
needAdditionalRecordAfterSplit() - Method in class org.apache.hadoop.mapreduce.lib.input.SplitLineReader
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Check whether task needs a commit.
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
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, Path) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
Check whether task needs a commit.
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Creates a new AMStarted RecordBuilder
newBuilder(AMStarted.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Creates a new AMStarted RecordBuilder by copying an existing Builder
newBuilder(AMStarted) - Static method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Creates a new AMStarted RecordBuilder by copying an existing AMStarted instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.Event
Creates a new Event RecordBuilder
newBuilder(Event.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.Event
Creates a new Event RecordBuilder by copying an existing Builder
newBuilder(Event) - Static method in class org.apache.hadoop.mapreduce.jobhistory.Event
Creates a new Event RecordBuilder by copying an existing Event instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Creates a new JhCounter RecordBuilder
newBuilder(JhCounter.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Creates a new JhCounter RecordBuilder by copying an existing Builder
newBuilder(JhCounter) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Creates a new JhCounter RecordBuilder by copying an existing JhCounter instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Creates a new JhCounterGroup RecordBuilder
newBuilder(JhCounterGroup.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Creates a new JhCounterGroup RecordBuilder by copying an existing Builder
newBuilder(JhCounterGroup) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Creates a new JhCounterGroup RecordBuilder by copying an existing JhCounterGroup instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
Creates a new JhCounters RecordBuilder
newBuilder(JhCounters.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
Creates a new JhCounters RecordBuilder by copying an existing Builder
newBuilder(JhCounters) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
Creates a new JhCounters RecordBuilder by copying an existing JhCounters instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Creates a new JobFinished RecordBuilder
newBuilder(JobFinished.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Creates a new JobFinished RecordBuilder by copying an existing Builder
newBuilder(JobFinished) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Creates a new JobFinished RecordBuilder by copying an existing JobFinished instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Creates a new JobInfoChange RecordBuilder
newBuilder(JobInfoChange.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Creates a new JobInfoChange RecordBuilder by copying an existing Builder
newBuilder(JobInfoChange) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Creates a new JobInfoChange RecordBuilder by copying an existing JobInfoChange instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Creates a new JobInited RecordBuilder
newBuilder(JobInited.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Creates a new JobInited RecordBuilder by copying an existing Builder
newBuilder(JobInited) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Creates a new JobInited RecordBuilder by copying an existing JobInited instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
Creates a new JobPriorityChange RecordBuilder
newBuilder(JobPriorityChange.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
Creates a new JobPriorityChange RecordBuilder by copying an existing Builder
newBuilder(JobPriorityChange) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
Creates a new JobPriorityChange RecordBuilder by copying an existing JobPriorityChange instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
Creates a new JobQueueChange RecordBuilder
newBuilder(JobQueueChange.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
Creates a new JobQueueChange RecordBuilder by copying an existing Builder
newBuilder(JobQueueChange) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
Creates a new JobQueueChange RecordBuilder by copying an existing JobQueueChange instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
Creates a new JobStatusChanged RecordBuilder
newBuilder(JobStatusChanged.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
Creates a new JobStatusChanged RecordBuilder by copying an existing Builder
newBuilder(JobStatusChanged) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
Creates a new JobStatusChanged RecordBuilder by copying an existing JobStatusChanged instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Creates a new JobSubmitted RecordBuilder
newBuilder(JobSubmitted.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Creates a new JobSubmitted RecordBuilder by copying an existing Builder
newBuilder(JobSubmitted) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Creates a new JobSubmitted RecordBuilder by copying an existing JobSubmitted instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Creates a new JobUnsuccessfulCompletion RecordBuilder
newBuilder(JobUnsuccessfulCompletion.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Creates a new JobUnsuccessfulCompletion RecordBuilder by copying an existing Builder
newBuilder(JobUnsuccessfulCompletion) - Static method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Creates a new JobUnsuccessfulCompletion RecordBuilder by copying an existing JobUnsuccessfulCompletion instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Creates a new MapAttemptFinished RecordBuilder
newBuilder(MapAttemptFinished.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Creates a new MapAttemptFinished RecordBuilder by copying an existing Builder
newBuilder(MapAttemptFinished) - Static method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Creates a new MapAttemptFinished RecordBuilder by copying an existing MapAttemptFinished instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Creates a new ReduceAttemptFinished RecordBuilder
newBuilder(ReduceAttemptFinished.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Creates a new ReduceAttemptFinished RecordBuilder by copying an existing Builder
newBuilder(ReduceAttemptFinished) - Static method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Creates a new ReduceAttemptFinished RecordBuilder by copying an existing ReduceAttemptFinished instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Creates a new TaskAttemptFinished RecordBuilder
newBuilder(TaskAttemptFinished.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Creates a new TaskAttemptFinished RecordBuilder by copying an existing Builder
newBuilder(TaskAttemptFinished) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Creates a new TaskAttemptFinished RecordBuilder by copying an existing TaskAttemptFinished instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Creates a new TaskAttemptStarted RecordBuilder
newBuilder(TaskAttemptStarted.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Creates a new TaskAttemptStarted RecordBuilder by copying an existing Builder
newBuilder(TaskAttemptStarted) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Creates a new TaskAttemptStarted RecordBuilder by copying an existing TaskAttemptStarted instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Creates a new TaskAttemptUnsuccessfulCompletion RecordBuilder
newBuilder(TaskAttemptUnsuccessfulCompletion.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Creates a new TaskAttemptUnsuccessfulCompletion RecordBuilder by copying an existing Builder
newBuilder(TaskAttemptUnsuccessfulCompletion) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Creates a new TaskAttemptUnsuccessfulCompletion RecordBuilder by copying an existing TaskAttemptUnsuccessfulCompletion instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Creates a new TaskFailed RecordBuilder
newBuilder(TaskFailed.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Creates a new TaskFailed RecordBuilder by copying an existing Builder
newBuilder(TaskFailed) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Creates a new TaskFailed RecordBuilder by copying an existing TaskFailed instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Creates a new TaskFinished RecordBuilder
newBuilder(TaskFinished.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Creates a new TaskFinished RecordBuilder by copying an existing Builder
newBuilder(TaskFinished) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Creates a new TaskFinished RecordBuilder by copying an existing TaskFinished instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Creates a new TaskStarted RecordBuilder
newBuilder(TaskStarted.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Creates a new TaskStarted RecordBuilder by copying an existing Builder
newBuilder(TaskStarted) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Creates a new TaskStarted RecordBuilder by copying an existing TaskStarted instance
newBuilder() - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
Creates a new TaskUpdated RecordBuilder
newBuilder(TaskUpdated.Builder) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
Creates a new TaskUpdated RecordBuilder by copying an existing Builder
newBuilder(TaskUpdated) - Static method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
Creates a new TaskUpdated RecordBuilder by copying an existing TaskUpdated instance
newCounter(String, String, long) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
Abstract factory method to create a new counter of type T
newCounter() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
Abstract factory method to create a new counter of type T
newCounter(String, FileSystemCounter) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
Abstract factory method to create a file system counter
newCounter(T) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
Abstract factory method for new framework counter
newFileSystemGroup() - Method in class org.apache.hadoop.mapreduce.counters.CounterGroupFactory
Abstract factory method to create a file system counter group
newFrameworkGroup(int) - Method in class org.apache.hadoop.mapreduce.counters.CounterGroupFactory
Create a new framework group
newFrameworkGroupFactory(Class<T>) - Method in class org.apache.hadoop.mapreduce.counters.CounterGroupFactory
Required override to return a new framework group factory
newGenericGroup(String, String, Limits) - Method in class org.apache.hadoop.mapreduce.counters.CounterGroupFactory
Abstract factory method to create a generic (vs framework) counter group
newGroup(String) - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupFactory.FrameworkGroupFactory
 
newGroup(String, Limits) - Method in class org.apache.hadoop.mapreduce.counters.CounterGroupFactory
Create a new counter group
newGroup(String, String, Limits) - Method in class org.apache.hadoop.mapreduce.counters.CounterGroupFactory
Create a new counter group
next() - Method in class org.apache.hadoop.mapred.BackupStore
 
next(LongWritable, BytesWritable) - Method in class org.apache.hadoop.mapred.FixedLengthRecordReader
 
next(TupleWritable) - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
 
next(K, TupleWritable) - Method in class org.apache.hadoop.mapred.join.JoinRecordReader
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
 
next(K, V) - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader
Reads the next key/value pair from the input for processing.
next() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
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
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
Read key/value pair in a line.
next(K, V) - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
next(K, V) - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
next(LongWritable, T) - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat.DBRecordReader
Reads the next key/value pair from the input for processing.
next(LongWritable, Text) - Method in class org.apache.hadoop.mapred.LineRecordReader
Read a line.
next() - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.MRResultIterator
 
next() - Method in interface org.apache.hadoop.mapred.RawKeyValueIterator
Sets up the current key and value (for getKey and getValue).
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
Read raw bytes from a SequenceFile.
next(Text, Text) - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
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() - Method in class org.apache.hadoop.mapred.Task.CombineValuesIterator
 
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
 
nextKey() - Method in class org.apache.hadoop.mapred.BackupStore
 
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.
nextKey() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl
Start processing next unique key.
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.CombineFileRecordReaderWrapper
 
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.input.DelegatingRecordReader
 
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthRecordReader
 
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.LineRecordReader
 
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 class org.apache.hadoop.mapreduce.task.MapContextImpl
 
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl
Advance to the next key/value pair.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.task.TaskInputOutputContextImpl
Advance to the next key, value pair, returning null if at end.
nextKeyValue() - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Advance to the next key, value pair, returning null if at end.
nextRawKey(DataInputBuffer) - Method in class org.apache.hadoop.mapred.IFile.Reader
 
nextRawKey(DataInputBuffer) - Method in class org.apache.hadoop.mapreduce.task.reduce.InMemoryReader
 
nextRawValue(DataInputBuffer) - Method in class org.apache.hadoop.mapred.IFile.Reader
 
nextRawValue(DataInputBuffer) - Method in class org.apache.hadoop.mapreduce.task.reduce.InMemoryReader
 
nextValue() - Method in class org.apache.hadoop.mapred.BackupStore
 
NLineInputFormat - Class in org.apache.hadoop.mapred.lib
NLineInputFormat which splits N lines of input as one split.
NLineInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.NLineInputFormat
 
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
 
nodeManagerHost - Variable in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Deprecated. 
nodeManagerHttpPort - Variable in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Deprecated. 
nodeManagerPort - Variable in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Deprecated. 
NormalizedResourceEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record the normalized map/reduce requirements.
NormalizedResourceEvent(TaskType, int) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.NormalizedResourceEvent
Normalized request when sent to the Resource Manager.
normalizeMemoryConfigValue(long) - Static method in class org.apache.hadoop.mapred.JobConf
Normalize the negative values in configuration
normalizeStatus(String, Configuration) - Static method in class org.apache.hadoop.mapred.Task
 
NULL - Static variable in interface org.apache.hadoop.mapred.Reporter
A constant of Reporter type that does nothing.
NULL_PROGRESS_SPLITS_ARRAY - Static variable in class org.apache.hadoop.mapreduce.jobhistory.AvroArrayUtils
 
NullOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
Consume all outputs and put them in /dev/null.
NullOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.NullOutputFormat
 
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
 
NUM_INPUT_FILES - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
NUM_MAP_PROFILES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
NUM_MAPS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
NUM_REDUCE_PROFILES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
NUM_REDUCES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
NUM_THREADS - Static variable in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
 
numSamples - Variable in class org.apache.hadoop.mapreduce.lib.partition.InputSampler.RandomSampler
 
numSamples - Variable in class org.apache.hadoop.mapreduce.lib.partition.InputSampler.SplitSampler
 

O

obsoleteMapOutput(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
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
 
ONE - Static variable in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorDescriptor
 
Operation - Enum in org.apache.hadoop.mapred
Generic operation that maps to the dependent set of ACLs that drive the authorization of the operation.
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.filecache - package org.apache.hadoop.filecache
 
org.apache.hadoop.mapred - package org.apache.hadoop.mapred
 
org.apache.hadoop.mapred.jobcontrol - package org.apache.hadoop.mapred.jobcontrol
 
org.apache.hadoop.mapred.join - package org.apache.hadoop.mapred.join
 
org.apache.hadoop.mapred.lib - package org.apache.hadoop.mapred.lib
 
org.apache.hadoop.mapred.lib.aggregate - package org.apache.hadoop.mapred.lib.aggregate
 
org.apache.hadoop.mapred.lib.db - package org.apache.hadoop.mapred.lib.db
 
org.apache.hadoop.mapred.pipes - package org.apache.hadoop.mapred.pipes
 
org.apache.hadoop.mapreduce - package org.apache.hadoop.mapreduce
 
org.apache.hadoop.mapreduce.counters - package org.apache.hadoop.mapreduce.counters
This package contains the implementations of different types of map-reduce counters.
org.apache.hadoop.mapreduce.filecache - package org.apache.hadoop.mapreduce.filecache
 
org.apache.hadoop.mapreduce.jobhistory - package org.apache.hadoop.mapreduce.jobhistory
 
org.apache.hadoop.mapreduce.lib.aggregate - package org.apache.hadoop.mapreduce.lib.aggregate
 
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.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
 
org.apache.hadoop.mapreduce.lib.join - package org.apache.hadoop.mapreduce.lib.join
 
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.protocol - package org.apache.hadoop.mapreduce.protocol
 
org.apache.hadoop.mapreduce.security - package org.apache.hadoop.mapreduce.security
 
org.apache.hadoop.mapreduce.security.token - package org.apache.hadoop.mapreduce.security.token
 
org.apache.hadoop.mapreduce.security.token.delegation - package org.apache.hadoop.mapreduce.security.token.delegation
 
org.apache.hadoop.mapreduce.server.jobtracker - package org.apache.hadoop.mapreduce.server.jobtracker
 
org.apache.hadoop.mapreduce.server.tasktracker - package org.apache.hadoop.mapreduce.server.tasktracker
 
org.apache.hadoop.mapreduce.split - package org.apache.hadoop.mapreduce.split
 
org.apache.hadoop.mapreduce.task - package org.apache.hadoop.mapreduce.task
 
org.apache.hadoop.mapreduce.task.annotation - package org.apache.hadoop.mapreduce.task.annotation
 
org.apache.hadoop.mapreduce.task.reduce - package org.apache.hadoop.mapreduce.task.reduce
 
org.apache.hadoop.mapreduce.tools - package org.apache.hadoop.mapreduce.tools
 
org.apache.hadoop.mapreduce.util - package org.apache.hadoop.mapreduce.util
 
org.apache.hadoop.mapreduce.v2 - package org.apache.hadoop.mapreduce.v2
 
out - Variable in class org.apache.hadoop.mapred.TextOutputFormat.LineRecordWriter
 
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
Full outer join.
OuterJoinRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>> - Class in org.apache.hadoop.mapreduce.lib.join
Full outer join.
OUTPUT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
OUTPUT_FIELD_COUNT_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
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
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_FORMAT_CLASS_ATTR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
OUTPUT_KEY_CLASS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
OUTPUT_TABLE_NAME_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Output table name
OUTPUT_TABLE_NAME_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Output table name
OUTPUT_VALUE_CLASS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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
OutputCommitter describes the commit of task output for a Map-Reduce job.
OutputCommitter() - Constructor for class org.apache.hadoop.mapred.OutputCommitter
 
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
OutputFormat describes the output-specification for a Map-Reduce job.
outputFormat - Variable in class org.apache.hadoop.mapred.Task
 
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
 
OutputLogFilter - Class in org.apache.hadoop.mapred
This class filters log files from directory given It doesnt accept paths having _logs.
OutputLogFilter() - Constructor for class org.apache.hadoop.mapred.OutputLogFilter
 
OverrideRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.join
Prefer the "rightmost" data source for this key.
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

parse(HistoryEventHandler) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser
 
parse(EventReader, HistoryEventHandler) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser
Only used for unit tests.
parse() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser
Parse the entire history file and populate the JobInfo object The first invocation will populate the object, subsequent calls will return the already parsed object.
parse(EventReader) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser
Only used for unit tests.
parseEscapedCompactString(String, T) - Static method in class org.apache.hadoop.mapreduce.util.CountersStrings
Parse a pre 0.21 counters string into a counter object.
parseOutputKeyValueSpec(String, List<Integer>, List<Integer>) - Static method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
Parser - Class in org.apache.hadoop.mapred.join
Very simple shift-reduce parser for join expressions.
Parser() - Constructor for class org.apache.hadoop.mapred.join.Parser
 
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
 
Parser.Node(String) - Constructor for class org.apache.hadoop.mapred.join.Parser.Node
 
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
 
Parser.NodeToken - Class in org.apache.hadoop.mapreduce.lib.join
 
Parser.NumToken - Class in org.apache.hadoop.mapred.join
 
Parser.NumToken(double) - Constructor for class org.apache.hadoop.mapred.join.Parser.NumToken
 
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
 
Parser.StrToken(Parser.TType, String) - Constructor for class org.apache.hadoop.mapred.join.Parser.StrToken
 
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
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
 
Parser.TType - Enum in org.apache.hadoop.mapreduce.lib.join
 
PART - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
PartialFileOutputCommitter - Class in org.apache.hadoop.mapreduce.lib.output
An OutputCommitter that commits files specified in job output directory i.e.
PartialFileOutputCommitter(Path, TaskAttemptContext) - Constructor for class org.apache.hadoop.mapreduce.lib.output.PartialFileOutputCommitter
 
PartialFileOutputCommitter(Path, JobContext) - Constructor for class org.apache.hadoop.mapreduce.lib.output.PartialFileOutputCommitter
 
PartialOutputCommitter - Interface in org.apache.hadoop.mapreduce.lib.output
Interface for an OutputCommitter implementing partial commit of task output, as during preemption.
Partitioner<K2,V2> - Interface in org.apache.hadoop.mapred
Partitions the key space.
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_CLASS_ATTR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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
 
partLength - Variable in class org.apache.hadoop.mapred.IndexRecord
 
PASSWORD_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
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
 
penalize() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapHost
Mark the host as penalized
PENDING_DIR_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Name of directory where pending data is placed.
PeriodicStatsAccumulator - Class in org.apache.hadoop.mapred
This abstract class that represents a bucketed series of measurements of a quantity being measured in a running task attempt.
physMemKbytes - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
physMemKbytes - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
physMemKbytes - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
ping(TaskAttemptID) - Method in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Periodically called by child to check if parent is still alive.
PORT - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
port - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
port - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
port - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
positionToNextRecord(DataInput) - Method in class org.apache.hadoop.mapred.IFile.Reader
 
PREP - Static variable in class org.apache.hadoop.mapred.JobStatus
 
PRESERVE_COMMANDFILE - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
PRESERVE_FAILED_TASK_FILES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
PRESERVE_FILES_PATTERN - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
print() - Method in class org.apache.hadoop.mapreduce.jobhistory.HistoryViewer
Print the job/task/attempt summary information
printAll() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.AMInfo
Print all the information about this AM.
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
 
priority - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
Deprecated. 
PRIORITY - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
PRIVATE_ACTIONS_KEY - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
ProcessTree - Class in org.apache.hadoop.mapreduce.util
Process tree related operations
ProcessTree() - Constructor for class org.apache.hadoop.mapreduce.util.ProcessTree
 
progress - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
progress() - Method in class org.apache.hadoop.mapred.Task.TaskReporter
 
progress() - Method in class org.apache.hadoop.mapred.TaskAttemptContextImpl
Report progress.
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.StatusReporter
 
progress() - Method in class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl.DummyReporter
 
progress() - Method in class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl
Report progress.
PROGRESS_INTERVAL - Static variable in class org.apache.hadoop.mapred.Task
The number of milliseconds between progress reports.
PROGRESS_MONITOR_POLL_INTERVAL_KEY - Static variable in class org.apache.hadoop.mapreduce.Job
Key in mapred-*.xml that sets progMonitorPollIntervalMillis
PROGRESS_STATUS_LEN_LIMIT_DEFAULT - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
PROGRESS_STATUS_LEN_LIMIT_KEY - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
ProgressSplitsBlock - Class in org.apache.hadoop.mapred
 
PROTOCOL - Static variable in interface org.apache.hadoop.mapreduce.jobhistory.Events.Callback
 
PROTOCOL - Static variable in interface org.apache.hadoop.mapreduce.jobhistory.Events
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.Event
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
 
put(int, Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
 
putBackKnownMapOutput(MapHost, TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
putIndex(IndexRecord, int) - Method in class org.apache.hadoop.mapred.SpillRecord
Set spill offsets for given partition.

Q

qACLNeeded - Variable in enum org.apache.hadoop.mapred.Operation
 
QUEUE_CONF_FILE_NAME - Static variable in class org.apache.hadoop.mapred.QueueManager
 
QUEUE_NAME - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
QueueACL - Enum in org.apache.hadoop.mapred
Enum representing an AccessControlList that drives set of operations that can be performed on a queue.
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
 
QueueManager - Class in org.apache.hadoop.mapred
Class that exposes information about queues maintained by the Hadoop Map/Reduce framework.
QueueManager(Configuration) - Constructor for class org.apache.hadoop.mapred.QueueManager
Construct a new QueueManager using configuration specified in the passed in Configuration object.
QueueState - Enum in org.apache.hadoop.mapreduce
Enum representing queue state

R

rackname - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
rackname - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
rackname - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Deprecated. 
rackname - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
RAW_MAP_OUTPUT_LENGTH - Static variable in interface org.apache.hadoop.mapred.MRConstants
The custom http header used for the "raw" map output length.
RawKeyValueIterator - Interface in org.apache.hadoop.mapred
RawKeyValueIterator is an iterator used to iterate over the raw keys and values during sort/merge of intermediate data.
rawLength - Variable in class org.apache.hadoop.mapred.IndexRecord
 
rawWriter - Variable in class org.apache.hadoop.mapred.lib.FilterOutputFormat.FilterRecordWriter
 
rawWriter - Variable in class org.apache.hadoop.mapreduce.lib.output.FilterOutputFormat.FilterRecordWriter
 
read(byte[], int, int) - Method in class org.apache.hadoop.mapred.IFileInputStream
Read bytes from the stream.
read() - Method in class org.apache.hadoop.mapred.IFileInputStream
 
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
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.ClusterStatus.BlackListInfo
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.ClusterStatus
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.Counters.Counter
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.Counters.Group
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.FileSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.JobProfile
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
readFields(DataInput) - Method in class org.apache.hadoop.mapred.JvmTask
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.MapTask
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.MapTaskCompletionEventsUpdate
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.ReduceTask
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.Task
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.TaskStatus
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup.FSCounter
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup.FrameworkCounter
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.counters.GenericCounter
 
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.security.token.JobTokenIdentifier
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.task.reduce.ShuffleHeader
 
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.TaskReport
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
 
readLine(Text, int, int) - Method in class org.apache.hadoop.mapreduce.lib.input.CompressedSplitLineReader
 
readSplitMetaInfo(JobID, FileSystem, Configuration, Path) - Static method in class org.apache.hadoop.mapreduce.split.SplitMetaInfoReader
 
readWithChecksum(byte[], int, int) - Method in class org.apache.hadoop.mapred.IFileInputStream
Read bytes from the stream.
READY - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
 
recNo - Variable in class org.apache.hadoop.mapred.IFile.Reader
 
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
 
RECORDS_BEFORE_PROGRESS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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
 
recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Recover the task output.
recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
This method implements the new interface by calling the old method.
recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
 
recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
Recover the task output.
reduce(Text, Iterator<Text>, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Combines values for a given key.
reduce(Text, Iterator<Text>, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorMapper
Do nothing.
reduce(Text, Iterator<Text>, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorReducer
 
reduce(Object, Iterator, OutputCollector, Reporter) - Method in class org.apache.hadoop.mapred.lib.ChainReducer
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
 
reduce(K, Iterator<V>, OutputCollector<K, V>, Reporter) - Method in class org.apache.hadoop.mapred.lib.IdentityReducer
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
 
reduce(K2, Iterator<V2>, OutputCollector<K3, V3>, Reporter) - Method in interface org.apache.hadoop.mapred.Reducer
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_CLASS_ATTR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_CPU_VCORES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_DEBUG_SCRIPT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_ENV - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_FAILURES_MAXPERCENT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_INPUT_BUFFER_PERCENT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_JAVA_OPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_LOG_LEVEL - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_MARKRESET_BUFFER_PERCENT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_MARKRESET_BUFFER_SIZE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_MAX_ATTEMPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_MEMORY_MB - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_MEMORY_TOTAL_BYTES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_MEMTOMEM_ENABLED - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_MEMTOMEM_THRESHOLD - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_MERGE_INMEM_THRESHOLD - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_OUTPUT_KEY_VALUE_SPEC - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
REDUCE_SKIP_INCR_PROC_COUNT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_SKIP_MAXGROUPS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
REDUCE_SPECULATIVE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
ReduceAttemptFinished - Class in org.apache.hadoop.mapreduce.jobhistory
 
ReduceAttemptFinished() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Default constructor.
ReduceAttemptFinished(CharSequence, CharSequence, CharSequence, CharSequence, Long, Long, Long, CharSequence, Integer, CharSequence, CharSequence, JhCounters, List<Integer>, List<Integer>, List<Integer>, List<Integer>) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
All-args constructor.
ReduceAttemptFinished.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for ReduceAttemptFinished instances.
ReduceAttemptFinishedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record successful completion of a reduce attempt
ReduceAttemptFinishedEvent(TaskAttemptID, TaskType, String, long, long, long, String, int, String, String, Counters, int[][]) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Create an event to record completion of a reduce attempt
ReduceAttemptFinishedEvent(TaskAttemptID, TaskType, String, long, long, long, String, String, Counters) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Deprecated. please use the constructor with an additional argument, an array of splits arrays instead. See ProgressSplitsBlock for an explanation of the meaning of that parameter. Create an event to record completion of a reduce attempt
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<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce.task
The context passed to the Reducer.
ReduceContextImpl(Configuration, TaskAttemptID, RawKeyValueIterator, Counter, Counter, RecordWriter<KEYOUT, VALUEOUT>, OutputCommitter, StatusReporter, RawComparator<KEYIN>, Class<KEYIN>, Class<VALUEIN>) - Constructor for class org.apache.hadoop.mapreduce.task.ReduceContextImpl
 
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
 
reduceCounters - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Deprecated. 
REDUCEMEMORY_MB - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
reduceProgress() - Method in class org.apache.hadoop.mapred.JobStatus
 
reduceProgress() - Method in interface org.apache.hadoop.mapred.RunningJob
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
Reduces a set of intermediate values which share a key to a smaller set of values.
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
 
REDUCER_INPUT_KEY_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
REDUCER_INPUT_VALUE_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
REDUCER_OUTPUT_KEY_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
REDUCER_OUTPUT_VALUE_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
ReduceTask - Class in org.apache.hadoop.mapred
A Reduce task.
ReduceTask() - Constructor for class org.apache.hadoop.mapred.ReduceTask
 
ReduceTask(String, TaskAttemptID, int, int, int) - Constructor for class org.apache.hadoop.mapred.ReduceTask
 
RegexMapper<K> - Class in org.apache.hadoop.mapred.lib
A Mapper that extracts text matching a regular expression.
RegexMapper() - Constructor for class org.apache.hadoop.mapred.lib.RegexMapper
 
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
 
reinitialize() - Method in class org.apache.hadoop.mapred.BackupStore
 
remove() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
 
remove() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterator
 
removeAll() - Method in class org.apache.hadoop.mapred.MapOutputFile
Removes all of the files related to a task.
removeAll() - Method in class org.apache.hadoop.mapred.MROutputFiles
Removes all of the files related to a task.
removeTokenForJob(String) - Method in class org.apache.hadoop.mapreduce.security.token.JobTokenSecretManager
Remove the cached job token of a job from cache
renewDelegationToken(Token<DelegationTokenIdentifier>) - Method in class org.apache.hadoop.mapred.JobClient
Deprecated. Use Token.renew(org.apache.hadoop.conf.Configuration) instead
renewDelegationToken(Token<DelegationTokenIdentifier>) - Method in class org.apache.hadoop.mapreduce.Cluster
Deprecated. Use Token.renew(org.apache.hadoop.conf.Configuration) instead
renewDelegationToken(Token<DelegationTokenIdentifier>) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Renew an existing delegation token
replay(TupleWritable) - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
 
replay(V) - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
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
 
reportDiagnosticInfo(TaskAttemptID, String) - Method in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Report error messages back to parent.
reporter - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
Reporter - Interface in org.apache.hadoop.mapred
A facility for Map-Reduce applications to report progress and update counters, status information etc.
reporter - Variable in class org.apache.hadoop.mapred.Task.CombinerRunner
 
reporter - Variable in class org.apache.hadoop.mapreduce.task.ReduceContextImpl
 
reportException(Throwable) - Method in interface org.apache.hadoop.mapreduce.task.reduce.ExceptionReporter
 
reportException(Throwable) - Method in class org.apache.hadoop.mapreduce.task.reduce.Shuffle
 
reportFatalError(TaskAttemptID, Throwable, String) - Method in class org.apache.hadoop.mapred.Task
Report a fatal error to the parent (task) tracker.
reportLocalError(IOException) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
reportNextRecordRange(TaskUmbilicalProtocol, long) - Method in class org.apache.hadoop.mapred.Task
Reports the next executing record range to TaskTracker.
reportNextRecordRange(TaskAttemptID, SortedRanges.Range) - Method in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Report the record range which is going to process next by the Task.
reserve(TaskAttemptID, long, int) - Method in interface org.apache.hadoop.mapreduce.task.reduce.MergeManager
To reserve resources for data to be shuffled.
reserve(TaskAttemptID, long, int) - Method in class org.apache.hadoop.mapreduce.task.reduce.MergeManagerImpl
 
reset() - Method in class org.apache.hadoop.mapred.BackupStore
 
reset(int) - Method in class org.apache.hadoop.mapred.IFile.Reader
 
reset() - Method in class org.apache.hadoop.mapred.join.JoinRecordReader.JoinDelegationIterator
 
reset() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader.MultiFilterDelegationIterator
 
reset(byte[], int, int) - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.InMemValBytes
 
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(int) - Method in class org.apache.hadoop.mapreduce.task.reduce.InMemoryReader
 
reset() - Method in class org.apache.hadoop.mapreduce.task.ReduceContextImpl.ValueIterator
 
ResetableIterator<T extends org.apache.hadoop.io.Writable> - Interface in org.apache.hadoop.mapred.join
This defines an interface to a stateful Iterator that can replay elements added to it directly.
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
 
ResetableIterator.EMPTY() - Constructor for class org.apache.hadoop.mapred.join.ResetableIterator.EMPTY
 
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.
resetKnownMaps() - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
resolve(TaskCompletionEvent) - Method in interface org.apache.hadoop.mapreduce.task.reduce.ShuffleScheduler
Interpret a TaskCompletionEvent from the event stream.
resolve(TaskCompletionEvent) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
RESOURCE_CALCULATOR_PROCESS_TREE - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
ResourceBundles - Class in org.apache.hadoop.mapreduce.util
Helper class to handle resource bundles in a saner way
ResourceBundles() - Constructor for class org.apache.hadoop.mapreduce.util.ResourceBundles
 
resume() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
resume the suspended thread
retrievePassword(JobTokenIdentifier) - Method in class org.apache.hadoop.mapreduce.security.token.JobTokenSecretManager
Look up the token password/secret for the given job token identifier.
retrieveTokenSecret(String) - Method in class org.apache.hadoop.mapreduce.security.token.JobTokenSecretManager
Look up the token password/secret for the given jobId.
RIGHT_OFFSET_PROPERTY_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
 
rrClass - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
rrClass - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
rrConstructor - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
rrConstructor - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
rrCstrMap - Static variable in class org.apache.hadoop.mapred.join.Parser.Node
 
rrCstrMap - Static variable in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
run(RecordReader<K1, V1>, OutputCollector<K2, V2>, Reporter) - Method in class org.apache.hadoop.mapred.lib.MultithreadedMapRunner
 
run(RecordReader<K1, V1>, OutputCollector<K2, V2>, Reporter) - Method in interface org.apache.hadoop.mapred.MapRunnable
Start mapping input <key, value> pairs.
run(RecordReader<K1, V1>, OutputCollector<K2, V2>, Reporter) - Method in class org.apache.hadoop.mapred.MapRunner
 
run() - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.SpillThread
 
run(JobConf, TaskUmbilicalProtocol) - Method in class org.apache.hadoop.mapred.MapTask
 
run(String[]) - Method in class org.apache.hadoop.mapred.pipes.Submitter
 
run(JobConf, TaskUmbilicalProtocol) - Method in class org.apache.hadoop.mapred.ReduceTask
 
run() - Method in interface org.apache.hadoop.mapred.ShuffleConsumerPlugin
 
run(JobConf, TaskUmbilicalProtocol) - Method in class org.apache.hadoop.mapred.Task
Run this task as a part of the named job.
run() - Method in class org.apache.hadoop.mapred.Task.TaskReporter
The communication thread handles communication with the parent (Task Tracker).
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(Mapper<K1, V1, K2, V2>.Context) - Method in class org.apache.hadoop.mapreduce.lib.input.DelegatingMapper
 
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() - Method in class org.apache.hadoop.mapreduce.task.reduce.Shuffle
 
run(String[]) - Method in class org.apache.hadoop.mapreduce.tools.CLI
 
runJob(JobConf) - Static method in class org.apache.hadoop.mapred.JobClient
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.
runJobCleanupTask(TaskUmbilicalProtocol, Task.TaskReporter) - Method in class org.apache.hadoop.mapred.Task
 
runJobSetupTask(TaskUmbilicalProtocol, Task.TaskReporter) - Method in class org.apache.hadoop.mapred.Task
 
RUNNING - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
 
RUNNING - Static variable in class org.apache.hadoop.mapred.JobStatus
 
RunningJob - Interface in org.apache.hadoop.mapred
RunningJob is the user-interface to query for details on a running Map-Reduce job.
runTaskCleanupTask(TaskUmbilicalProtocol, Task.TaskReporter) - Method in class org.apache.hadoop.mapred.Task
 

S

SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.Event
 
SCHEMA$ - Static variable in enum org.apache.hadoop.mapreduce.jobhistory.EventType
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.JobInited
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
 
SCHEMA$ - Static variable in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
 
SecureShuffleUtils - Class in org.apache.hadoop.mapreduce.security
utilities for generating kyes, hashes and verifying them for shuffle
SecureShuffleUtils() - Constructor for class org.apache.hadoop.mapreduce.security.SecureShuffleUtils
 
seek(long) - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - Method in class org.apache.hadoop.mapreduce.security.token.JobTokenSelector
 
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
InputFormat reading keys, values from SequenceFiles in binary (raw) format.
SequenceFileAsBinaryInputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat
 
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
Read records from a SequenceFile as binary (raw) bytes.
SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
 
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
An OutputFormat that writes keys, values to SequenceFiles in binary(raw) format
SequenceFileAsBinaryOutputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
 
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
Inner class used for appendRaw
SequenceFileAsBinaryOutputFormat.WritableValueBytes() - Constructor for class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat.WritableValueBytes
 
SequenceFileAsBinaryOutputFormat.WritableValueBytes(BytesWritable) - Constructor for class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat.WritableValueBytes
 
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
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.mapred.SequenceFileAsTextInputFormat
 
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
This class converts the input keys and values to their String forms by calling toString() method.
SequenceFileAsTextRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
 
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
A class that allows a map/red job to work on a sample of sequence files.
SequenceFileInputFilter() - Constructor for class org.apache.hadoop.mapred.SequenceFileInputFilter
 
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
filter interface
SequenceFileInputFilter.Filter - Interface in org.apache.hadoop.mapreduce.lib.input
filter interface
SequenceFileInputFilter.FilterBase - Class in org.apache.hadoop.mapred
base class for Filters
SequenceFileInputFilter.FilterBase() - Constructor for class org.apache.hadoop.mapred.SequenceFileInputFilter.FilterBase
 
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
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
 
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
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
 
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
Records filter by matching key to regex
SequenceFileInputFilter.RegexFilter() - Constructor for class org.apache.hadoop.mapred.SequenceFileInputFilter.RegexFilter
 
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
An InputFormat for SequenceFiles.
SequenceFileInputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileInputFormat
 
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
An OutputFormat that writes SequenceFiles.
SequenceFileOutputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileOutputFormat
 
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
 
SESSION_TIMEZONE_KEY - Static variable in class org.apache.hadoop.mapreduce.lib.db.OracleDBRecordReader
Configuration key to set to a timezone string.
setAcls(Map<CharSequence, CharSequence>) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Sets the value of the 'acls' field
setAcls(Map<CharSequence, CharSequence>) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Sets the value of the 'acls' field.
setAggregatorDescriptors(JobConf, Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
 
setAggregatorDescriptors(Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
 
setApplicationAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Sets the value of the 'applicationAttemptId' field
setApplicationAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Sets the value of the 'applicationAttemptId' field.
setApplicationId(String) - Method in class org.apache.hadoop.mapreduce.v2.LogParams
 
setArchiveTimestamps(Configuration, String) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
setAssignedJobID(JobID) - Method in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated. setAssignedJobID should not be called. JOBID is set by the framework.
setAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'attemptId' field
setAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'attemptId' field.
setAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'attemptId' field
setAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'attemptId' field.
setAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Sets the value of the 'attemptId' field
setAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Sets the value of the 'attemptId' field.
setAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Sets the value of the 'attemptId' field
setAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Sets the value of the 'attemptId' field.
setAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'attemptId' field
setAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'attemptId' field.
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.
setAvataar(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Sets the value of the 'avataar' field
setAvataar(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Sets the value of the 'avataar' field.
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[], Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use Job.setCacheArchives(URI[]) instead
setCacheArchives(URI[]) - Method in class org.apache.hadoop.mapreduce.Job
Set the given set of archives
setCacheFiles(URI[], Configuration) - Static method in class org.apache.hadoop.mapreduce.filecache.DistributedCache
Deprecated. Use Job.setCacheFiles(URI[]) instead
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
 
setCleanupProgress(float) - Method in class org.apache.hadoop.mapred.JobStatus
Sets the cleanup progress of this job
setCleanupProgress(float) - Method in class org.apache.hadoop.mapreduce.JobStatus
Sets the cleanup progress of this job
setClockSplits(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'clockSplits' field
setClockSplits(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'clockSplits' field.
setClockSplits(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'clockSplits' field
setClockSplits(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'clockSplits' field.
setClockSplits(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'clockSplits' field
setClockSplits(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'clockSplits' field.
setCombinerClass(Class<? extends Reducer>) - Method in class org.apache.hadoop.mapred.JobConf
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.
setCombinerKeyGroupingComparator(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapred.JobConf
Set the user defined RawComparator comparator for grouping keys in the input to the combiner.
setCombinerKeyGroupingComparatorClass(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 combiner, Reducer.reduce(Object, Iterable, org.apache.hadoop.mapreduce.Reducer.Context)
setCompressMapOutput(boolean) - Method in class org.apache.hadoop.mapred.JobConf
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.mapred.join.CompositeRecordReader
setConf(Configuration) - Method in class org.apache.hadoop.mapred.MapOutputFile
 
setConf(Configuration) - Method in class org.apache.hadoop.mapred.MROutputFiles
 
setConf(Configuration) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.MD5Filter
configure the filter according to configuration
setConf(Configuration) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.PercentFilter
configure the filter by checking the configuration
setConf(Configuration) - Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.RegexFilter
configure the Filter by checking the configuration
setConf(Configuration) - Method in class org.apache.hadoop.mapred.Task
 
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.
setContainerId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Sets the value of the 'containerId' field
setContainerId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Sets the value of the 'containerId' field.
setContainerId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Sets the value of the 'containerId' field
setContainerId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Sets the value of the 'containerId' field.
setContainerId(String) - Method in class org.apache.hadoop.mapreduce.v2.LogParams
 
setCounters(Counters) - Method in class org.apache.hadoop.mapred.TaskStatus
Set the task's counters.
setCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'counters' field
setCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'counters' field.
setCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'counters' field
setCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'counters' field.
setCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Sets the value of the 'counters' field
setCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Sets the value of the 'counters' field.
setCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'counters' field
setCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'counters' field.
setCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Sets the value of the 'counters' field
setCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Sets the value of the 'counters' field.
setCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Sets the value of the 'counters' field
setCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Sets the value of the 'counters' field.
setCountersEnabled(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
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.
setCounts(List<JhCounter>) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
Sets the value of the 'counts' field
setCounts(List<JhCounter>) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Sets the value of the 'counts' field.
setCpuUsages(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'cpuUsages' field
setCpuUsages(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'cpuUsages' field.
setCpuUsages(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'cpuUsages' field
setCpuUsages(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'cpuUsages' field.
setCpuUsages(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'cpuUsages' field
setCpuUsages(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'cpuUsages' field.
setCredentials(Credentials) - Method in class org.apache.hadoop.mapred.JobConf
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStartedEvent
 
setDatum(Object) - Method in interface org.apache.hadoop.mapreduce.jobhistory.HistoryEvent
Set the Avro datum wrapped by this.
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinishedEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChangeEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInitedEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChangeEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChangeEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChangedEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletionEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.NormalizedResourceEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStartedEvent
 
setDatum(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdatedEvent
 
setDiagnosticInfo(String) - Method in class org.apache.hadoop.mapred.TaskStatus
 
setDiagnostics(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Sets the value of the 'diagnostics' field
setDiagnostics(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Sets the value of the 'diagnostics' field.
setDisplayName(String) - Method in class org.apache.hadoop.mapred.Counters.Counter
 
setDisplayName(String) - Method in class org.apache.hadoop.mapred.Counters.Group
 
setDisplayName(String) - Method in interface org.apache.hadoop.mapreduce.Counter
Deprecated. (and no-op by default)
setDisplayName(String) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounter
Deprecated. 
setDisplayName(String) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
setDisplayName(String) - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
Set the display name of the group
setDisplayName(String) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
setDisplayName(String) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
setDisplayName(String) - Method in class org.apache.hadoop.mapreduce.counters.GenericCounter
Deprecated. 
setDisplayName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
Sets the value of the 'displayName' field
setDisplayName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Sets the value of the 'displayName' field.
setDisplayName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
Sets the value of the 'displayName' field
setDisplayName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Sets the value of the 'displayName' field.
setError(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'error' field
setError(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'error' field.
setError(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Sets the value of the 'error' field
setError(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Sets the value of the 'error' field.
setEvent(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.Event.Builder
Sets the value of the 'event' field
setEvent(Object) - Method in class org.apache.hadoop.mapreduce.jobhistory.Event
Sets the value of the 'event' field.
setEventId(int) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
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.
setFailedDueToAttempt(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Sets the value of the 'failedDueToAttempt' field
setFailedDueToAttempt(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Sets the value of the 'failedDueToAttempt' field.
setFailedMaps(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Sets the value of the 'failedMaps' field
setFailedMaps(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Sets the value of the 'failedMaps' field.
setFailedReduces(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Sets the value of the 'failedReduces' field
setFailedReduces(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Sets the value of the 'failedReduces' field.
setFailureInfo(String) - Method in class org.apache.hadoop.mapred.JobStatus
 
setFailureInfo(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
Set diagnostic information.
setFileTimestamps(Configuration, String) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
setFilterClass(Configuration, Class) - Static method in class org.apache.hadoop.mapred.SequenceFileInputFilter
set the filter class
setFilterClass(Job, Class<?>) - Static method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
set the filter class
setFinishedMaps(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Sets the value of the 'finishedMaps' field
setFinishedMaps(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Sets the value of the 'finishedMaps' field.
setFinishedMaps(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Sets the value of the 'finishedMaps' field
setFinishedMaps(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Sets the value of the 'finishedMaps' field.
setFinishedReduces(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Sets the value of the 'finishedReduces' field
setFinishedReduces(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Sets the value of the 'finishedReduces' field.
setFinishedReduces(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Sets the value of the 'finishedReduces' field
setFinishedReduces(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Sets the value of the 'finishedReduces' field.
setFinishTime(long) - Method in class org.apache.hadoop.mapred.JobStatus
Set the finish time of the job
setFinishTime(long) - Method in class org.apache.hadoop.mapred.TaskReport
set finish time of task.
setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Sets the value of the 'finishTime' field
setFinishTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Sets the value of the 'finishTime' field.
setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Sets the value of the 'finishTime' field
setFinishTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Sets the value of the 'finishTime' field.
setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'finishTime' field
setFinishTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'finishTime' field.
setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'finishTime' field
setFinishTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'finishTime' field.
setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Sets the value of the 'finishTime' field
setFinishTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Sets the value of the 'finishTime' field.
setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'finishTime' field
setFinishTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'finishTime' field.
setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Sets the value of the 'finishTime' field
setFinishTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Sets the value of the 'finishTime' field.
setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Sets the value of the 'finishTime' field
setFinishTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Sets the value of the 'finishTime' field.
setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated.Builder
Sets the value of the 'finishTime' field
setFinishTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
Sets the value of the 'finishTime' field.
setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.JobStatus
Set the finish time of the job
setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.TaskReport
set finish time of task.
setFormat(JobConf) - Method in class org.apache.hadoop.mapred.join.CompositeInputFormat
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
set the filtering frequency in configuration
setFrequency(Configuration, int) - Static method in class org.apache.hadoop.mapred.SequenceFileInputFilter.PercentFilter
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)
setGroups(List<JhCounterGroup>) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters.Builder
Sets the value of the 'groups' field
setGroups(List<JhCounterGroup>) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
Sets the value of the 'groups' field.
setHistoryFile(String) - Method in class org.apache.hadoop.mapred.JobStatus
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
setHostname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'hostname' field
setHostname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'hostname' field.
setHostname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'hostname' field
setHostname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'hostname' field.
setHostname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Sets the value of the 'hostname' field
setHostname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Sets the value of the 'hostname' field.
setHostname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'hostname' field
setHostname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'hostname' field.
setHttpPort(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Sets the value of the 'httpPort' field
setHttpPort(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Sets the value of the 'httpPort' field.
setID(int) - Method in class org.apache.hadoop.mapred.join.Parser.Node
 
setID(int) - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
setIncludeAllCounters(boolean) - Method in class org.apache.hadoop.mapred.TaskStatus
 
setInput(JobConf, Class<? extends DBWritable>, String, String, String, String...) - Static method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
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
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.
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
 
setInputDirRecursive(Job, boolean) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
setInputFieldNames(String...) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setInputFormat(Class<? extends InputFormat>) - Method in class org.apache.hadoop.mapred.JobConf
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
 
setInputPathFilter(JobConf, Class<? extends PathFilter>) - Static method in class org.apache.hadoop.mapred.FileInputFormat
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
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
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
 
setInputSplit(InputSplit) - Method in class org.apache.hadoop.mapred.Task.TaskReporter
 
setInputTableName(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
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
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
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
 
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
Set the mapred job conf for this job.
setJobConfPath(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Sets the value of the 'jobConfPath' field
setJobConfPath(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Sets the value of the 'jobConfPath' field.
setJobEndNotificationURI(String) - Method in class org.apache.hadoop.mapred.JobConf
Set the uri to be invoked in-order to send a notification after the job has completed (success/failure).
setJobFile(String) - Method in class org.apache.hadoop.mapred.Task
 
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Sets the value of the 'jobid' field
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Sets the value of the 'jobid' field.
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
Sets the value of the 'jobid' field
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Sets the value of the 'jobid' field.
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Sets the value of the 'jobid' field
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Sets the value of the 'jobid' field.
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange.Builder
Sets the value of the 'jobid' field
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
Sets the value of the 'jobid' field.
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange.Builder
Sets the value of the 'jobid' field
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
Sets the value of the 'jobid' field.
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged.Builder
Sets the value of the 'jobid' field
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
Sets the value of the 'jobid' field.
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Sets the value of the 'jobid' field
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Sets the value of the 'jobid' field.
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Sets the value of the 'jobid' field
setJobid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Sets the value of the 'jobid' field.
setJobID(String) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Set the job ID for this job.
setJobID(JobID) - Method in class org.apache.hadoop.mapreduce.task.JobContextImpl
Set the JobID.
setJobName(String) - Method in class org.apache.hadoop.mapred.JobConf
Set the user-specified job name.
setJobName(String) - Method in class org.apache.hadoop.mapreduce.Job
Set the user-specified job name.
setJobName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Sets the value of the 'jobName' field
setJobName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Sets the value of the 'jobName' field.
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
Set JobPriority for this job.
setJobPriority(JobPriority) - Method in class org.apache.hadoop.mapred.JobStatus
Set the priority of the job, defaulting to NORMAL.
setJobPriority(String) - Method in interface org.apache.hadoop.mapred.RunningJob
Set the priority of a running job.
setJobPriority(JobID, String) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Set the priority of the specified job
setJobQueueName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange.Builder
Sets the value of the 'jobQueueName' field
setJobQueueName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobQueueChange
Sets the value of the 'jobQueueName' field.
setJobQueueName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Sets the value of the 'jobQueueName' field
setJobQueueName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Sets the value of the 'jobQueueName' field.
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.
setJobStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Sets the value of the 'jobStatus' field
setJobStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Sets the value of the 'jobStatus' field.
setJobStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged.Builder
Sets the value of the 'jobStatus' field
setJobStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChanged
Sets the value of the 'jobStatus' field.
setJobStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion.Builder
Sets the value of the 'jobStatus' field
setJobStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
Sets the value of the 'jobStatus' field.
setJobStatuses(JobStatus[]) - Method in class org.apache.hadoop.mapred.JobQueueInfo
 
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
setJobTokenSecret(SecretKey) - Method in class org.apache.hadoop.mapred.Task
Set the job token secret
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
Set whether the framework should keep the intermediate files for failed tasks.
setKeepTaskFilesPattern(String) - Method in class org.apache.hadoop.mapred.JobConf
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
 
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
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
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
 
setLaunchTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
Sets the value of the 'launchTime' field
setLaunchTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Sets the value of the 'launchTime' field.
setLaunchTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Sets the value of the 'launchTime' field
setLaunchTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Sets the value of the 'launchTime' field.
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.
setLocalArchives(Configuration, String) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
setLocalFiles(Configuration, String) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated. 
setLocality(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Sets the value of the 'locality' field
setLocality(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Sets the value of the 'locality' field.
setLocalMapFiles(Map<TaskAttemptID, MapOutputFile>) - Method in class org.apache.hadoop.mapred.ReduceTask
Register the set of mapper outputs created by a LocalJobRunner-based job with this ReduceTask so it knows where to fetch from.
setMapCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Sets the value of the 'mapCounters' field
setMapCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Sets the value of the 'mapCounters' field.
setMapDebugScript(String) - Method in class org.apache.hadoop.mapred.JobConf
Set the debug script to run when the map tasks fail.
setMapFinishTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'mapFinishTime' field
setMapFinishTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'mapFinishTime' field.
setMapOutputCompressorClass(Class<? extends CompressionCodec>) - Method in class org.apache.hadoop.mapred.JobConf
Set the given class as the CompressionCodec for the map outputs.
setMapOutputKeyClass(Class<?>) - Method in class org.apache.hadoop.mapred.JobConf
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
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
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.
setMapperConf(boolean, Configuration, Class<?>, Class<?>, Class<?>, Class<?>, Configuration, int, String) - Static method in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
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
Sets the map progress of this job
setMapProgress(float) - Method in class org.apache.hadoop.mapreduce.JobStatus
Sets the map progress of this job
setMapredJobID(String) - Method in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated. 
setMapRunnerClass(Class<? extends MapRunnable>) - Method in class org.apache.hadoop.mapred.JobConf
Expert: Set the MapRunnable class for the job.
setMapSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapred.JobConf
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
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
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. 
setMaxReduceAttempts(int) - Method in class org.apache.hadoop.mapred.JobConf
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
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
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)
setMemoryForMapTask(long) - Method in class org.apache.hadoop.mapred.JobConf
 
setMemoryForReduceTask(long) - Method in class org.apache.hadoop.mapred.JobConf
 
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
 
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.
setName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
Sets the value of the 'name' field
setName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Sets the value of the 'name' field.
setName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup.Builder
Sets the value of the 'name' field
setName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
Sets the value of the 'name' field.
setName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters.Builder
Sets the value of the 'name' field
setName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
Sets the value of the 'name' field.
setNeededMem(int) - Method in class org.apache.hadoop.mapreduce.JobStatus
 
setNextRecordRange(SortedRanges.Range) - Method in class org.apache.hadoop.mapred.TaskStatus
Set the next record range which is going to be processed by Task.
setNodeId(String) - Method in class org.apache.hadoop.mapreduce.v2.LogParams
 
setNodeManagerHost(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Sets the value of the 'nodeManagerHost' field
setNodeManagerHost(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Sets the value of the 'nodeManagerHost' field.
setNodeManagerHttpPort(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Sets the value of the 'nodeManagerHttpPort' field
setNodeManagerHttpPort(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Sets the value of the 'nodeManagerHttpPort' field.
setNodeManagerPort(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Sets the value of the 'nodeManagerPort' field
setNodeManagerPort(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Sets the value of the 'nodeManagerPort' field.
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.
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
Set the number of map tasks for this job.
setNumReduceTasks(int) - Method in class org.apache.hadoop.mapred.JobConf
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.
setNumReservedSlots(int) - Method in class org.apache.hadoop.mapreduce.JobStatus
 
setNumTasksToExecutePerJvm(int) - Method in class org.apache.hadoop.mapred.JobConf
Sets the number of tasks that a spawned task JVM should run before it exits
setNumUsedSlots(int) - Method in class org.apache.hadoop.mapreduce.JobStatus
 
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.
setOutput(JobConf, String, String...) - Static method in class org.apache.hadoop.mapred.lib.db.DBOutputFormat
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
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
setOutputCommitter(Class<? extends OutputCommitter>) - Method in class org.apache.hadoop.mapred.JobConf
Set the OutputCommitter implementation for the map-reduce job.
setOutputCompressionType(JobConf, SequenceFile.CompressionType) - Static method in class org.apache.hadoop.mapred.SequenceFileOutputFormat
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.
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
Set the OutputFormat implementation for the map-reduce job.
setOutputFormatClass(JobConf, Class<? extends OutputFormat>) - Static method in class org.apache.hadoop.mapred.lib.LazyOutputFormat
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
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.
setOutputKeyComparatorClass(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapred.JobConf
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.
setOutputTableName(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
setOutputValueClass(Class<?>) - Method in class org.apache.hadoop.mapred.JobConf
Set the value class for job outputs.
setOutputValueClass(Class<?>) - Method in class org.apache.hadoop.mapreduce.Job
Set the value class for job outputs.
setOutputValueGroupingComparator(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapred.JobConf
Set the user defined RawComparator comparator for grouping keys in the input to the reduce.
setOwner(String) - Method in class org.apache.hadoop.mapreduce.v2.LogParams
 
setPartitionerClass(Class<? extends Partitioner>) - Method in class org.apache.hadoop.mapred.JobConf
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(JobConf, Path) - Static method in class org.apache.hadoop.mapred.lib.TotalOrderPartitioner
Deprecated. Use TotalOrderPartitioner.setPartitionFile(Configuration, Path) instead
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
 
setPattern(Configuration, String) - Static method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter.RegexFilter
Define the filtering regex and stores it in conf
setPhase(TaskStatus.Phase) - Method in class org.apache.hadoop.mapred.Task
Set current phase of the task.
setPhase(TaskStatus.Phase) - Method in class org.apache.hadoop.mapred.TaskStatus
Set current phase of this task.
setPhysMemKbytes(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'physMemKbytes' field
setPhysMemKbytes(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'physMemKbytes' field.
setPhysMemKbytes(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'physMemKbytes' field
setPhysMemKbytes(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'physMemKbytes' field.
setPhysMemKbytes(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'physMemKbytes' field
setPhysMemKbytes(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'physMemKbytes' field.
setPort(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'port' field
setPort(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'port' field.
setPort(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'port' field
setPort(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'port' field.
setPort(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'port' field
setPort(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'port' field.
setPriority(JobPriority) - Method in class org.apache.hadoop.mapreduce.Job
Set the priority of a running job.
setPriority(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange.Builder
Sets the value of the 'priority' field
setPriority(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChange
Sets the value of the 'priority' field.
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
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
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
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.
setProgress(float) - Method in class org.apache.hadoop.mapred.Task.TaskReporter
 
setProgress(float) - Method in class org.apache.hadoop.mapred.TaskStatus
 
setProperties(Properties) - Method in class org.apache.hadoop.mapred.JobQueueInfo
 
setProperties(Properties) - Method in class org.apache.hadoop.mapreduce.QueueInfo
 
setQueue(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
Set queue name
setQueueChildren(List<QueueInfo>) - Method in class org.apache.hadoop.mapreduce.QueueInfo
 
setQueueName(String) - Method in class org.apache.hadoop.mapred.JobConf
Set the name of the queue to which this job should be submitted.
setQueueName(String) - Method in class org.apache.hadoop.mapred.JobQueueInfo
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
Set the state of the queue
setRackname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'rackname' field
setRackname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'rackname' field.
setRackname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'rackname' field
setRackname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'rackname' field.
setRackname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Sets the value of the 'rackname' field
setRackname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Sets the value of the 'rackname' field.
setRackname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'rackname' field
setRackname(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'rackname' field.
setRecordLength(Configuration, int) - Static method in class org.apache.hadoop.mapred.FixedLengthInputFormat
Set the length of each record
setRecordLength(Configuration, int) - Static method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthInputFormat
Set the length of each record
setReduceCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Sets the value of the 'reduceCounters' field
setReduceCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Sets the value of the 'reduceCounters' field.
setReduceDebugScript(String) - Method in class org.apache.hadoop.mapred.JobConf
Set the debug script to run when the reduce tasks fail.
setReduceProgress(float) - Method in class org.apache.hadoop.mapred.JobStatus
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
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.Chain
Sets the Reducer class to the chain job.
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
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.
setReducerConf(Configuration, Class<?>, Class<?>, Class<?>, Class<?>, Configuration, String) - Static method in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
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.
setReduceSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapred.JobConf
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.
setReservedMem(int) - Method in class org.apache.hadoop.mapreduce.JobStatus
 
setRetired() - Method in class org.apache.hadoop.mapred.JobStatus
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.
setRunningTaskAttemptIds(Collection<TaskAttemptID>) - Method in class org.apache.hadoop.mapreduce.TaskReport
set running attempt(s) of the task.
setRunningTaskAttempts(Collection<TaskAttemptID>) - Method in class org.apache.hadoop.mapred.TaskReport
set running attempt(s) of the task.
setRunState(int) - Method in class org.apache.hadoop.mapred.JobStatus
Change the current run state of the job.
setRunState(TaskStatus.State) - Method in class org.apache.hadoop.mapred.TaskStatus
 
setSchedulerInfo(String, Object) - Method in class org.apache.hadoop.mapred.QueueManager
Set a generic Object that represents scheduling information relevant to a queue.
setSchedulingInfo(String) - Method in class org.apache.hadoop.mapred.JobQueueInfo
Set the scheduling information associated to particular job queue
setSchedulingInfo(String) - Method in class org.apache.hadoop.mapred.JobStatus
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
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
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
Sets the setup progress of this job
setSetupProgress(float) - Method in class org.apache.hadoop.mapreduce.JobStatus
Sets the setup progress of this job
setShuffleFinishTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'shuffleFinishTime' field
setShuffleFinishTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'shuffleFinishTime' field.
setShufflePort(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Sets the value of the 'shufflePort' field
setShufflePort(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Sets the value of the 'shufflePort' field.
setShuffleSecret(SecretKey) - Method in class org.apache.hadoop.mapred.Task
Set the secret key used to authenticate the shuffle
setShuffleSecretKey(byte[], Credentials) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
 
setSkipOutputPath(JobConf, Path) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Set the directory to which skipped records are written.
setSkipping(boolean) - Method in class org.apache.hadoop.mapred.Task
Sets whether to run Task in skipping mode.
setSkipRanges(SortedRanges) - Method in class org.apache.hadoop.mapred.Task
Set skipRanges.
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.
setSortFinishTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'sortFinishTime' field
setSortFinishTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'sortFinishTime' field.
setSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapred.JobConf
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.
setSplitLocations(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Sets the value of the 'splitLocations' field
setSplitLocations(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Sets the value of the 'splitLocations' field.
setStartTime(long) - Method in class org.apache.hadoop.mapred.JobStatus
Set the start time of the job
setStartTime(long) - Method in class org.apache.hadoop.mapred.TaskReport
set start time of the task.
setStartTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted.Builder
Sets the value of the 'startTime' field
setStartTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Sets the value of the 'startTime' field.
setStartTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Sets the value of the 'startTime' field
setStartTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Sets the value of the 'startTime' field.
setStartTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Sets the value of the 'startTime' field
setStartTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Sets the value of the 'startTime' field.
setStartTime(long) - Method in class org.apache.hadoop.mapreduce.JobStatus
Set the start time of the job
setStartTime(long) - Method in class org.apache.hadoop.mapreduce.TaskReport
set start time of the task.
setState(int) - Method in class org.apache.hadoop.mapred.jobcontrol.Job
Deprecated. 
setState(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'state' field
setState(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'state' field.
setState(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'state' field
setState(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'state' field.
setState(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Sets the value of the 'state' field
setState(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Sets the value of the 'state' field.
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
 
setStateString(String) - Method in class org.apache.hadoop.mapred.TaskStatus
Set the state of the TaskStatus.
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.mapred.Task.TaskReporter
 
setStatus(String) - Method in class org.apache.hadoop.mapred.TaskAttemptContextImpl
Set the current status of the task to the given string.
setStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'status' field
setStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'status' field.
setStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Sets the value of the 'status' field
setStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Sets the value of the 'status' field.
setStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Sets the value of the 'status' field
setStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Sets the value of the 'status' field.
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.StatusReporter
 
setStatus(String) - Method in class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl.DummyReporter
 
setStatus(String) - Method in class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl
Set the current status of the task to the given string.
setStatus(String) - Method in interface org.apache.hadoop.mapreduce.TaskAttemptContext
Set the current status of the task to the given string.
setStatusString(String) - Method in class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl
 
setSubmitTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange.Builder
Sets the value of the 'submitTime' field
setSubmitTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Sets the value of the 'submitTime' field.
setSubmitTime(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Sets the value of the 'submitTime' field
setSubmitTime(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Sets the value of the 'submitTime' field.
setSuccessfulAttempt(TaskAttemptID) - Method in class org.apache.hadoop.mapred.TaskReport
set successful attempt ID of the task.
setSuccessfulAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Sets the value of the 'successfulAttemptId' field
setSuccessfulAttemptId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Sets the value of the 'successfulAttemptId' field.
setSuccessfulAttemptId(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.TaskReport
set successful attempt ID of the task.
setTaskAttemptId(TaskAttemptID) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
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(TaskAttemptID) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated. use TaskCompletionEvent.setTaskAttemptId(TaskAttemptID) instead.
setTaskId(String) - Method in class org.apache.hadoop.mapred.TaskLogAppender
 
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'taskid' field
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'taskid' field.
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'taskid' field
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'taskid' field.
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Sets the value of the 'taskid' field
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Sets the value of the 'taskid' field.
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Sets the value of the 'taskid' field
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Sets the value of the 'taskid' field.
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'taskid' field
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'taskid' field.
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Sets the value of the 'taskid' field
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Sets the value of the 'taskid' field.
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Sets the value of the 'taskid' field
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Sets the value of the 'taskid' field.
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Sets the value of the 'taskid' field
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Sets the value of the 'taskid' field.
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated.Builder
Sets the value of the 'taskid' field
setTaskid(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
Sets the value of the 'taskid' field.
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
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
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
Set task status.
setTaskStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'taskStatus' field
setTaskStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'taskStatus' field.
setTaskStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'taskStatus' field
setTaskStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'taskStatus' field.
setTaskStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Sets the value of the 'taskStatus' field
setTaskStatus(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Sets the value of the 'taskStatus' field.
setTaskStatus(TaskCompletionEvent.Status) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Set task status.
setTaskTracker(String) - Method in class org.apache.hadoop.mapred.TaskStatus
 
setTaskTrackerHttp(String) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Set task tracker http location.
setTaskTrackerHttp(String) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Set task tracker http location.
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'taskType' field
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'taskType' field.
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'taskType' field
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'taskType' field.
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished.Builder
Sets the value of the 'taskType' field
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Sets the value of the 'taskType' field.
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Sets the value of the 'taskType' field
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Sets the value of the 'taskType' field.
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'taskType' field
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'taskType' field.
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed.Builder
Sets the value of the 'taskType' field
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Sets the value of the 'taskType' field.
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished.Builder
Sets the value of the 'taskType' field
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Sets the value of the 'taskType' field.
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted.Builder
Sets the value of the 'taskType' field
setTaskType(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Sets the value of the 'taskType' field.
setTotalCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished.Builder
Sets the value of the 'totalCounters' field
setTotalCounters(JhCounters) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Sets the value of the 'totalCounters' field.
setTotalLogFileSize(long) - Method in class org.apache.hadoop.mapred.TaskLogAppender
 
setTotalMaps(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Sets the value of the 'totalMaps' field
setTotalMaps(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Sets the value of the 'totalMaps' field.
setTotalReduces(int) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Sets the value of the 'totalReduces' field
setTotalReduces(Integer) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Sets the value of the 'totalReduces' field.
setTrackerName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted.Builder
Sets the value of the 'trackerName' field
setTrackerName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Sets the value of the 'trackerName' field.
setTrackingUrl(String) - Method in class org.apache.hadoop.mapred.JobStatus
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.
setType(EventType) - Method in class org.apache.hadoop.mapreduce.jobhistory.Event.Builder
Sets the value of the 'type' field
setType(EventType) - Method in class org.apache.hadoop.mapreduce.jobhistory.Event
Sets the value of the 'type' field.
setUber(boolean) - Method in class org.apache.hadoop.mapreduce.JobStatus
Set uber-mode flag
setUberized(boolean) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited.Builder
Sets the value of the 'uberized' field
setUberized(Boolean) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Sets the value of the 'uberized' field.
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<K1, V1, K2, V2>.Context) - Method in class org.apache.hadoop.mapreduce.lib.input.DelegatingMapper
 
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.
SETUP_CLEANUP_NEEDED - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
setupJob(JobContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
setupJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
For the framework to setup the job output during initialization.
setupJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
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
 
setupProgress() - Method in interface org.apache.hadoop.mapred.RunningJob
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.mapred.FileOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Sets up output for the task.
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
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.
setUsedMem(int) - Method in class org.apache.hadoop.mapreduce.JobStatus
 
setUseNewMapper(boolean) - Method in class org.apache.hadoop.mapred.JobConf
Set whether the framework should use the new api for the mapper.
setUseNewReducer(boolean) - Method in class org.apache.hadoop.mapred.JobConf
Set whether the framework should use the new api for the reducer.
setUser(String) - Method in class org.apache.hadoop.mapred.JobConf
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
 
setUserName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Sets the value of the 'userName' field
setUserName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Sets the value of the 'userName' field.
setUsername(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
 
setValue(long) - Method in class org.apache.hadoop.mapred.Counters.Counter
 
setValue(long) - Method in interface org.apache.hadoop.mapreduce.Counter
Set this counter by the given value
setValue(long) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup.FSCounter
 
setValue(long) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup.FrameworkCounter
 
setValue(long) - Method in class org.apache.hadoop.mapreduce.counters.GenericCounter
 
setValue(long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter.Builder
Sets the value of the 'value' field
setValue(Long) - Method in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Sets the value of the 'value' field.
setVMemKbytes(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished.Builder
Sets the value of the 'vMemKbytes' field
setVMemKbytes(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Sets the value of the 'vMemKbytes' field.
setVMemKbytes(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished.Builder
Sets the value of the 'vMemKbytes' field
setVMemKbytes(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Sets the value of the 'vMemKbytes' field.
setVMemKbytes(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion.Builder
Sets the value of the 'vMemKbytes' field
setVMemKbytes(List<Integer>) - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Sets the value of the 'vMemKbytes' field.
setWorkflowAdjacencies(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Sets the value of the 'workflowAdjacencies' field
setWorkflowAdjacencies(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Sets the value of the 'workflowAdjacencies' field.
setWorkflowId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Sets the value of the 'workflowId' field
setWorkflowId(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Sets the value of the 'workflowId' field.
setWorkflowName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Sets the value of the 'workflowName' field
setWorkflowName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Sets the value of the 'workflowName' field.
setWorkflowNodeName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Sets the value of the 'workflowNodeName' field
setWorkflowNodeName(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Sets the value of the 'workflowNodeName' field.
setWorkflowTags(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted.Builder
Sets the value of the 'workflowTags' field
setWorkflowTags(CharSequence) - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Sets the value of the 'workflowTags' field.
setWorkingDirectory(Path) - Method in class org.apache.hadoop.mapred.JobConf
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.
setWorkOutputPath(JobConf, Path) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
Set the Path of the task's temporary output directory for the map-reduce job.
setWriteAllCounters(boolean) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Set the "writeAllCounters" option to true or false
setWriter(IFile.Writer<K, V>) - Method in class org.apache.hadoop.mapred.Task.CombineOutputCollector
 
setWriteSkipRecs(boolean) - Method in class org.apache.hadoop.mapred.Task
Set whether to write skip records.
shiftBufferedKey() - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.BlockingBuffer
Set position from last mark to end of writable buffer, then rewrite the data between last mark and kvindex.
shouldDie() - Method in class org.apache.hadoop.mapred.JvmTask
 
shouldReset() - Method in class org.apache.hadoop.mapred.MapTaskCompletionEventsUpdate
 
shuffle(MapHost, InputStream, long, long, ShuffleClientMetrics, Reporter) - Method in class org.apache.hadoop.mapreduce.task.reduce.MapOutput
 
Shuffle<K,V> - Class in org.apache.hadoop.mapreduce.task.reduce
 
Shuffle() - Constructor for class org.apache.hadoop.mapreduce.task.reduce.Shuffle
 
Shuffle.ShuffleError - Exception in org.apache.hadoop.mapreduce.task.reduce
 
SHUFFLE_CONNECT_TIMEOUT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SHUFFLE_CONSUMER_PLUGIN - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
SHUFFLE_EXCEPTION_MSG_REGEX - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
SHUFFLE_EXCEPTION_STACK_REGEX - Static variable in interface org.apache.hadoop.mapreduce.server.jobtracker.JTConfig
 
SHUFFLE_FETCH_FAILURES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SHUFFLE_INPUT_BUFFER_PERCENT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SHUFFLE_MEMORY_LIMIT_PERCENT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SHUFFLE_MERGE_PERCENT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SHUFFLE_NOTIFY_READERROR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SHUFFLE_PARALLEL_COPIES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SHUFFLE_READ_TIMEOUT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SHUFFLE_SSL_ENABLED_DEFAULT - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
SHUFFLE_SSL_ENABLED_KEY - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
ShuffleClientMetrics - Class in org.apache.hadoop.mapreduce.task.reduce
 
ShuffleConsumerPlugin<K,V> - Interface in org.apache.hadoop.mapred
ShuffleConsumerPlugin for serving Reducers.
ShuffleConsumerPlugin.Context<K,V> - Class in org.apache.hadoop.mapred
 
ShuffleConsumerPlugin.Context(TaskAttemptID, JobConf, FileSystem, TaskUmbilicalProtocol, LocalDirAllocator, Reporter, CompressionCodec, Class<? extends Reducer>, Task.CombineOutputCollector<K, V>, Counters.Counter, Counters.Counter, Counters.Counter, Counters.Counter, Counters.Counter, Counters.Counter, TaskStatus, Progress, Progress, Task, MapOutputFile, Map<TaskAttemptID, MapOutputFile>) - Constructor for class org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context
 
shuffleError(TaskAttemptID, String) - Method in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Report that a reduce-task couldn't shuffle map-outputs.
shuffleFinishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
ShuffleHeader - Class in org.apache.hadoop.mapreduce.task.reduce
Shuffle Header information that is sent by the TaskTracker and deciphered by the Fetcher thread of Reduce task
ShuffleHeader() - Constructor for class org.apache.hadoop.mapreduce.task.reduce.ShuffleHeader
 
ShuffleHeader(String, long, long, int) - Constructor for class org.apache.hadoop.mapreduce.task.reduce.ShuffleHeader
 
shufflePort - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Deprecated. 
ShuffleScheduler<K,V> - Interface in org.apache.hadoop.mapreduce.task.reduce
 
ShuffleSchedulerImpl<K,V> - Class in org.apache.hadoop.mapreduce.task.reduce
 
ShuffleSchedulerImpl(JobConf, TaskStatus, TaskAttemptID, ExceptionReporter, Progress, Counters.Counter, Counters.Counter, Counters.Counter) - Constructor for class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
shuffleSecret - Variable in class org.apache.hadoop.mapred.Task
 
sigQuitProcess(String) - Static method in class org.apache.hadoop.mapreduce.util.ProcessTree
Sends SIGQUIT to process; Java programs will dump their stack to stdout.
sigQuitProcessGroup(String) - Static method in class org.apache.hadoop.mapreduce.util.ProcessTree
Sends SIGQUIT to all processes belonging to the same process group, ordering all processes in the group to send their stack dump to stdout.
size() - Method in class org.apache.hadoop.mapred.Counters.Group
 
size() - Method in class org.apache.hadoop.mapred.Counters
Deprecated. use AbstractCounters.countCounters() instead
size() - Method in class org.apache.hadoop.mapred.SpillRecord
Return number of IndexRecord entries in this spill.
size() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
 
size() - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
 
size() - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
 
size() - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
 
size() - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
The number of children in this Tuple.
skip(long) - Method in class org.apache.hadoop.mapred.IFileInputStream
 
skip(K) - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
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
Pass skip key to child RRs.
skip(K) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
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.
SKIP_OUTDIR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SKIP_RECORDS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SKIP_START_ATTEMPTS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SkipBadRecords - Class in org.apache.hadoop.mapred
Utility class for skip bad records functionality.
SkipBadRecords() - Constructor for class org.apache.hadoop.mapred.SkipBadRecords
 
sortFinishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
specToString(String, String, int, List<Integer>, List<Integer>) - Static method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
SPECULATIVE_SLOWNODE_THRESHOLD - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SPECULATIVE_SLOWTASK_THRESHOLD - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SPECULATIVECAP - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
spilledRecordsCounter - Variable in class org.apache.hadoop.mapred.Task
 
SpillRecord - Class in org.apache.hadoop.mapred
 
SpillRecord(int) - Constructor for class org.apache.hadoop.mapred.SpillRecord
 
SpillRecord(Path, JobConf) - Constructor for class org.apache.hadoop.mapred.SpillRecord
 
SpillRecord(Path, JobConf, String) - Constructor for class org.apache.hadoop.mapred.SpillRecord
 
SpillRecord(Path, JobConf, Checksum, String) - Constructor for class org.apache.hadoop.mapred.SpillRecord
 
split - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
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_FILE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
SPLIT_MAXSIZE - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
SPLIT_METAINFO_MAXSIZE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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
 
SplitLineReader - Class in org.apache.hadoop.mapreduce.lib.input
 
SplitLineReader(InputStream, byte[]) - Constructor for class org.apache.hadoop.mapreduce.lib.input.SplitLineReader
 
SplitLineReader(InputStream, Configuration, byte[]) - Constructor for class org.apache.hadoop.mapreduce.lib.input.SplitLineReader
 
splitLocations - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Deprecated. 
SplitMetaInfoReader - Class in org.apache.hadoop.mapreduce.split
A utility that reads the split meta info and creates split meta info objects
SplitMetaInfoReader() - Constructor for class org.apache.hadoop.mapreduce.split.SplitMetaInfoReader
 
startCommunicationThread() - Method in class org.apache.hadoop.mapred.Task.TaskReporter
 
startOffset - Variable in class org.apache.hadoop.mapred.IndexRecord
 
startTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
Deprecated. 
startTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Deprecated. 
startTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Deprecated. 
state - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
state - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
state - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Deprecated. 
statement - Variable in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
STATIC_RESOLUTIONS - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
status - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
status - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Deprecated. 
status - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Deprecated. 
StatusReporter - Class in org.apache.hadoop.mapreduce
 
StatusReporter() - Constructor for class org.apache.hadoop.mapreduce.StatusReporter
 
statusUpdate(TaskUmbilicalProtocol) - Method in class org.apache.hadoop.mapred.Task
Send a status update to the task tracker
statusUpdate(TaskAttemptID, TaskStatus) - Method in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Report child's progress to parent.
STDERR_LOGFILE_ENV - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
STDOUT_LOGFILE_ENV - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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.
stopCommunicationThread() - Method in class org.apache.hadoop.mapred.Task.TaskReporter
 
StreamBackedIterator<X extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.mapred.join
This class provides an implementation of ResetableIterator.
StreamBackedIterator() - Constructor for class org.apache.hadoop.mapred.join.StreamBackedIterator
 
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
 
STRING_VALUE_MAX - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
 
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
 
STRING_VALUE_MIN - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
StringValueMax - Class in org.apache.hadoop.mapred.lib.aggregate
This class implements a value aggregator that maintain the biggest of a sequence of strings.
StringValueMax() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.StringValueMax
 
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
This class implements a value aggregator that maintain the smallest of a sequence of strings.
StringValueMin() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.StringValueMin
 
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
 
submitJob(String) - Method in class org.apache.hadoop.mapred.JobClient
Submit a job to the MR system.
submitJob(JobConf) - Method in class org.apache.hadoop.mapred.JobClient
Submit a job to the MR system.
submitJob(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Deprecated. Use Submitter.runJob(JobConf)
submitJob(JobID, String, Credentials) - Method in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
Submit a Job for execution.
submitJobInternal(JobConf) - Method in class org.apache.hadoop.mapred.JobClient
 
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
 
submitTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobInfoChange
Deprecated. 
submitTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Deprecated. 
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
 
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
 
SUCCESS - Static variable in interface org.apache.hadoop.mapred.MRConstants
 
successFetch() - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleClientMetrics
 
SUCCESSFUL_JOB_OUTPUT_DIR_MARKER - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
 
successfulAttemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Deprecated. 
sum(Counters, Counters) - Static method in class org.apache.hadoop.mapred.Counters
Convenience method for computing the sum of two sets of counters.
suspend() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
suspend the running thread
swap(int, int) - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer
Swap metadata for items i, j
syncLogs(String, TaskAttemptID, boolean) - Static method in class org.apache.hadoop.mapred.TaskLog
 
syncLogs() - Static method in class org.apache.hadoop.mapred.TaskLog
 
syncLogsShutdown(ScheduledExecutorService) - Static method in class org.apache.hadoop.mapred.TaskLog
 

T

tableName - Variable in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
Task - Class in org.apache.hadoop.mapred
Base class for tasks.
Task() - Constructor for class org.apache.hadoop.mapred.Task
 
Task(String, TaskAttemptID, int, int) - Constructor for class org.apache.hadoop.mapred.Task
 
TASK - Static variable in class org.apache.hadoop.mapreduce.TaskID
 
Task.CombineOutputCollector<K,V> - Class in org.apache.hadoop.mapred
OutputCollector for the combiner.
Task.CombineOutputCollector(Counters.Counter, Progressable, Configuration) - Constructor for class org.apache.hadoop.mapred.Task.CombineOutputCollector
 
Task.CombinerRunner<K,V> - Class in org.apache.hadoop.mapred
 
Task.CombineValuesIterator<KEY,VALUE> - Class in org.apache.hadoop.mapred
Iterator to return Combined values
Task.CombineValuesIterator(RawKeyValueIterator, RawComparator<KEY>, Class<KEY>, Class<VALUE>, Configuration, Reporter, Counters.Counter) - Constructor for class org.apache.hadoop.mapred.Task.CombineValuesIterator
 
Task.Counter - Enum in org.apache.hadoop.mapred
Deprecated. Provided for compatibility. Use TaskCounter instead.
Task.NewCombinerRunner<K,V> - Class in org.apache.hadoop.mapred
 
Task.OldCombinerRunner<K,V> - Class in org.apache.hadoop.mapred
 
Task.OldCombinerRunner(Class<? extends Reducer<K, V, K, V>>, JobConf, Counters.Counter, Task.TaskReporter) - Constructor for class org.apache.hadoop.mapred.Task.OldCombinerRunner
 
Task.TaskReporter - Class in org.apache.hadoop.mapred
 
TASK_ATTEMPT_ID - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_CLEANUP_NEEDED - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_DEBUGOUT_LINES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_ID - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_ISMAP - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_LOCAL_OUTPUT_CLASS - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
TASK_LOG_BACKUPS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_MAP_PROFILE_PARAMS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_OUTPUT_DIR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_PARTITION - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_PROFILE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_PROFILE_PARAMS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_REDUCE_PROFILE_PARAMS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_TEMP_DIR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_TIMEOUT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_TIMEOUT_CHECK_INTERVAL_MS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TASK_USERLOG_LIMIT - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
TaskAttemptContext - Interface in org.apache.hadoop.mapred
 
TaskAttemptContext - Interface in org.apache.hadoop.mapreduce
The context for task attempts.
TaskAttemptContextImpl - Class in org.apache.hadoop.mapred
 
TaskAttemptContextImpl(JobConf, TaskAttemptID) - Constructor for class org.apache.hadoop.mapred.TaskAttemptContextImpl
 
TaskAttemptContextImpl - Class in org.apache.hadoop.mapreduce.task
The context for task attempts.
TaskAttemptContextImpl(Configuration, TaskAttemptID) - Constructor for class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl
 
TaskAttemptContextImpl(Configuration, TaskAttemptID, StatusReporter) - Constructor for class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl
 
TaskAttemptContextImpl.DummyReporter - Class in org.apache.hadoop.mapreduce.task
 
TaskAttemptContextImpl.DummyReporter() - Constructor for class org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl.DummyReporter
 
TaskAttemptFinished - Class in org.apache.hadoop.mapreduce.jobhistory
 
TaskAttemptFinished() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Default constructor.
TaskAttemptFinished(CharSequence, CharSequence, CharSequence, CharSequence, Long, CharSequence, CharSequence, CharSequence, JhCounters) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
All-args constructor.
TaskAttemptFinished.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for TaskAttemptFinished instances.
TaskAttemptFinishedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record successful task completion
TaskAttemptFinishedEvent(TaskAttemptID, TaskType, String, long, String, String, String, Counters) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Create an event to record successful finishes for setup and cleanup attempts
TaskAttemptID - Class in org.apache.hadoop.mapred
TaskAttemptID represents the immutable and unique identifier for a task attempt.
TaskAttemptID(TaskID, int) - Constructor for class org.apache.hadoop.mapred.TaskAttemptID
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
Constructs a TaskId object from given parts.
TaskAttemptID() - Constructor for class org.apache.hadoop.mapred.TaskAttemptID
 
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(String, int, boolean, int, int) - Constructor for class org.apache.hadoop.mapreduce.TaskAttemptID
Deprecated. 
TaskAttemptID() - Constructor for class org.apache.hadoop.mapreduce.TaskAttemptID
 
TaskAttemptStarted - Class in org.apache.hadoop.mapreduce.jobhistory
 
TaskAttemptStarted() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Default constructor.
TaskAttemptStarted(CharSequence, CharSequence, CharSequence, Long, CharSequence, Integer, Integer, CharSequence, CharSequence, CharSequence) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
All-args constructor.
TaskAttemptStarted.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for TaskAttemptStarted instances.
TaskAttemptStartedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record start of a task attempt
TaskAttemptStartedEvent(TaskAttemptID, TaskType, long, String, int, int, ContainerId, String, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Create an event to record the start of an attempt
TaskAttemptStartedEvent(TaskAttemptID, TaskType, long, String, int, int, String, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
 
TaskAttemptUnsuccessfulCompletion - Class in org.apache.hadoop.mapreduce.jobhistory
 
TaskAttemptUnsuccessfulCompletion() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Default constructor.
TaskAttemptUnsuccessfulCompletion(CharSequence, CharSequence, CharSequence, Long, CharSequence, Integer, CharSequence, CharSequence, CharSequence, JhCounters, List<Integer>, List<Integer>, List<Integer>, List<Integer>) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
All-args constructor.
TaskAttemptUnsuccessfulCompletion.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for TaskAttemptUnsuccessfulCompletion instances.
TaskAttemptUnsuccessfulCompletionEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record unsuccessful (Killed/Failed) completion of task attempts
TaskAttemptUnsuccessfulCompletionEvent(TaskAttemptID, TaskType, String, long, String, int, String, String, Counters, int[][]) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Create an event to record the unsuccessful completion of attempts
TaskAttemptUnsuccessfulCompletionEvent(TaskAttemptID, TaskType, String, long, String, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Deprecated. please use the constructor with an additional argument, an array of splits arrays instead. See ProgressSplitsBlock for an explanation of the meaning of that parameter. Create an event to record the unsuccessful completion of attempts
TaskAttemptUnsuccessfulCompletionEvent(TaskAttemptID, TaskType, String, long, String, int, String, String, int[][]) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
 
taskCleanup - Variable in class org.apache.hadoop.mapred.Task
 
TaskCompletionEvent - Class in org.apache.hadoop.mapred
This is used to track task completion events on job tracker.
TaskCompletionEvent() - Constructor for class org.apache.hadoop.mapred.TaskCompletionEvent
Default constructor for Writable.
TaskCompletionEvent(int, TaskAttemptID, int, boolean, TaskCompletionEvent.Status, String) - Constructor for class org.apache.hadoop.mapred.TaskCompletionEvent
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
 
TaskCompletionEvent.Status - Enum in org.apache.hadoop.mapreduce
 
taskContext - Variable in class org.apache.hadoop.mapred.Task
 
TaskCounter - Enum in org.apache.hadoop.mapreduce
 
TaskFailed - Class in org.apache.hadoop.mapreduce.jobhistory
 
TaskFailed() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Default constructor.
TaskFailed(CharSequence, CharSequence, Long, CharSequence, CharSequence, CharSequence, JhCounters) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
All-args constructor.
TaskFailed.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for TaskFailed instances.
TaskFailedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record the failure of a task
TaskFailedEvent(TaskID, long, TaskType, String, String, TaskAttemptID, Counters) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
Create an event to record task failure
TaskFailedEvent(TaskID, long, TaskType, String, String, TaskAttemptID) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
 
TaskFinished - Class in org.apache.hadoop.mapreduce.jobhistory
 
TaskFinished() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Default constructor.
TaskFinished(CharSequence, CharSequence, Long, CharSequence, JhCounters, CharSequence) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
All-args constructor.
TaskFinished.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for TaskFinished instances.
TaskFinishedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record the successful completion of a task
TaskFinishedEvent(TaskID, TaskAttemptID, long, TaskType, String, Counters) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent
Create an event to record the successful completion of a task
TaskID - Class in org.apache.hadoop.mapred
TaskID represents the immutable and unique identifier for a Map or Reduce Task.
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
Constructs a TaskID object from given JobID.
TaskID(String, int, TaskType, int) - Constructor for class org.apache.hadoop.mapred.TaskID
Constructs a TaskInProgressId object from given parts.
TaskID() - Constructor for class org.apache.hadoop.mapred.TaskID
 
taskid - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
taskid - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
taskid - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Deprecated. 
taskid - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Deprecated. 
taskid - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
taskid - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Deprecated. 
taskid - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Deprecated. 
taskid - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Deprecated. 
taskid - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
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(JobID, boolean, int) - Constructor for class org.apache.hadoop.mapreduce.TaskID
Deprecated. 
TaskID(String, int, boolean, int) - Constructor for class org.apache.hadoop.mapreduce.TaskID
Deprecated. 
TaskID() - Constructor for class org.apache.hadoop.mapreduce.TaskID
 
TaskInputOutputContext<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Interface in org.apache.hadoop.mapreduce
A context object that allows input and output from the task.
TaskInputOutputContextImpl<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce.task
A context object that allows input and output from the task.
TaskInputOutputContextImpl(Configuration, TaskAttemptID, RecordWriter<KEYOUT, VALUEOUT>, OutputCommitter, StatusReporter) - Constructor for class org.apache.hadoop.mapreduce.task.TaskInputOutputContextImpl
 
TaskLog - Class in org.apache.hadoop.mapred
A simple logger to handle the task-specific user logs.
TaskLog() - Constructor for class org.apache.hadoop.mapred.TaskLog
 
TaskLog.LogName - Enum in org.apache.hadoop.mapred
The filter for userlogs.
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
A report on the state of a task.
TaskReport() - Constructor for class org.apache.hadoop.mapred.TaskReport
 
TaskReport - Class in org.apache.hadoop.mapreduce
A report on the state of a task.
TaskReport() - Constructor for class org.apache.hadoop.mapreduce.TaskReport
 
TaskReport(TaskID, float, String, String[], TIPStatus, long, long, Counters) - Constructor for class org.apache.hadoop.mapreduce.TaskReport
Creates a new TaskReport object
TaskStarted - Class in org.apache.hadoop.mapreduce.jobhistory
 
TaskStarted() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Default constructor.
TaskStarted(CharSequence, CharSequence, Long, CharSequence) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
All-args constructor.
TaskStarted.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for TaskStarted instances.
TaskStartedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record the start of a task
TaskStartedEvent(TaskID, long, TaskType, String) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskStartedEvent
Create an event to record start of a task
TaskStatus - Class in org.apache.hadoop.mapred
Describes the current status of a task.
TaskStatus() - Constructor for class org.apache.hadoop.mapred.TaskStatus
 
TaskStatus(TaskAttemptID, float, int, TaskStatus.State, String, String, String, TaskStatus.Phase, Counters) - Constructor for class org.apache.hadoop.mapred.TaskStatus
 
taskStatus - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
taskStatus - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
taskStatus - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Deprecated. 
TaskStatus.Phase - Enum in org.apache.hadoop.mapred
 
TaskStatus.State - Enum in org.apache.hadoop.mapred
 
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 - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
taskType - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
taskType - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
Deprecated. 
taskType - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Deprecated. 
taskType - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 
taskType - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
Deprecated. 
taskType - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
Deprecated. 
taskType - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskStarted
Deprecated. 
TaskType - Enum in org.apache.hadoop.mapreduce
Enum for map, reduce, job-setup, job-cleanup, task-cleanup task types.
TaskUmbilicalProtocol - Interface in org.apache.hadoop.mapred
Protocol that task child process uses to contact its parent process.
TaskUpdated - Class in org.apache.hadoop.mapreduce.jobhistory
 
TaskUpdated() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
Default constructor.
TaskUpdated(CharSequence, Long) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
All-args constructor.
TaskUpdated.Builder - Class in org.apache.hadoop.mapreduce.jobhistory
RecordBuilder for TaskUpdated instances.
TaskUpdatedEvent - Class in org.apache.hadoop.mapreduce.jobhistory
Event to record updates to a task
TaskUpdatedEvent(TaskID, long) - Constructor for class org.apache.hadoop.mapreduce.jobhistory.TaskUpdatedEvent
Create an event to record task updates
TEMP_DIR - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
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
Deprecated. 
terminateProcess(String) - Static method in class org.apache.hadoop.mapreduce.util.ProcessTree
Sends terminate signal to the process, allowing it to gracefully exit.
terminateProcessGroup(String) - Static method in class org.apache.hadoop.mapreduce.util.ProcessTree
Sends terminate signal to all the process belonging to the passed process group, allowing the group to gracefully exit.
TextInputFormat - Class in org.apache.hadoop.mapred
An InputFormat for plain text files.
TextInputFormat() - Constructor for class org.apache.hadoop.mapred.TextInputFormat
 
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
 
TextOutputFormat<K,V> - Class in org.apache.hadoop.mapred
An OutputFormat that writes plain text files.
TextOutputFormat() - Constructor for class org.apache.hadoop.mapred.TextOutputFormat
 
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
 
TextOutputFormat.LineRecordWriter(DataOutputStream, String) - Constructor for class org.apache.hadoop.mapred.TextOutputFormat.LineRecordWriter
 
TextOutputFormat.LineRecordWriter(DataOutputStream) - Constructor for class org.apache.hadoop.mapred.TextOutputFormat.LineRecordWriter
 
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
 
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
 
threadBusy() - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleClientMetrics
 
threadFree() - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleClientMetrics
 
tipFailed(TaskID) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
 
TIPStatus - Enum in org.apache.hadoop.mapred
The states of a Tasks.
toAvro(int[]) - Static method in class org.apache.hadoop.mapreduce.jobhistory.AvroArrayUtils
 
toEscapedCompactString(Counter) - Static method in class org.apache.hadoop.mapreduce.util.CountersStrings
Make the pre 0.21 counter string (for e.g.
toEscapedCompactString(G) - Static method in class org.apache.hadoop.mapreduce.util.CountersStrings
Make the 0.21 counter group string.
toEscapedCompactString(T) - Static method in class org.apache.hadoop.mapreduce.util.CountersStrings
Make the pre 0.21 counters string
toFullPropertyName(String, String) - Static method in class org.apache.hadoop.mapred.QueueManager
 
toHex(byte[]) - Static method in class org.apache.hadoop.mapreduce.security.SecureShuffleUtils
byte array to Hex String
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
A Mapper that maps text values into pairs.
TokenCountMapper() - Constructor for class org.apache.hadoop.mapred.lib.TokenCountMapper
 
tokenSecret - Variable in class org.apache.hadoop.mapred.Task
 
toString() - Method in class org.apache.hadoop.mapred.ClusterStatus.BlackListInfo
 
toString() - Method in class org.apache.hadoop.mapred.FileSplit
 
toString() - Method in class org.apache.hadoop.mapred.MultiFileSplit
 
toString() - Method in class org.apache.hadoop.mapred.Task
 
toString() - Method in enum org.apache.hadoop.mapred.TaskLog.LogName
 
toString() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
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.task.reduce.MapHost
 
toString() - Method in class org.apache.hadoop.mapreduce.task.reduce.MapOutput
 
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
 
totalCounters - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
Deprecated. 
totalMaps - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Deprecated. 
TotalOrderPartitioner<K extends org.apache.hadoop.io.WritableComparable<?>,V> - Class in org.apache.hadoop.mapred.lib
Partitioner effecting a total order by reading split points from an externally generated source.
TotalOrderPartitioner() - Constructor for class org.apache.hadoop.mapred.lib.TotalOrderPartitioner
 
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
 
totalReduces - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Deprecated. 
toWriteSkipRecs() - Method in class org.apache.hadoop.mapred.Task
Get whether to write skip records.
trackerName - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
Deprecated. 
tryDivide(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.mapreduce.lib.db.BigDecimalSplitter
Divide numerator by denominator.
TT_CONTENTION_TRACKING - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_DISTRIBUTED_CACHE_CHECK_PERIOD - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_DNS_INTERFACE - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_DNS_NAMESERVER - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_GROUP - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_HEALTH_CHECKER_INTERVAL - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_HEALTH_CHECKER_SCRIPT_ARGS - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_HEALTH_CHECKER_SCRIPT_PATH - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_HEALTH_CHECKER_SCRIPT_TIMEOUT - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_HOST_NAME - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_HTTP_ADDRESS - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_HTTP_THREADS - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_INDEX_CACHE - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_INSTRUMENTATION - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_KEYTAB_FILE - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_LOCAL_CACHE_KEEP_AROUND_PCT - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
Percentage of the local distributed cache that should be kept in between garbage collection.
TT_LOCAL_CACHE_SIZE - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_LOCAL_CACHE_SUBDIRS_LIMIT - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_LOCAL_DIR_MINSPACE_KILL - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_LOCAL_DIR_MINSPACE_START - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_MAP_SLOTS - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_MAX_TASK_COMPLETION_EVENTS_TO_POLL - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_MEMORY_CALCULATOR_PLUGIN - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
Deprecated. Use TTConfig.TT_RESOURCE_CALCULATOR_PLUGIN instead
TT_MEMORY_MANAGER_MONITORING_INTERVAL - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_OUTOFBAND_HEARBEAT - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_REDUCE_SLOTS - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_REPORT_ADDRESS - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_RESERVED_PHYSCIALMEMORY_MB - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_RESOURCE_CALCULATOR_PLUGIN - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_SLEEP_TIME_BEFORE_SIG_KILL - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_STATIC_RESOLUTIONS - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_TASK_CONTROLLER - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_USER_NAME - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TT_USERLOGCLEANUP_SLEEPTIME - Static variable in interface org.apache.hadoop.mapreduce.server.tasktracker.TTConfig
 
TTConfig - Interface in org.apache.hadoop.mapreduce.server.tasktracker
Place holder for TaskTracker server-level configuration.
TupleWritable - Class in org.apache.hadoop.mapred.join
Writable type storing multiple Writables.
TupleWritable() - Constructor for class org.apache.hadoop.mapred.join.TupleWritable
Create an empty tuple with no allocated storage for writables.
TupleWritable(Writable[]) - Constructor for class org.apache.hadoop.mapred.join.TupleWritable
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.
type - Variable in class org.apache.hadoop.mapreduce.jobhistory.Event
Deprecated. 
TYPE_SEPARATOR - Static variable in interface org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorDescriptor
 
TYPE_SEPARATOR - Static variable in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorDescriptor
 

U

uberized - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobInited
Deprecated. 
ugi - Variable in class org.apache.hadoop.mapreduce.task.JobContextImpl
The UserGroupInformation object that has a reference to the current user
umbilical - Variable in class org.apache.hadoop.mapred.Task
 
UNINITIALIZED_MEMORY_VALUE - Static variable in class org.apache.hadoop.mapred.ClusterStatus
 
UNIQ_VALUE_COUNT - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
 
UNIQ_VALUE_COUNT - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
UniqValueCount - Class in org.apache.hadoop.mapred.lib.aggregate
This class implements a value aggregator that dedupes a sequence of objects.
UniqValueCount() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.UniqValueCount
the default constructor
UniqValueCount(long) - Constructor for class org.apache.hadoop.mapred.lib.aggregate.UniqValueCount
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
Pattern for the default unpacking behavior for job jars
updateCounters(int) - Method in class org.apache.hadoop.mapred.BackupStore
This method is called by the valueIterators after writing the first key and value bytes to the BackupStore
updateCountersForExternalAppend(long) - Method in class org.apache.hadoop.mapred.IFile.Writer
 
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
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
 
USER_LOG_RETAIN_HOURS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
USER_NAME - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
UserDefinedValueAggregatorDescriptor - Class in org.apache.hadoop.mapred.lib.aggregate
This class implements a wrapper for a user defined value aggregator descriptor.
UserDefinedValueAggregatorDescriptor(String, JobConf) - Constructor for class org.apache.hadoop.mapred.lib.aggregate.UserDefinedValueAggregatorDescriptor
 
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 - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Deprecated. 
USERNAME_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
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
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

validateKeyValueTypes(boolean, Configuration, Class<?>, Class<?>, Class<?>, Class<?>, int, String) - Static method in class org.apache.hadoop.mapreduce.lib.chain.Chain
 
value - Variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounter
Deprecated. 
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
 
VALUE_HISTOGRAM - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
ValueAggregator<E> - Interface in org.apache.hadoop.mapred.lib.aggregate
This interface defines the minimal protocol for value aggregators.
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
This class implements the common functionalities of the subclasses of ValueAggregatorDescriptor class.
ValueAggregatorBaseDescriptor() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
 
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
This class implements the generic combiner of Aggregate.
ValueAggregatorCombiner() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
 
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
This interface defines the contract a value aggregator descriptor must support.
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
This is the main class for creating a map/reduce job using Aggregate framework.
ValueAggregatorJob() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
 
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
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.mapred.lib.aggregate.ValueAggregatorJobBase
 
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
This class implements the generic mapper of Aggregate.
ValueAggregatorMapper() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorMapper
 
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
This class implements the generic reducer of Aggregate.
ValueAggregatorReducer() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorReducer
 
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
 
ValueHistogram - Class in org.apache.hadoop.mapred.lib.aggregate
This class implements a value aggregator that computes the histogram of a sequence of strings.
ValueHistogram() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueHistogram
 
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.mapred.FileInputFormat.Counter
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.FileOutputFormat.Counter
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.JobClient.TaskStatusFilter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.JobInProgress.Counter
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.JobPriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.JobTracker.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.join.Parser.TType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.Master.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.QueueACL
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.Task.Counter
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.TaskCompletionEvent.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.TaskLog.LogName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.TaskStatus.Phase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.TaskStatus.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.TIPStatus
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.FileSystemCounter
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.JobACL
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.jobhistory.EventType
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.input.FileInputFormat.Counter
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.lib.input.FileInputFormatCounter
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.lib.output.FileOutputFormat.Counter
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.lib.output.FileOutputFormatCounter
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.task.reduce.MapHost.State
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.
values() - Static method in enum org.apache.hadoop.mapred.FileInputFormat.Counter
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.FileOutputFormat.Counter
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.JobClient.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.mapred.JobInProgress.Counter
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
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.JobTracker.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.mapred.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.mapred.Master.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.mapred.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.hadoop.mapred.PeriodicStatsAccumulator
 
values() - Static method in enum org.apache.hadoop.mapred.QueueACL
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.Task.Counter
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
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.TaskLog.LogName
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.TaskStatus.Phase
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.TaskStatus.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.mapred.TIPStatus
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.FileSystemCounter
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.JobACL
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.jobhistory.EventType
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.input.FileInputFormat.Counter
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.lib.input.FileInputFormatCounter
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.lib.output.FileOutputFormat.Counter
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.lib.output.FileOutputFormatCounter
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.task.reduce.MapHost.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.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.
verifyReply(String, String, SecretKey) - Static method in class org.apache.hadoop.mapreduce.security.SecureShuffleUtils
verify that base64Hash is same as HMacHash(msg)
version() - Method in class org.apache.hadoop.mapreduce.counters.CounterGroupFactory
 
versionID - Static variable in interface org.apache.hadoop.mapred.TaskUmbilicalProtocol
Changed the version to 2, since we have a new method getMapOutputs Changed version to 3 to have progress() return a boolean Changed the version to 4, since we have replaced TaskUmbilicalProtocol.progress(String, float, String, org.apache.hadoop.mapred.TaskStatus.Phase, Counters) with statusUpdate(String, TaskStatus) Version 5 changed counters representation for HADOOP-2248 Version 6 changes the TaskStatus representation for HADOOP-2208 Version 7 changes the done api (via HADOOP-3140).
versionID - Static variable in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
 
violation() - Method in class org.apache.hadoop.mapreduce.counters.Limits
 
vMemKbytes - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
Deprecated. 
vMemKbytes - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
Deprecated. 
vMemKbytes - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
Deprecated. 

W

waitForCompletion() - Method in interface org.apache.hadoop.mapred.RunningJob
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.
waitForResource() - Method in interface org.apache.hadoop.mapreduce.task.reduce.MergeManager
To wait until merge has some freed resources available so that it can accept shuffled data.
waitForResource() - Method in class org.apache.hadoop.mapreduce.task.reduce.MergeManagerImpl
 
WAITING - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
 
waitUntilDone(int) - Method in interface org.apache.hadoop.mapreduce.task.reduce.ShuffleScheduler
Wait until the shuffle finishes or until the timeout.
waitUntilDone(int) - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl
Wait until the shuffle finishes or until the timeout.
WORKDIR - Static variable in interface org.apache.hadoop.mapred.MRConstants
Used in MRv1, mostly in TaskTracker code
WORKDIR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
WORKFLOW_ADJACENCY_PREFIX_PATTERN - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
WORKFLOW_ADJACENCY_PREFIX_PATTERN - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
WORKFLOW_ADJACENCY_PREFIX_STRING - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
WORKFLOW_ADJACENCY_PREFIX_STRING - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
WORKFLOW_ID - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
WORKFLOW_ID - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
WORKFLOW_NAME - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
WORKFLOW_NAME - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
WORKFLOW_NODE_NAME - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
WORKFLOW_NODE_NAME - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
WORKFLOW_TAGS - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
WORKFLOW_TAGS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
workflowAdjacencies - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Deprecated. 
workflowId - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Deprecated. 
workflowName - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Deprecated. 
workflowNodeName - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Deprecated. 
workflowTags - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobSubmitted
Deprecated. 
WORKING_DIR - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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
Proxy class for a RecordReader participating in the join framework.
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(DataInputBuffer, DataInputBuffer) - Method in class org.apache.hadoop.mapred.BackupStore
Write the given K,V to the cache.
write(DataOutput) - Method in class org.apache.hadoop.mapred.ClusterStatus.BlackListInfo
 
write(DataOutput) - Method in class org.apache.hadoop.mapred.ClusterStatus
 
write(DataOutput) - Method in class org.apache.hadoop.mapred.Counters.Counter
 
write(DataOutput) - Method in class org.apache.hadoop.mapred.Counters.Group
 
write(DataOutput) - Method in class org.apache.hadoop.mapred.FileSplit
 
write(byte[], int, int) - Method in class org.apache.hadoop.mapred.IFileOutputStream
Write bytes to the stream.
write(int) - Method in class org.apache.hadoop.mapred.IFileOutputStream
 
write(DataOutput) - Method in class org.apache.hadoop.mapred.JobProfile
 
write(DataOutput) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Write splits in the following format.
write(DataOutput) - Method in class org.apache.hadoop.mapred.JvmTask
 
write(K, V) - Method in class org.apache.hadoop.mapred.lib.FilterOutputFormat.FilterRecordWriter
 
write(int) - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.Buffer
 
write(byte[], int, int) - Method in class org.apache.hadoop.mapred.MapTask.MapOutputBuffer.Buffer
Attempt to write a sequence of bytes to the collection buffer.
write(DataOutput) - Method in class org.apache.hadoop.mapred.MapTask
 
write(DataOutput) - Method in class org.apache.hadoop.mapred.MapTaskCompletionEventsUpdate
 
write(K, V) - Method in interface org.apache.hadoop.mapred.RecordWriter
Writes a key/value pair.
write(DataOutput) - Method in class org.apache.hadoop.mapred.ReduceTask
 
write(DataOutput) - Method in class org.apache.hadoop.mapred.Task
 
write(DataOutput) - Method in class org.apache.hadoop.mapred.TaskStatus
 
write(K, V) - Method in class org.apache.hadoop.mapred.TextOutputFormat.LineRecordWriter
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounterGroup
GenericGroup ::= displayName #counter counter*
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Write the set of groups.
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup.FSCounter
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.counters.FileSystemCounterGroup
FileSystemGroup ::= #scheme (scheme #counter (key value)*)*
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup.FrameworkCounter
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.counters.FrameworkCounterGroup
FrameworkGroup ::= #counter (key value)*
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.counters.GenericCounter
GenericCounter ::= keyName isDistinctDisplayName [displayName] value
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.security.token.JobTokenIdentifier
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.task.reduce.ShuffleHeader
 
write(KEYOUT, VALUEOUT) - Method in class org.apache.hadoop.mapreduce.task.TaskInputOutputContextImpl
Generate an output key/value pair.
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.TaskReport
 
write(DataOutput) - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
 
writeCompressedBytes(DataOutputStream) - Method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat.WritableValueBytes
 
writeFile(RawKeyValueIterator, IFile.Writer<K, V>, Progressable, Configuration) - Static method in class org.apache.hadoop.mapred.Merger
 
writePartitionFile(JobConf, InputSampler.Sampler<K, V>) - Static method in class org.apache.hadoop.mapred.lib.InputSampler
 
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.
writeToFile(Path, JobConf) - Method in class org.apache.hadoop.mapred.SpillRecord
Write this spill record to the location provided.
writeToFile(Path, JobConf, Checksum) - Method in class org.apache.hadoop.mapred.SpillRecord
 
writeUncompressedBytes(DataOutputStream) - Method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat.WritableValueBytes
 
written - Variable in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
 

Y

YARN_FRAMEWORK_NAME - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 

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

Copyright © 2014 Apache Software Foundation. All Rights Reserved.