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
 
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(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.
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 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
 
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
 
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
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_ATTEMPT_ID_ENV - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
APPLICATION_MASTER_CLASS - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
APPLICATION_TOKENS_FILE - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
applicationAttemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.AMStarted
 
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
 
assertAndDestroyProcessGroup(String, long, boolean) - Static method in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
Make sure that the given pid is a process group leader and then destroy the process group.
ATTEMPT - Static variable in class org.apache.hadoop.mapreduce.TaskAttemptID
 
attemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
 
attemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
 
attemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
 
attemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
 
attemptId - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
 
available() - Method in class org.apache.hadoop.mapred.TaskLog.Reader
 
avataar - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
 
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
 
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 interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_ARCHIVES_SIZES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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 interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_FILES_SIZES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_LOCALARCHIVES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
CACHE_LOCALFILES - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
 
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
captureDebugOut(List<String>, File) - Static method in class org.apache.hadoop.mapred.TaskLog
Wrap a command in a shell to capture debug script's stdout and stderr to debugout.
captureOutAndError(List<String>, File, File, long) - Static method in class org.apache.hadoop.mapred.TaskLog
Wrap a command in a shell to capture stdout and stderr to files.
captureOutAndError(List<String>, List<String>, File, File, long) - Static method in class org.apache.hadoop.mapred.TaskLog
Wrap a command in a shell to capture stdout and stderr to files.
captureOutAndError(List<String>, List<String>, File, File, long, String) - Static method in class org.apache.hadoop.mapred.TaskLog
Deprecated. pidFiles are no more used. Instead pid is exported to env variable JVM_PID.
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.
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.
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
 
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
 
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
 
clockSplits - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
 
clockSplits - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
 
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.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(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.DelegatingRecordReader
 
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
 
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
 
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.
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
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
 
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
 
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 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
 
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
 
containerId - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
 
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
 
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 - Static variable in class org.apache.hadoop.mapreduce.counters.Limits
 
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
 
counters - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
 
counters - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
 
counters - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
 
counters - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
 
counters - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
 
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.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 - Static variable in class org.apache.hadoop.mapreduce.counters.Limits
 
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
 
cpuUsages - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
 
cpuUsages - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
 
cpuUsages - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
 
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
 
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.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.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.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.
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.DelegatingInputFormat
 
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.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.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[]) - 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(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
 
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, 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
 
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_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_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_APPLICATION_CLASSPATH - Static variable in interface org.apache.hadoop.mapreduce.MRJobConfig
Default CLASSPATH for all YARN MapReduce applications.
DEFAULT_MAPREDUCE_MINICLUSTER_CONTROL_RESOURCE_MONITORING - Static variable in interface org.apache.hadoop.mapreduce.MRConfig
 
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_LEVEL - 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_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
 
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.
destroy() - Method in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
Destroy the process-tree.
destroy(boolean) - Method in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
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.
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
 
displayName - Variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
 
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
Distribute application-specific large, read-only files efficiently.
DistributedCache() - Constructor for class org.apache.hadoop.filecache.DistributedCache
 
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(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
 
error - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
 
Event - Class in org.apache.hadoop.mapreduce.jobhistory
 
Event() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.Event
 
event - Variable in class org.apache.hadoop.mapreduce.jobhistory.Event
 
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
 
failedFetch() - Method in class org.apache.hadoop.mapreduce.task.reduce.ShuffleClientMetrics
 
failedMaps - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
 
failedReduces - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
 
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.
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
 
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
 
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
 
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
 
finishedMaps - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
 
finishedReduces - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
 
finishedReduces - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobFinished
 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.JobUnsuccessfulCompletion
 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinished
 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFailed
 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskFinished
 
finishTime - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskUpdated
 
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
 
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.
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.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.
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
 
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.MapAttemptFinishedEvent
Get the attempt id
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the attempt id
getAttemptId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Get the task attempt id
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.
getAvailablePhysicalMemorySize() - Method in class org.apache.hadoop.mapreduce.util.LinuxResourceCalculatorPlugin
Obtain the total size of the available physical memory present in the system.
getAvailablePhysicalMemorySize() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin
Obtain the total size of the available physical memory present in the system.
getAvailableVirtualMemorySize() - Method in class org.apache.hadoop.mapreduce.util.LinuxResourceCalculatorPlugin
Obtain the total size of the available virtual memory present in the system.
getAvailableVirtualMemorySize() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin
Obtain the total size of the available virtual memory present in the system.
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
 
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.MapAttemptFinishedEvent
 
getClockSplits() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
 
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.
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
 
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.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.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
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.TaskFailedEvent
Get task counters
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.
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.
getCpuFrequency() - Method in class org.apache.hadoop.mapreduce.util.LinuxResourceCalculatorPlugin
Obtain the CPU frequency of on the system.
getCpuFrequency() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin
Obtain the CPU frequency of on the system.
getCpuUsage() - Method in class org.apache.hadoop.mapreduce.util.LinuxResourceCalculatorPlugin
Obtain the CPU usage % of the machine.
getCpuUsage() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin
Obtain the CPU usage % of the machine.
getCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
 
getCpuUsages() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
 
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
 
getCumulativeCpuTime() - Method in class org.apache.hadoop.mapreduce.util.LinuxResourceCalculatorPlugin
Obtain the cumulative CPU time since the system is on.
getCumulativeCpuTime() - Method in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
Get the CPU time in millisecond used by all the processes in the process-tree since the process-tree created
getCumulativeCpuTime() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin
Obtain the cumulative CPU time since the system is on.
getCumulativeCpuTime() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin.ProcResourceValues
Obtain the cumulative CPU time used by a current process tree.
getCumulativeRssmem() - Method in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
Get the cumulative resident set size (rss) memory used by all the processes in the process-tree.
getCumulativeRssmem(int) - Method in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
Get the cumulative resident set size (rss) memory used by all the processes in the process-tree that are older than the passed in age.
getCumulativeVmem() - Method in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
Get the cumulative virtual memory used by all the processes in the process-tree.
getCumulativeVmem(int) - Method in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
Get the cumulative virtual memory used by all the processes in the process-tree that are older than the passed in age.
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.DelegatingRecordReader
 
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.DelegatingRecordReader
 
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.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.
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.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
 
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.TaskAttemptUnsuccessfulCompletionEvent
Get the error string
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
 
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.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
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.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.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
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.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.JobUnsuccessfulCompletionEvent
Get the number of finished maps
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.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.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.JobUnsuccessfulCompletionEvent
Get the job finish time
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the attempt finish time
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.TaskAttemptFinishedEvent
Get the attempt finish time
getFinishTime() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the finish time
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.TaskFinishedEvent
Get the task finish time
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.
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.
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
 
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.
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
 
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskAttemptInfo
 
getHostname() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
Get the host name
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.TaskAttemptFinishedEvent
Get the host where the attempt executed
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.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
 
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.
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.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.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.JobInfoChangeEvent
Get the Job ID
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobInitedEvent
Get the job ID
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobPriorityChangeEvent
Get the Job ID
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobStatusChangedEvent
Get the Job Id
getJobId() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the Job Id
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.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.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(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
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.JobInfoChangeEvent
Get the Job launch time
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.TaskAttemptStartedEvent
Get the locality
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.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.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.mapreduce.lib.jobcontrol.ControlledJob
 
getMapRunnerClass() - Method in class org.apache.hadoop.mapred.JobConf
Get the MapRunnable class for the job.
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
 
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.AMStartedEvent
 
getNodeManagerHost() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.AMInfo
 
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.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
getNumProcessors() - Method in class org.apache.hadoop.mapreduce.util.LinuxResourceCalculatorPlugin
Obtain the total number of processors present on the system.
getNumProcessors() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin
Obtain the total number of processors present on the system.
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(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.
getPhysicalMemorySize() - Method in class org.apache.hadoop.mapreduce.util.LinuxResourceCalculatorPlugin
Obtain the total size of the physical memory present in the system.
getPhysicalMemorySize() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin
Obtain the total size of the physical memory present in the system.
getPhysicalMemorySize() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin.ProcResourceValues
Obtain the physical memory size used by current process tree.
getPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
 
getPhysMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
 
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.MapAttemptFinishedEvent
Get the tracker rpc port
getPort() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the tracker rpc port
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.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.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.  
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.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.
getProcessTreeDump() - Method in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
Get a dump of the process-tree.
getProcResourceValues() - Method in class org.apache.hadoop.mapreduce.util.LinuxResourceCalculatorPlugin
 
getProcResourceValues() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin
Obtain resource status used by current process tree.
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.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.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.DelegatingRecordReader
 
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.MapAttemptFinishedEvent
Get the rack name
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.TaskAttemptFinishedEvent
Get the rackname where the attempt executed
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.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.FileInputFormat
 
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.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.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.
getResourceCalculatorPlugin(Class<? extends ResourceCalculatorPlugin>, Configuration) - Static method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin
Get the ResourceCalculatorPlugin from the class name and configure it.
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>, 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.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.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.TaskAttemptStartedEvent
Get the shuffle port
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.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.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.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.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.TaskAttemptStartedEvent
Get the start time
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.MapAttemptFinishedEvent
Get the state string
getState() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the state string
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.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.JobInfoChangeEvent
Get the Job submit time
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
 
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(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 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.MapAttemptFinishedEvent
Get the task ID
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the Task ID
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Get the task ID
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the task id
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the task id
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
Get the task id
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent
Get task id
getTaskId() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskStartedEvent
Get the task id
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 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(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) - 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.MapAttemptFinishedEvent
Get the task status
getTaskStatus() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
Get the task status
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.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.ReduceAttemptFinishedEvent
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinishedEvent
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletionEvent
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFailedEvent
Get the task type
getTaskType() - Method in class org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent
Get task type
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
 
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.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.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.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.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.lib.join.Parser.Token
 
getUberized() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.JobInfo
 
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.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 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.
getVirtualMemorySize() - Method in class org.apache.hadoop.mapreduce.util.LinuxResourceCalculatorPlugin
Obtain the total size of the virtual memory present in the system.
getVirtualMemorySize() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin
Obtain the total size of the virtual memory present in the system.
getVirtualMemorySize() - Method in class org.apache.hadoop.mapreduce.util.ResourceCalculatorPlugin.ProcResourceValues
Obtain the virtual memory size used by a current process tree.
getVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent
 
getVMemKbytes() - Method in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinishedEvent
 
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.JobSubmittedEvent
Get the adjacencies of the workflow
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.JobSubmittedEvent
Get the name of the workflow
getWorkflowNodeName() - Method in class org.apache.hadoop.mapreduce.jobhistory.JobSubmittedEvent
Get the node name of the workflow
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
 
GROUP_NAME_MAX - Static variable in class org.apache.hadoop.mapreduce.counters.Limits
 
groups - Variable in class org.apache.hadoop.mapreduce.jobhistory.JhCounters
 
GROUPS_MAX - Static variable in class org.apache.hadoop.mapreduce.counters.Limits
 


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.
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
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
 
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
 
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
 
hostname - Variable in class org.apache.hadoop.mapreduce.jobhistory.ReduceAttemptFinished
 
hostname - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptFinished
 
hostname - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptUnsuccessfulCompletion
 
HostUtil - Class in org.apache.hadoop.mapreduce.util
 
HostUtil() - Constructor for class org.apache.hadoop.mapreduce.util.HostUtil
 
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
 
httpPort - Variable in class org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStarted
 

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(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.DelegatingRecordReader
 
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) - 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_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.mapreduce.lib.partition
Sample from s splits at regular intervals.
InputSampler.IntervalSampler(double) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler.IntervalSampler
Create a new IntervalSampler sampling all splits.
InputSampler.IntervalSampler(double, int) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler.IntervalSampler
Create a new IntervalSampler.
InputSampler.RandomSampler<K,V> - Class in org.apache.hadoop.mapreduce.lib.partition
Sample from random points in the input.
InputSampler.RandomSampler(double, int) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler.RandomSampler
Create a new RandomSampler sampling all splits.
InputSampler.RandomSampler(double, int, int) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler.RandomSampler
Create a new RandomSampler.
InputSampler.Sampler<K,V> - Interface in org.apache.hadoop.mapreduce.lib.partition
Interface to sample using an InputFormat.
InputSampler.SplitSampler<K,V> - Class in org.apache.hadoop.mapreduce.lib.partition
Samples the first n records from s splits.
InputSampler.SplitSampler(int) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler.SplitSampler
Create a SplitSampler sampling all splits.
InputSampler.SplitSampler(int, int) - Constructor for class org.apache.hadoop.mapreduce.lib.partition.InputSampler.SplitSampler
Create a new SplitSampler.
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.
isAlive() - Method in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
Is the root-process alive?
isAnyProcessInTreeAlive() - Method in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
Is any of the subprocesses in the process-tree alive?
isAvailable() - Static method in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
Checks if the ProcfsBasedProcessTree is available on this system.
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.
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.KeyValueTextInputFormat
 
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.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
 
JhCounterGroup - Class in org.apache.hadoop.mapreduce.jobhistory
 
JhCounterGroup() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JhCounterGroup
 
JhCounters - Class in org.apache.hadoop.mapreduce.jobhistory
 
JhCounters() - Constructor for class org.apache.hadoop.mapreduce.jobhistory.JhCounters
 
JIFFY_LENGTH_IN_MILLIS - Static variable in class org.apache.hadoop.mapreduce.util.ProcfsBasedProcessTree
 
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_TOKEN_HDFS_FILE - Static variable in class org.apache.hadoop.mapreduce.security.TokenCache
file name used on HDFS for generated job token
JOB_TOKENS_FILENAME - Static variable in class org.apache.hadoop.mapreduce.security.TokenCache
conf setting for job tokens cache file name
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
 
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