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

A

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.
ABSOLUTE - Static variable in class org.apache.hadoop.metrics.spi.MetricValue
 
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.
AbstractDNSToSwitchMapping - Class in org.apache.hadoop.net
This is a base class for DNS to Switch mappings.
AbstractDNSToSwitchMapping() - Constructor for class org.apache.hadoop.net.AbstractDNSToSwitchMapping
Create an unconfigured instance
AbstractDNSToSwitchMapping(Configuration) - Constructor for class org.apache.hadoop.net.AbstractDNSToSwitchMapping
Create an instance, caching the configuration file.
AbstractFileSystem - Class in org.apache.hadoop.fs
This class provides an interface for implementors of a Hadoop file system (analogous to the VFS of Unix).
AbstractFileSystem(URI, String, boolean, int) - Constructor for class org.apache.hadoop.fs.AbstractFileSystem
Constructor to be called by subclasses.
AbstractMapWritable - Class in org.apache.hadoop.io
Abstract base class for MapWritable and SortedMapWritable Unlike org.apache.nutch.crawl.MapWritable, this class allows creation of MapWritable<Writable, MapWritable> so the CLASS_TO_ID and ID_TO_CLASS maps travel with the class instead of being static.
AbstractMapWritable() - Constructor for class org.apache.hadoop.io.AbstractMapWritable
constructor.
AbstractMetric - Class in org.apache.hadoop.metrics2
The immutable metric
AbstractMetric(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.AbstractMetric
Construct the metric
AbstractMetricsContext - Class in org.apache.hadoop.metrics.spi
The main class of the Service Provider Interface.
AbstractMetricsContext() - Constructor for class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Creates a new instance of AbstractMetricsContext
accept(Path) - Method in class org.apache.hadoop.fs.GlobFilter
 
accept(Path) - Method in interface org.apache.hadoop.fs.PathFilter
Tests whether or not the specified abstract pathname should be included in a pathname list.
accept(Class<?>) - Method in class org.apache.hadoop.io.serializer.avro.AvroReflectSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.io.serializer.avro.AvroSpecificSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.io.serializer.JavaSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.io.serializer.WritableSerialization
 
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(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).
accepts(String) - Method in class org.apache.hadoop.metrics2.MetricsFilter
Whether to accept the name
accepts(MetricsTag) - Method in class org.apache.hadoop.metrics2.MetricsFilter
Whether to accept the tag
accepts(Iterable<MetricsTag>) - Method in class org.apache.hadoop.metrics2.MetricsFilter
Whether to accept the tags
accepts(MetricsRecord) - Method in class org.apache.hadoop.metrics2.MetricsFilter
Whether to accept the record
AccessControlException - Exception in org.apache.hadoop.fs.permission
Deprecated.
Use AccessControlException instead.
AccessControlException() - Constructor for exception org.apache.hadoop.fs.permission.AccessControlException
Deprecated.
Default constructor is needed for unwrapping from RemoteException.
AccessControlException(String) - Constructor for exception org.apache.hadoop.fs.permission.AccessControlException
Deprecated.
Constructs an AccessControlException with the specified detail message.
AccessControlException(Throwable) - Constructor for exception org.apache.hadoop.fs.permission.AccessControlException
Deprecated.
Constructs a new exception with the specified cause and a detail message of (cause==null ? null : cause.toString()) (which typically contains the class and detail message of cause).
add(E) - Method in class org.apache.hadoop.io.EnumSetWritable
 
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(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(T) - Method in interface org.apache.hadoop.mapreduce.lib.join.ResetableIterator
Add an element to the collection of elements to iterate over.
add(X) - Method in class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
 
add(String, long) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Add sample to a stat metric by name.
add(String, long) - Method in class org.apache.hadoop.metrics2.lib.MutableRates
Add a rate sample for a rate metric
add(long, long) - Method in class org.apache.hadoop.metrics2.lib.MutableStat
Add a number of samples and their sum to the running stat
add(long) - Method in class org.apache.hadoop.metrics2.lib.MutableStat
Add a snapshot to the metric
add(MetricsTag) - Method in class org.apache.hadoop.metrics2.MetricsRecordBuilder
Add an immutable metrics tag object
add(AbstractMetric) - Method in class org.apache.hadoop.metrics2.MetricsRecordBuilder
Add a pre-made immutable metric object
add(Key) - Method in class org.apache.hadoop.util.bloom.BloomFilter
 
add(Key) - Method in class org.apache.hadoop.util.bloom.CountingBloomFilter
 
add(Key) - Method in class org.apache.hadoop.util.bloom.DynamicBloomFilter
 
add(Key) - Method in class org.apache.hadoop.util.bloom.RetouchedBloomFilter
 
add_escapes(String) - Method in exception org.apache.hadoop.record.compiler.generated.ParseException
Deprecated.
Used to convert raw characters to their escaped version when these raw version cannot be used as part of an ASCII string literal.
addAllAsks(List<ResourceRequest>) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
Add list of ResourceRequest to update the ResourceManager about the application's resource requirements.
addAllReleases(List<ContainerId>) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
Add the list of ContainerId of containers being released by the ApplicationMaster
addAllServiceResponse(Map<String, ByteBuffer>) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.StartContainerResponse
Add to the list of auxiliary services which have been started on the NodeManager.
addArchiveToClassPath(Path) - Method in class org.apache.hadoop.mapreduce.Job
Add an archive path to the current set of classpath entries.
addAsk(ResourceRequest) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
addCacheArchive(URI) - Method in class org.apache.hadoop.mapreduce.Job
Add a archives to be localized
addCacheFile(URI) - Method in class org.apache.hadoop.mapreduce.Job
Add a file to be localized
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(MetricsInfo, int) - Method in class org.apache.hadoop.metrics2.MetricsRecordBuilder
Add an integer metric
addCounter(MetricsInfo, long) - Method in class org.apache.hadoop.metrics2.MetricsRecordBuilder
Add an long metric
addDefaultResource(String) - Static method in class org.apache.hadoop.conf.Configuration
Add a default resource.
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.
addDelegationTokens(String, Credentials) - Method in class org.apache.hadoop.fs.FileSystem
Obtain all delegation tokens used by this FileSystem that are not already present in the given Credentials.
addDependingJob(ControlledJob) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Add a job to this jobs' dependency list.
addDeprecation(String, String[], String) - Static method in class org.apache.hadoop.conf.Configuration
addDeprecation(String, String, String) - Static method in class org.apache.hadoop.conf.Configuration
Adds the deprecated key to the deprecation map.
addDeprecation(String, String[]) - Static method in class org.apache.hadoop.conf.Configuration
addDeprecation(String, String) - Static method in class org.apache.hadoop.conf.Configuration
Adds the deprecated key to the deprecation map when no custom message is provided.
addEscapes(String) - Static method in error org.apache.hadoop.record.compiler.generated.TokenMgrError
Deprecated.
Replaces unprintable characters by their espaced (or unicode escaped) equivalents in the given string
addFalsePositive(Key) - Method in class org.apache.hadoop.util.bloom.RetouchedBloomFilter
Adds a false positive information to this retouched Bloom filter.
addFalsePositive(Collection<Key>) - Method in class org.apache.hadoop.util.bloom.RetouchedBloomFilter
Adds a collection of false positive information to this retouched Bloom filter.
addFalsePositive(List<Key>) - Method in class org.apache.hadoop.util.bloom.RetouchedBloomFilter
Adds a list of false positive information to this retouched Bloom filter.
addFalsePositive(Key[]) - Method in class org.apache.hadoop.util.bloom.RetouchedBloomFilter
Adds an array of false positive information to this retouched Bloom filter.
addField(String, TypeID) - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
Deprecated.
Add a field.
addFileset(FileSet) - Method in class org.apache.hadoop.record.compiler.ant.RccTask
Deprecated.
Adds a fileset that can consist of one or more files
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.
addGauge(MetricsInfo, int) - Method in class org.apache.hadoop.metrics2.MetricsRecordBuilder
Add a integer gauge metric
addGauge(MetricsInfo, long) - Method in class org.apache.hadoop.metrics2.MetricsRecordBuilder
Add a long gauge metric
addGauge(MetricsInfo, float) - Method in class org.apache.hadoop.metrics2.MetricsRecordBuilder
Add a float gauge metric
addGauge(MetricsInfo, double) - Method in class org.apache.hadoop.metrics2.MetricsRecordBuilder
Add a double gauge metric
addGroup(G) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Add a group.
addGroup(String, String) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Add a new group
addIdentifier(String, Class<?>[], Class<? extends Parser.Node>, Class<? extends ComposableRecordReader>) - Static method in class org.apache.hadoop.mapred.join.Parser.Node
For a given identifier, add a mapping to the nodetype for the parse tree and to the ComposableRecordReader to be created, including the formals required to invoke the constructor.
addIdentifier(String, Class<?>[], Class<? extends Parser.Node>, Class<? extends ComposableRecordReader>) - Static method in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
For a given identifier, add a mapping to the nodetype for the parse tree and to the ComposableRecordReader to be created, including the formals required to invoke the constructor.
addInputPath(JobConf, Path) - Static method in class org.apache.hadoop.mapred.FileInputFormat
Add a Path to the list of inputs for the map-reduce job.
addInputPath(JobConf, Path, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.mapred.lib.MultipleInputs
Add a Path with a custom InputFormat to the list of inputs for the map-reduce job.
addInputPath(JobConf, Path, Class<? extends InputFormat>, Class<? extends Mapper>) - Static method in class org.apache.hadoop.mapred.lib.MultipleInputs
Add a Path with a custom InputFormat and Mapper to the list of inputs for the map-reduce job.
addInputPath(Job, Path) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Add a Path to the list of inputs for the map-reduce job.
addInputPath(Job, Path, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.mapreduce.lib.input.MultipleInputs
Add a Path with a custom InputFormat to the list of inputs for the map-reduce job.
addInputPath(Job, Path, Class<? extends InputFormat>, Class<? extends Mapper>) - Static method in class org.apache.hadoop.mapreduce.lib.input.MultipleInputs
Add a Path with a custom InputFormat and Mapper to the list of inputs for the map-reduce job.
addInputPathRecursively(List<FileStatus>, FileSystem, Path, PathFilter) - Method in class org.apache.hadoop.mapred.FileInputFormat
Add files in the input path recursively into the results.
addInputPathRecursively(List<FileStatus>, FileSystem, Path, PathFilter) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Add files in the input path recursively into the results.
addInputPaths(JobConf, String) - Static method in class org.apache.hadoop.mapred.FileInputFormat
Add the given comma separated paths to the list of inputs for the map-reduce job.
addInputPaths(Job, String) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Add the given comma separated paths to the list of inputs for the map-reduce job.
addJob(ControlledJob) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
Add a new 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
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(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.
addRecord(String) - Method in interface org.apache.hadoop.metrics2.MetricsCollector
Add a metrics record
addRecord(MetricsInfo) - Method in interface org.apache.hadoop.metrics2.MetricsCollector
Add a metrics record
addRelease(ContainerId) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
addResource(String) - Method in class org.apache.hadoop.conf.Configuration
Add a configuration resource.
addResource(URL) - Method in class org.apache.hadoop.conf.Configuration
Add a configuration resource.
addResource(Path) - Method in class org.apache.hadoop.conf.Configuration
Add a configuration resource.
addResource(InputStream) - Method in class org.apache.hadoop.conf.Configuration
Add a configuration resource.
addResource(InputStream, String) - Method in class org.apache.hadoop.conf.Configuration
Add a configuration resource.
addToMap(Class) - Method in class org.apache.hadoop.io.AbstractMapWritable
Add a Class to the maps if it is not already present.
adjustBeginLineColumn(int, int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
Method to adjust line and column numbers for the start of a token.
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
 
allocate(AllocateRequest) - Method in interface org.apache.hadoop.yarn.api.AMRMProtocol
The main interface between an ApplicationMaster and the ResourceManager.
AllocateRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The core request sent by the ApplicationMaster to the ResourceManager to obtain resources in the cluster.
AllocateResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager the ApplicationMaster during resource negotiation.
AMResponse - Interface in org.apache.hadoop.yarn.api.records
The response sent by the ResourceManager the ApplicationMaster during resource negotiation.
AMRMProtocol - Interface in org.apache.hadoop.yarn.api
The protocol between a live instance of ApplicationMaster and the ResourceManager.
and(Filter) - Method in class org.apache.hadoop.util.bloom.BloomFilter
 
and(Filter) - Method in class org.apache.hadoop.util.bloom.CountingBloomFilter
 
and(Filter) - Method in class org.apache.hadoop.util.bloom.DynamicBloomFilter
 
append(Path, int, Progressable) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
Append to an existing file (optional operation).
append(Path) - Method in class org.apache.hadoop.fs.FileSystem
Append to an existing file (optional operation).
append(Path, int) - Method in class org.apache.hadoop.fs.FileSystem
Append to an existing file (optional operation).
append(Path, int, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
Append to an existing file (optional operation).
append(Path, int, Progressable) - Method in class org.apache.hadoop.fs.FilterFileSystem
Append to an existing file (optional operation).
append(Path, int, Progressable) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
This optional operation is not yet supported.
append(Path, int, Progressable) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
append(Path, int, Progressable) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
Append to an existing file (optional operation).
append(Path, int, Progressable) - Method in class org.apache.hadoop.fs.s3.S3FileSystem
This optional operation is not yet supported.
append(Path, int, Progressable) - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
This optional operation is not yet supported.
append(Path, int, Progressable) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
append(byte[], int, int) - Method in class org.apache.hadoop.io.Text
Append a range of bytes to the end of the given text
append(LoggingEvent) - Method in class org.apache.hadoop.log.metrics.EventCounter
 
append(byte[], int, int) - Method in class org.apache.hadoop.record.Buffer
Deprecated.
Append specified bytes to the buffer.
append(byte[]) - Method in class org.apache.hadoop.record.Buffer
Deprecated.
Append specified bytes to the buffer
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.
ApplicationAccessType - Enum in org.apache.hadoop.yarn.api.records
Application access types.
ApplicationAttemptId - Class in org.apache.hadoop.yarn.api.records
ApplicationAttemptId denotes the particular attempt of an ApplicationMaster for a given ApplicationId.
ApplicationAttemptId() - Constructor for class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
 
ApplicationClassLoader - Class in org.apache.hadoop.yarn.util
A URLClassLoader for YARN application isolation.
ApplicationClassLoader(URL[], ClassLoader, List<String>) - Constructor for class org.apache.hadoop.yarn.util.ApplicationClassLoader
 
ApplicationClassLoader(String, ClassLoader, List<String>) - Constructor for class org.apache.hadoop.yarn.util.ApplicationClassLoader
 
ApplicationId - Class in org.apache.hadoop.yarn.api.records
ApplicationId represents the globally unique identifier for an application.
ApplicationId() - Constructor for class org.apache.hadoop.yarn.api.records.ApplicationId
 
ApplicationMaster - Class in org.apache.hadoop.yarn.applications.distributedshell
An ApplicationMaster for executing shell commands on a set of launched containers using the YARN framework.
ApplicationMaster() - Constructor for class org.apache.hadoop.yarn.applications.distributedshell.ApplicationMaster
 
ApplicationReport - Interface in org.apache.hadoop.yarn.api.records
ApplicationReport is a report of an application.
ApplicationResourceUsageReport - Interface in org.apache.hadoop.yarn.api.records
Contains various scheduling metrics to be reported by UI and CLI.
ApplicationSubmissionContext - Interface in org.apache.hadoop.yarn.api.records
ApplicationSubmissionContext represents all of the information needed by the ResourceManager to launch the ApplicationMaster for an application.
applyUMask(FsPermission) - Method in class org.apache.hadoop.fs.permission.FsPermission
Apply a umask to this permission and return a new one
approximateCount(Key) - Method in class org.apache.hadoop.util.bloom.CountingBloomFilter
This method calculates an approximate count of the key, i.e.
ArrayFile - Class in org.apache.hadoop.io
A dense file-based mapping from integers to values.
ArrayFile() - Constructor for class org.apache.hadoop.io.ArrayFile
 
ArrayListBackedIterator<X extends 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 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
 
ArrayPrimitiveWritable - Class in org.apache.hadoop.io
This is a wrapper class.
ArrayPrimitiveWritable() - Constructor for class org.apache.hadoop.io.ArrayPrimitiveWritable
Construct an empty instance, for use during Writable read
ArrayPrimitiveWritable(Class<?>) - Constructor for class org.apache.hadoop.io.ArrayPrimitiveWritable
Construct an instance of known type but no value yet for use with type-specific wrapper classes
ArrayPrimitiveWritable(Object) - Constructor for class org.apache.hadoop.io.ArrayPrimitiveWritable
Wrap an existing array of primitives
ArrayWritable - Class in org.apache.hadoop.io
A Writable for arrays containing instances of a class.
ArrayWritable(Class<? extends Writable>) - Constructor for class org.apache.hadoop.io.ArrayWritable
 
ArrayWritable(Class<? extends Writable>, Writable[]) - Constructor for class org.apache.hadoop.io.ArrayWritable
 
ArrayWritable(String[]) - Constructor for class org.apache.hadoop.io.ArrayWritable
 
ATTEMPT - Static variable in class org.apache.hadoop.mapreduce.TaskAttemptID
 
available() - Method in class org.apache.hadoop.io.compress.DecompressorStream
 
AVRO_REFLECT_PACKAGES - Static variable in class org.apache.hadoop.io.serializer.avro.AvroReflectSerialization
Key to configure packages that contain classes to be serialized and deserialized using this class.
AVRO_SCHEMA_KEY - Static variable in class org.apache.hadoop.io.serializer.avro.AvroSerialization
 
AvroFSInput - Class in org.apache.hadoop.fs
Adapts an FSDataInputStream to Avro's SeekableInput interface.
AvroFSInput(FSDataInputStream, long) - Constructor for class org.apache.hadoop.fs.AvroFSInput
Construct given an FSDataInputStream and its length.
AvroFSInput(FileContext, Path) - Constructor for class org.apache.hadoop.fs.AvroFSInput
Construct given a FileContext and a Path.
AvroReflectSerializable - Interface in org.apache.hadoop.io.serializer.avro
Tag interface for Avro 'reflect' serializable classes.
AvroReflectSerialization - Class in org.apache.hadoop.io.serializer.avro
Serialization for Avro Reflect classes.
AvroReflectSerialization() - Constructor for class org.apache.hadoop.io.serializer.avro.AvroReflectSerialization
 
AvroSerialization<T> - Class in org.apache.hadoop.io.serializer.avro
Base class for providing serialization to Avro types.
AvroSerialization() - Constructor for class org.apache.hadoop.io.serializer.avro.AvroSerialization
 
AvroSpecificSerialization - Class in org.apache.hadoop.io.serializer.avro
Serialization for Avro Specific classes.
AvroSpecificSerialization() - Constructor for class org.apache.hadoop.io.serializer.avro.AvroSpecificSerialization
 

B

backup(int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
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
 
beginColumn - Variable in class org.apache.hadoop.record.compiler.generated.Token
Deprecated.
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
beginLine - Variable in class org.apache.hadoop.record.compiler.generated.Token
Deprecated.
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
BeginToken() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
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
 
BinaryComparable - Class in org.apache.hadoop.io
Interface supported by WritableComparable types supporting ordering/permutation by a representative set of bytes.
BinaryComparable() - Constructor for class org.apache.hadoop.io.BinaryComparable
 
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
 
BinaryRecordInput - Class in org.apache.hadoop.record
Deprecated.
Replaced by Avro.
BinaryRecordInput(InputStream) - Constructor for class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
Creates a new instance of BinaryRecordInput
BinaryRecordInput(DataInput) - Constructor for class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
Creates a new instance of BinaryRecordInput
BinaryRecordOutput - Class in org.apache.hadoop.record
Deprecated.
Replaced by Avro.
BinaryRecordOutput(OutputStream) - Constructor for class org.apache.hadoop.record.BinaryRecordOutput
Deprecated.
Creates a new instance of BinaryRecordOutput
BinaryRecordOutput(DataOutput) - Constructor for class org.apache.hadoop.record.BinaryRecordOutput
Deprecated.
Creates a new instance of BinaryRecordOutput
BlockCompressorStream - Class in org.apache.hadoop.io.compress
A CompressorStream which works with 'block-based' based compression algorithms, as opposed to 'stream-based' compression algorithms.
BlockCompressorStream(OutputStream, Compressor, int, int) - Constructor for class org.apache.hadoop.io.compress.BlockCompressorStream
BlockCompressorStream(OutputStream, Compressor) - Constructor for class org.apache.hadoop.io.compress.BlockCompressorStream
Create a BlockCompressorStream with given output-stream and compressor.
BlockDecompressorStream - Class in org.apache.hadoop.io.compress
A DecompressorStream which works with 'block-based' based compression algorithms, as opposed to 'stream-based' compression algorithms.
BlockDecompressorStream(InputStream, Decompressor, int) - Constructor for class org.apache.hadoop.io.compress.BlockDecompressorStream
BlockDecompressorStream(InputStream, Decompressor) - Constructor for class org.apache.hadoop.io.compress.BlockDecompressorStream
BlockDecompressorStream(InputStream) - Constructor for class org.apache.hadoop.io.compress.BlockDecompressorStream
 
BlockLocation - Class in org.apache.hadoop.fs
 
BlockLocation() - Constructor for class org.apache.hadoop.fs.BlockLocation
Default Constructor
BlockLocation(String[], String[], long, long) - Constructor for class org.apache.hadoop.fs.BlockLocation
Constructor with host, name, offset and length
BlockLocation(String[], String[], long, long, boolean) - Constructor for class org.apache.hadoop.fs.BlockLocation
Constructor with host, name, offset, length and corrupt flag
BlockLocation(String[], String[], String[], long, long) - Constructor for class org.apache.hadoop.fs.BlockLocation
Constructor with host, name, network topology, offset and length
BlockLocation(String[], String[], String[], long, long, boolean) - Constructor for class org.apache.hadoop.fs.BlockLocation
Constructor with host, name, network topology, offset, length and corrupt flag
BLOOM_FILE_NAME - Static variable in class org.apache.hadoop.io.BloomMapFile
 
BloomFilter - Class in org.apache.hadoop.util.bloom
Implements a Bloom filter, as defined by Bloom in 1970.
BloomFilter() - Constructor for class org.apache.hadoop.util.bloom.BloomFilter
Default constructor - use with readFields
BloomFilter(int, int, int) - Constructor for class org.apache.hadoop.util.bloom.BloomFilter
Constructor
BloomMapFile - Class in org.apache.hadoop.io
This class extends MapFile and provides very much the same functionality.
BloomMapFile() - Constructor for class org.apache.hadoop.io.BloomMapFile
 
BOOLEAN_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
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
 
BooleanWritable - Class in org.apache.hadoop.io
A WritableComparable for booleans.
BooleanWritable() - Constructor for class org.apache.hadoop.io.BooleanWritable
 
BooleanWritable(boolean) - Constructor for class org.apache.hadoop.io.BooleanWritable
 
BoolTypeID - Static variable in class org.apache.hadoop.record.meta.TypeID
Deprecated.
Constant classes for the basic types, so we can share them.
bufcolumn - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
buffer - Variable in class org.apache.hadoop.io.compress.CompressorStream
 
buffer - Variable in class org.apache.hadoop.io.compress.DecompressorStream
 
buffer() - Method in interface org.apache.hadoop.io.file.tfile.RawComparable
Get the underlying byte array.
buffer - Variable in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
Buffer - Class in org.apache.hadoop.record
Deprecated.
Replaced by Avro.
Buffer() - Constructor for class org.apache.hadoop.record.Buffer
Deprecated.
Create a zero-count sequence.
Buffer(byte[]) - Constructor for class org.apache.hadoop.record.Buffer
Deprecated.
Create a Buffer using the byte array as the initial value.
Buffer(byte[], int, int) - Constructor for class org.apache.hadoop.record.Buffer
Deprecated.
Create a Buffer using the byte range as the initial value.
buffer - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
BUFFER_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
BufferTypeID - Static variable in class org.apache.hadoop.record.meta.TypeID
Deprecated.
 
bufline - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
bufpos - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
BYTE_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
bytesToCodePoint(ByteBuffer) - Static method in class org.apache.hadoop.io.Text
Returns the next code point at the current position in the buffer.
BytesWritable - Class in org.apache.hadoop.io
A byte sequence that is usable as a key or value.
BytesWritable() - Constructor for class org.apache.hadoop.io.BytesWritable
Create a zero-size sequence.
BytesWritable(byte[]) - Constructor for class org.apache.hadoop.io.BytesWritable
Create a BytesWritable using the byte array as the initial value.
BytesWritable(byte[], int) - Constructor for class org.apache.hadoop.io.BytesWritable
Create a BytesWritable using the byte array as the initial value and length as the length.
ByteTypeID - Static variable in class org.apache.hadoop.record.meta.TypeID
Deprecated.
 
ByteWritable - Class in org.apache.hadoop.io
A WritableComparable for a single byte.
ByteWritable() - Constructor for class org.apache.hadoop.io.ByteWritable
 
ByteWritable(byte) - Constructor for class org.apache.hadoop.io.ByteWritable
 
BZip2Codec - Class in org.apache.hadoop.io.compress
This class provides output and input streams for bzip2 compression and decompression.
BZip2Codec() - Constructor for class org.apache.hadoop.io.compress.BZip2Codec
Creates a new instance of BZip2Codec.

C

CachedDNSToSwitchMapping - Class in org.apache.hadoop.net
A cached implementation of DNSToSwitchMapping that takes an raw DNSToSwitchMapping and stores the resolved network location in a cache.
CachedDNSToSwitchMapping(DNSToSwitchMapping) - Constructor for class org.apache.hadoop.net.CachedDNSToSwitchMapping
cache a raw DNS mapping
cacheGroupsAdd(List<String>) - Method in interface org.apache.hadoop.security.GroupMappingServiceProvider
Caches the group user information
cacheGroupsRefresh() - Method in interface org.apache.hadoop.security.GroupMappingServiceProvider
Refresh the cache of groups and user mapping
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(CancelDelegationTokenRequest) - Method in interface org.apache.hadoop.yarn.api.ClientRMProtocol
Cancel an existing delegation token.
CancelDelegationTokenRequest - Interface in org.apache.hadoop.mapreduce.v2.api.protocolrecords
The request issued by the client to the ResourceManager to cancel a delegation token.
CancelDelegationTokenRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The request issued by the client to the ResourceManager to cancel a delegation token.
CancelDelegationTokenResponse - Interface in org.apache.hadoop.mapreduce.v2.api.protocolrecords
The response from the ResourceManager to a cancelDelegationToken request.
CancelDelegationTokenResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response from the ResourceManager to a cancelDelegationToken request.
cancelDeleteOnExit(Path) - Method in class org.apache.hadoop.fs.FileSystem
Cancel the deletion of the path when the FileSystem is closed
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
 
changed() - Method in class org.apache.hadoop.metrics2.lib.MutableMetric
 
charAt(int) - Method in class org.apache.hadoop.io.Text
Returns the Unicode Scalar Value (32-bit integer value) for the character at position.
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.
checkPath(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Check that a Path belongs to this FileSystem.
checkPath(Path) - Method in class org.apache.hadoop.fs.FileSystem
Check that a Path belongs to this FileSystem.
checkPath(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
Check that a Path belongs to this FileSystem.
checkpoint() - Method in class org.apache.hadoop.fs.Trash
Create a trash checkpoint.
checkScheme(URI, String) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Check that the Uri's scheme matches
checkStream() - Method in class org.apache.hadoop.io.compress.DecompressorStream
 
ChecksumException - Exception in org.apache.hadoop.fs
Thrown for checksum errors.
ChecksumException(String, long) - Constructor for exception org.apache.hadoop.fs.ChecksumException
 
ChecksumFileSystem - Class in org.apache.hadoop.fs
Abstract Checksumed FileSystem.
ChecksumFileSystem(FileSystem) - Constructor for class org.apache.hadoop.fs.ChecksumFileSystem
 
chmod(String, String) - Static method in class org.apache.hadoop.fs.FileUtil
Change the permissions on a filename.
chmod(String, String, boolean) - Static method in class org.apache.hadoop.fs.FileUtil
Change the permissions on a file / directory, recursively, if needed.
cleanup(Log, Closeable...) - Static method in class org.apache.hadoop.io.IOUtils
Close the Closeable objects and ignore any IOException or null pointers.
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
cleanupJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
cleanupJob(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Deprecated.
cleanupJob(JobContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
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.conf.Configuration
Clears all keys from the configuration.
clear() - Method in class org.apache.hadoop.io.MapWritable
clear() - Method in class org.apache.hadoop.io.SortedMapWritable
clear() - Method in class org.apache.hadoop.io.Text
Clear the string to empty.
clear() - Method in class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
 
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.StreamBackedIterator
 
clear() - Method in class org.apache.hadoop.util.bloom.HashFunction
Clears this hash function.
clearAsks() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
clearChanged() - Method in class org.apache.hadoop.metrics2.lib.MutableMetric
Clear the changed flag in the snapshot operations
clearMark() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
 
clearReleases() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
clearServiceResponse() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.StartContainerResponse
Remove all the auxiliary services from the StartContainerResponse object
clearStatistics() - Static method in class org.apache.hadoop.fs.AbstractFileSystem
 
clearStatistics() - Static method in class org.apache.hadoop.fs.FileContext
Clears all the statistics stored in AbstractFileSystem, for all the file systems.
clearStatistics() - Static method in class org.apache.hadoop.fs.FileSystem
Reset all statistics for all file systems
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
 
Client - Class in org.apache.hadoop.yarn.applications.distributedshell
Client for Distributed Shell application submission to YARN.
Client(Configuration) - Constructor for class org.apache.hadoop.yarn.applications.distributedshell.Client
 
Client() - Constructor for class org.apache.hadoop.yarn.applications.distributedshell.Client
 
ClientRMProtocol - Interface in org.apache.hadoop.yarn.api
The protocol between clients and the ResourceManager to submit/abort jobs and to get information on applications, cluster metrics, nodes, queues and ACLs.
clone(T, Configuration) - Static method in class org.apache.hadoop.io.WritableUtils
Make a copy of a writable object using serialization to a buffer.
clone() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
clone() - Method in class org.apache.hadoop.record.Buffer
Deprecated.
 
cloneInto(Writable, Writable) - Static method in class org.apache.hadoop.io.WritableUtils
Deprecated.
use ReflectionUtils.cloneInto instead.
cloneWritableInto(Writable, Writable) - Static method in class org.apache.hadoop.util.ReflectionUtils
Deprecated.
close() - Method in class org.apache.hadoop.fs.AvroFSInput
 
close() - Method in class org.apache.hadoop.fs.FileSystem
No more filesystem operations are needed.
close() - Method in class org.apache.hadoop.fs.FilterFileSystem
 
close() - Method in class org.apache.hadoop.fs.FSDataOutputStream
Close the underlying output stream.
close() - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
close() - Method in class org.apache.hadoop.io.compress.CompressionInputStream
 
close() - Method in class org.apache.hadoop.io.compress.CompressionOutputStream
 
close() - Method in class org.apache.hadoop.io.compress.CompressorStream
 
close() - Method in class org.apache.hadoop.io.compress.DecompressorStream
 
close() - Method in class org.apache.hadoop.io.DefaultStringifier
 
close() - Method in interface org.apache.hadoop.io.Stringifier
Closes this object.
close() - Method in class org.apache.hadoop.log.metrics.EventCounter
 
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.WrappedRecordReader
Forward close request to proxied RR.
close() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
 
close() - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Do nothing.
close() - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
 
close() - Method in class org.apache.hadoop.mapred.lib.ChainMapper
Closes the ChainMapper and all the Mappers in the chain.
close() - Method in class org.apache.hadoop.mapred.lib.ChainReducer
Closes the ChainReducer, the Reducer and all the Mappers in the chain.
close() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
close() - Method in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
 
close() - Method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Closes all the opened named outputs.
close() - Method in class org.apache.hadoop.mapred.MapReduceBase
Default implementation that does nothing.
close() - Method in interface org.apache.hadoop.mapred.RecordReader
Close this InputSplit to future operations.
close(Reporter) - Method in interface org.apache.hadoop.mapred.RecordWriter
Close this RecordWriter to future operations.
close() - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
 
close() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
close() - Method in class org.apache.hadoop.mapreduce.Cluster
Close the Cluster.
close() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Close the record reader.
close() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
close() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
close() - Method in class org.apache.hadoop.mapreduce.lib.input.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 interface org.apache.hadoop.mapreduce.lib.join.ResetableIterator
Close datasources and release resources.
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() - Method in class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
Closes all the opened outputs.
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.metrics.ganglia.GangliaContext
method to close the datagram socket
close() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Stops monitoring and frees buffered data, returning this object to its initial state.
close() - Method in class org.apache.hadoop.metrics.spi.CompositeContext
 
Closeable - Interface in org.apache.hadoop.io
Deprecated.
use java.io.Closeable
closeAll() - Static method in class org.apache.hadoop.fs.FileSystem
Close all cached filesystems.
closeAllForUGI(UserGroupInformation) - Static method in class org.apache.hadoop.fs.FileSystem
Close all cached filesystems for a given UGI.
closeConnection() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
closed - Variable in class org.apache.hadoop.io.compress.CompressorStream
 
closed - Variable in class org.apache.hadoop.io.compress.DecompressorStream
 
closeSocket(Socket) - Static method in class org.apache.hadoop.io.IOUtils
Closes the socket ignoring IOException
closeStream(Closeable) - Static method in class org.apache.hadoop.io.IOUtils
Closes the stream ignoring IOException.
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
 
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.
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
 
CodeBuffer - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
CodecPool - Class in org.apache.hadoop.io.compress
A global compressor/decompressor pool used to save and reuse (possibly native) compression/decompression codecs.
CodecPool() - Constructor for class org.apache.hadoop.io.compress.CodecPool
 
collect(K, V) - Method in interface org.apache.hadoop.mapred.OutputCollector
Adds a key/value pair to the output.
column - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
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(Object[], TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.InnerJoinRecordReader
Return true iff the tuple is full (all data sources contain this key).
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader
Default implementation offers MultiFilterRecordReader.emit(org.apache.hadoop.mapreduce.lib.join.TupleWritable) every Tuple from the collector (the outer join of child RRs).
combine(Object[], TupleWritable) - Method in class org.apache.hadoop.mapreduce.lib.join.OuterJoinRecordReader
Emit everything from the collector.
CombineFileInputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
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
COMMA_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
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.
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.
CommonConfigurationKeysPublic - Class in org.apache.hadoop.fs
This class contains constants for configuration keys used in the common code.
CommonConfigurationKeysPublic() - Constructor for class org.apache.hadoop.fs.CommonConfigurationKeysPublic
 
comparator() - Method in class org.apache.hadoop.io.SortedMapWritable
COMPARATOR_JCLASS - Static variable in class org.apache.hadoop.io.file.tfile.TFile
comparator prefix: java class
COMPARATOR_MEMCMP - Static variable in class org.apache.hadoop.io.file.tfile.TFile
comparator: memcmp
COMPARATOR_OPTIONS - Static variable in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
 
compare(byte[], int, int, byte[], int, int) - Method in interface org.apache.hadoop.io.RawComparator
Compare two objects in binary.
compare(T, T) - Method in class org.apache.hadoop.io.serializer.JavaSerializationComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.io.WritableComparator
Optimization hook.
compare(WritableComparable, WritableComparable) - Method in class org.apache.hadoop.io.WritableComparator
Compare two WritableComparables.
compare(Object, Object) - Method in class org.apache.hadoop.io.WritableComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.record.RecordComparator
Deprecated.
 
compareBytes(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.io.WritableComparator
Lexicographic order of binary data.
compareBytes(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.record.Utils
Deprecated.
Lexicographic order of binary data.
compareTo(Object) - Method in class org.apache.hadoop.fs.FileStatus
Compare this object to another object
compareTo(Object) - Method in class org.apache.hadoop.fs.LocatedFileStatus
Compare this object to another object
compareTo(Object) - Method in class org.apache.hadoop.fs.Path
 
compareTo(BinaryComparable) - Method in class org.apache.hadoop.io.BinaryComparable
Compare bytes from {#getBytes()}.
compareTo(byte[], int, int) - Method in class org.apache.hadoop.io.BinaryComparable
Compare bytes from {#getBytes()} to those provided.
compareTo(BooleanWritable) - Method in class org.apache.hadoop.io.BooleanWritable
 
compareTo(ByteWritable) - Method in class org.apache.hadoop.io.ByteWritable
Compares two ByteWritables.
compareTo(DoubleWritable) - Method in class org.apache.hadoop.io.DoubleWritable
 
compareTo(FloatWritable) - Method in class org.apache.hadoop.io.FloatWritable
Compares two FloatWritables.
compareTo(IntWritable) - Method in class org.apache.hadoop.io.IntWritable
Compares two IntWritables.
compareTo(LongWritable) - Method in class org.apache.hadoop.io.LongWritable
Compares two LongWritables.
compareTo(MD5Hash) - Method in class org.apache.hadoop.io.MD5Hash
Compares this object with the specified object for order.
compareTo(NullWritable) - Method in class org.apache.hadoop.io.NullWritable
 
compareTo(ShortWritable) - Method in class org.apache.hadoop.io.ShortWritable
Compares two ShortWritable.
compareTo(VIntWritable) - Method in class org.apache.hadoop.io.VIntWritable
Compares two VIntWritables.
compareTo(VLongWritable) - Method in class org.apache.hadoop.io.VLongWritable
Compares two VLongWritables.
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.
compareTo(Object) - Method in class org.apache.hadoop.record.Buffer
Deprecated.
Define the sort order of the Buffer.
compareTo(Object) - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
Deprecated.
This class doesn't implement Comparable as it's not meant to be used for anything besides de/serializing.
compareTo(Object) - Method in class org.apache.hadoop.record.Record
Deprecated.
 
compareTo(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
 
compareTo(ApplicationId) - Method in class org.apache.hadoop.yarn.api.records.ApplicationId
 
compareTo(ContainerId) - Method in class org.apache.hadoop.yarn.api.records.ContainerId
 
compareTo(NodeId) - Method in class org.apache.hadoop.yarn.api.records.NodeId
 
compareTo(ResourceRequest) - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
 
compile(String) - Method in class org.apache.hadoop.metrics2.filter.GlobFilter
 
compile(String) - Method in class org.apache.hadoop.metrics2.filter.RegexFilter
 
completeLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
 
completeLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
Called when we're all done writing to the target.
completeLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
Called when we're all done writing to the target.
completeLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
completeLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
COMPLETION_POLL_INTERVAL_KEY - Static variable in class org.apache.hadoop.mapreduce.Job
Key in mapred-*.xml that sets completionPollInvervalMillis
ComposableInputFormat<K extends WritableComparable,V extends Writable> - Interface in org.apache.hadoop.mapred.join
Refinement of InputFormat requiring implementors to provide ComposableRecordReader instead of RecordReader.
ComposableInputFormat<K extends WritableComparable<?>,V extends 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 WritableComparable,V extends Writable> - Interface in org.apache.hadoop.mapred.join
Additional operations required of a RecordReader to participate in a join.
ComposableRecordReader<K extends WritableComparable<?>,V extends 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.
CompositeContext - Class in org.apache.hadoop.metrics.spi
 
CompositeContext() - Constructor for class org.apache.hadoop.metrics.spi.CompositeContext
 
CompositeInputFormat<K extends 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 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 WritableComparable,V extends Writable,X extends 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 WritableComparable<?>,V extends Writable,X extends 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.
compress() - Method in class org.apache.hadoop.io.compress.BlockCompressorStream
 
compress(byte[], int, int) - Method in interface org.apache.hadoop.io.compress.Compressor
Fills specified buffer with compressed data.
compress() - Method in class org.apache.hadoop.io.compress.CompressorStream
 
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
 
CompressedWritable - Class in org.apache.hadoop.io
A base-class for Writables which store themselves compressed and lazily inflate on field access.
CompressedWritable() - Constructor for class org.apache.hadoop.io.CompressedWritable
 
COMPRESSION_GZ - Static variable in class org.apache.hadoop.io.file.tfile.TFile
compression: gzip
COMPRESSION_LZO - Static variable in class org.apache.hadoop.io.file.tfile.TFile
compression: lzo
COMPRESSION_NONE - Static variable in class org.apache.hadoop.io.file.tfile.TFile
compression: none
CompressionCodec - Interface in org.apache.hadoop.io.compress
This class encapsulates a streaming compression/decompression pair.
CompressionCodecFactory - Class in org.apache.hadoop.io.compress
A factory that will find the correct codec for a given filename.
CompressionCodecFactory(Configuration) - Constructor for class org.apache.hadoop.io.compress.CompressionCodecFactory
Find the codecs specified in the config value io.compression.codecs and register them.
CompressionInputStream - Class in org.apache.hadoop.io.compress
A compression input stream.
CompressionInputStream(InputStream) - Constructor for class org.apache.hadoop.io.compress.CompressionInputStream
Create a compression input stream that reads the decompressed bytes from the given stream.
CompressionOutputStream - Class in org.apache.hadoop.io.compress
A compression output stream.
CompressionOutputStream(OutputStream) - Constructor for class org.apache.hadoop.io.compress.CompressionOutputStream
Create a compression output stream that writes the compressed bytes to the given stream.
Compressor - Interface in org.apache.hadoop.io.compress
Specification of a stream-based 'compressor' which can be plugged into a CompressionOutputStream to compress data.
compressor - Variable in class org.apache.hadoop.io.compress.CompressorStream
 
CompressorStream - Class in org.apache.hadoop.io.compress
 
CompressorStream(OutputStream, Compressor, int) - Constructor for class org.apache.hadoop.io.compress.CompressorStream
 
CompressorStream(OutputStream, Compressor) - Constructor for class org.apache.hadoop.io.compress.CompressorStream
 
CompressorStream(OutputStream) - Constructor for class org.apache.hadoop.io.compress.CompressorStream
Allow derived classes to directly set the underlying stream.
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.mapreduce.lib.input.SequenceFileRecordReader
 
conf - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
Configurable - Interface in org.apache.hadoop.conf
Something that may be configured with a Configuration.
Configuration - Class in org.apache.hadoop.conf
Provides access to configuration parameters.
Configuration() - Constructor for class org.apache.hadoop.conf.Configuration
A new configuration.
Configuration(boolean) - Constructor for class org.apache.hadoop.conf.Configuration
A new configuration where the behavior of reading from the default resources can be turned off.
Configuration(Configuration) - Constructor for class org.apache.hadoop.conf.Configuration
A new configuration with the same settings cloned from another.
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.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
Configured - Class in org.apache.hadoop.conf
Base class for things that may be configured with a Configuration.
Configured() - Constructor for class org.apache.hadoop.conf.Configured
Construct a Configured.
Configured(Configuration) - Constructor for class org.apache.hadoop.conf.Configured
Construct a Configured.
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.
constructOutputStream(DataOutput) - Static method in class org.apache.hadoop.io.DataOutputOutputStream
Construct an OutputStream from the given DataOutput.
constructQuery(String, String[]) - Method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat
Constructs the query used as the prepared statement to insert data.
Consts - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
Container - Interface in org.apache.hadoop.yarn.api.records
Container represents an allocated resource in the cluster.
ContainerId - Class in org.apache.hadoop.yarn.api.records
ContainerId represents a globally unique identifier for a Container in the cluster.
ContainerId() - Constructor for class org.apache.hadoop.yarn.api.records.ContainerId
 
ContainerLaunchContext - Interface in org.apache.hadoop.yarn.api.records
ContainerLaunchContext represents all of the information needed by the NodeManager to launch a container.
ContainerManager - Interface in org.apache.hadoop.yarn.api
The protocol between an ApplicationMaster and a NodeManager to start/stop containers and to get status of running containers.
ContainerStatus - Interface in org.apache.hadoop.yarn.api.records
ContainerStatus represents the current status of a Container.
ContainerToken - Interface in org.apache.hadoop.yarn.api.records
ContainerToken is the security token used by the framework to verify authenticity of any Container.
containsKey(Object) - Method in class org.apache.hadoop.io.MapWritable
containsKey(Object) - Method in class org.apache.hadoop.io.SortedMapWritable
containsValue(Object) - Method in class org.apache.hadoop.io.MapWritable
containsValue(Object) - Method in class org.apache.hadoop.io.SortedMapWritable
ContentSummary - Class in org.apache.hadoop.fs
Store the summary of a content (a directory or a file).
ContentSummary() - Constructor for class org.apache.hadoop.fs.ContentSummary
Constructor
ContentSummary(long, long, long) - Constructor for class org.apache.hadoop.fs.ContentSummary
Constructor
ContentSummary(long, long, long, long, long, long) - Constructor for class org.apache.hadoop.fs.ContentSummary
Constructor
context - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
context() - Method in interface org.apache.hadoop.metrics2.MetricsRecord
 
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.
copy(FileSystem, Path, FileSystem, Path, boolean, Configuration) - Static method in class org.apache.hadoop.fs.FileUtil
Copy files between FileSystems.
copy(FileSystem, Path[], FileSystem, Path, boolean, boolean, Configuration) - Static method in class org.apache.hadoop.fs.FileUtil
 
copy(FileSystem, Path, FileSystem, Path, boolean, boolean, Configuration) - Static method in class org.apache.hadoop.fs.FileUtil
Copy files between FileSystems.
copy(File, FileSystem, Path, boolean, Configuration) - Static method in class org.apache.hadoop.fs.FileUtil
Copy local files to a FileSystem.
copy(FileSystem, Path, File, boolean, Configuration) - Static method in class org.apache.hadoop.fs.FileUtil
Copy FileSystem files to local files.
copy(Writable) - Method in class org.apache.hadoop.io.AbstractMapWritable
Used by child copy constructors.
copy(byte[], int, int) - Method in class org.apache.hadoop.record.Buffer
Deprecated.
Copy the specified byte array to the Buffer.
copy(Configuration, T, T) - Static method in class org.apache.hadoop.util.ReflectionUtils
Make a copy of the writable object using serialization to a buffer
copyBytes() - Method in class org.apache.hadoop.io.BytesWritable
Get a copy of the bytes that is exactly the length of the data.
copyBytes(InputStream, OutputStream, int, boolean) - Static method in class org.apache.hadoop.io.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream, int) - Static method in class org.apache.hadoop.io.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream, Configuration) - Static method in class org.apache.hadoop.io.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream, Configuration, boolean) - Static method in class org.apache.hadoop.io.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream, long, boolean) - Static method in class org.apache.hadoop.io.IOUtils
Copies count bytes from one stream to another.
copyBytes() - Method in class org.apache.hadoop.io.Text
Get a copy of the bytes that is exactly the length of the data.
copyFromLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
 
copyFromLocalFile(Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
The src file is on the local disk.
copyFromLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
The src file is on the local disk.
copyFromLocalFile(boolean, boolean, Path[], Path) - Method in class org.apache.hadoop.fs.FileSystem
The src files are on the local disk.
copyFromLocalFile(boolean, boolean, Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
The src file is on the local disk.
copyFromLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
The src file is on the local disk.
copyFromLocalFile(boolean, boolean, Path[], Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
The src files are on the local disk.
copyFromLocalFile(boolean, boolean, Path, Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
The src file is on the local disk.
copyFromLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
copyFromLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.LocalFileSystem
 
copyMerge(FileSystem, Path, FileSystem, Path, boolean, Configuration, String) - Static method in class org.apache.hadoop.fs.FileUtil
Copy all files in a directory to one output file (merge).
copyToLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
The src file is under FS, and the dst is on the local disk.
copyToLocalFile(Path, Path, boolean) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
The src file is under FS, and the dst is on the local disk.
copyToLocalFile(Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
The src file is under FS, and the dst is on the local disk.
copyToLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
The src file is under FS, and the dst is on the local disk.
copyToLocalFile(boolean, Path, Path, boolean) - Method in class org.apache.hadoop.fs.FileSystem
The src file is under FS, and the dst is on the local disk.
copyToLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
The src file is under FS, and the dst is on the local disk.
copyToLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
copyToLocalFile(boolean, Path, Path) - Method in class org.apache.hadoop.fs.LocalFileSystem
 
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(MetricsInfo, int) - Method in interface org.apache.hadoop.metrics2.MetricsVisitor
Callback for integer value counters
counter(MetricsInfo, long) - Method in interface org.apache.hadoop.metrics2.MetricsVisitor
Callback for long value counters
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_MAP_PROCESSED_RECORDS - Static variable in class org.apache.hadoop.mapred.SkipBadRecords
Number of processed map records.
COUNTER_REDUCE_PROCESSED_GROUPS - Static variable in class org.apache.hadoop.mapred.SkipBadRecords
Number of processed reduce groups.
CounterGroup - 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.
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
CountingBloomFilter - Class in org.apache.hadoop.util.bloom
Implements a counting Bloom filter, as defined by Fan et al.
CountingBloomFilter() - Constructor for class org.apache.hadoop.util.bloom.CountingBloomFilter
Default constructor - use with readFields
CountingBloomFilter(int, int, int) - Constructor for class org.apache.hadoop.util.bloom.CountingBloomFilter
Constructor
create(Path, EnumSet<CreateFlag>, Options.CreateOpts...) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.create(Path, EnumSet, Options.CreateOpts...) except that the Path f must be fully qualified and the permission is absolute (i.e.
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
Create an FSDataOutputStream at the indicated Path with write-progress reporting.
create(Path, EnumSet<CreateFlag>, Options.CreateOpts...) - Method in class org.apache.hadoop.fs.FileContext
Create or overwrite file on indicated path and returns an output stream for writing into the file.
create(FileSystem, Path, FsPermission) - Static method in class org.apache.hadoop.fs.FileSystem
create a file with the provided permission The permission of the file is set to be the provided permission as in setPermission, not permission&~umask It is implemented using two RPCs.
create(Path) - Method in class org.apache.hadoop.fs.FileSystem
Create an FSDataOutputStream at the indicated Path.
create(Path, boolean) - Method in class org.apache.hadoop.fs.FileSystem
Create an FSDataOutputStream at the indicated Path.
create(Path, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
Create an FSDataOutputStream at the indicated Path with write-progress reporting.
create(Path, short) - Method in class org.apache.hadoop.fs.FileSystem
Create an FSDataOutputStream at the indicated Path.
create(Path, short, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
Create an FSDataOutputStream at the indicated Path with write-progress reporting.
create(Path, boolean, int) - Method in class org.apache.hadoop.fs.FileSystem
Create an FSDataOutputStream at the indicated Path.
create(Path, boolean, int, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
Create an FSDataOutputStream at the indicated Path with write-progress reporting.
create(Path, boolean, int, short, long) - Method in class org.apache.hadoop.fs.FileSystem
Create an FSDataOutputStream at the indicated Path.
create(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
Create an FSDataOutputStream at the indicated Path with write-progress reporting.
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
Create an FSDataOutputStream at the indicated Path with write-progress reporting.
create(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable, Options.ChecksumOpt) - Method in class org.apache.hadoop.fs.FileSystem
Create an FSDataOutputStream at the indicated Path with a custom checksum option.
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FilterFileSystem
Create an FSDataOutputStream at the indicated Path with write-progress reporting.
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
A stream obtained via this call must be closed before using other APIs of this class or else the invocation will block.
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
create(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
Create an FSDataOutputStream at the indicated Path with write-progress reporting.
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
Create an FSDataOutputStream at the indicated Path with write-progress reporting.
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.s3.S3FileSystem
 
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
CREATE_DIR - Static variable in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
createCheckpoint() - Method in class org.apache.hadoop.fs.TrashPolicy
Create a trash checkpoint.
createCompressor() - Method in class org.apache.hadoop.io.compress.BZip2Codec
Create a new Compressor for use by this CompressionCodec.
createCompressor() - Method in interface org.apache.hadoop.io.compress.CompressionCodec
Create a new Compressor for use by this CompressionCodec.
createCompressor() - Method in class org.apache.hadoop.io.compress.DefaultCodec
 
createCompressor() - Method in class org.apache.hadoop.io.compress.GzipCodec
 
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
 
createDecompressor() - Method in class org.apache.hadoop.io.compress.BZip2Codec
Create a new Decompressor for use by this CompressionCodec.
createDecompressor() - Method in interface org.apache.hadoop.io.compress.CompressionCodec
Create a new Decompressor for use by this CompressionCodec.
createDecompressor() - Method in class org.apache.hadoop.io.compress.DefaultCodec
 
createDecompressor() - Method in class org.apache.hadoop.io.compress.GzipCodec
 
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.
createFileSystem(URI, Configuration) - Static method in class org.apache.hadoop.fs.AbstractFileSystem
Create a file system instance for the specified uri using the conf.
CreateFlag - Enum in org.apache.hadoop.fs
CreateFlag specifies the file create semantic.
createImmutable(short) - Static method in class org.apache.hadoop.fs.permission.FsPermission
Create an immutable FsPermission object.
createInputStream(InputStream) - Method in class org.apache.hadoop.io.compress.BZip2Codec
Create a CompressionInputStream that will read from the given input stream and return a stream for uncompressed data.
createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.io.compress.BZip2Codec
Create a CompressionInputStream that will read from the given InputStream with the given Decompressor, and return a stream for uncompressed data.
createInputStream(InputStream, Decompressor, long, long, SplittableCompressionCodec.READ_MODE) - Method in class org.apache.hadoop.io.compress.BZip2Codec
Creates CompressionInputStream to be used to read off uncompressed data in one of the two reading modes.
createInputStream(InputStream) - Method in interface org.apache.hadoop.io.compress.CompressionCodec
Create a CompressionInputStream that will read from the given input stream.
createInputStream(InputStream, Decompressor) - Method in interface org.apache.hadoop.io.compress.CompressionCodec
Create a CompressionInputStream that will read from the given InputStream with the given Decompressor.
createInputStream(InputStream) - Method in class org.apache.hadoop.io.compress.DefaultCodec
 
createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.io.compress.DefaultCodec
 
createInputStream(InputStream) - Method in class org.apache.hadoop.io.compress.GzipCodec
 
createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.io.compress.GzipCodec
 
createInputStream(InputStream, Decompressor, long, long, SplittableCompressionCodec.READ_MODE) - Method in interface org.apache.hadoop.io.compress.SplittableCompressionCodec
Create a stream as dictated by the readMode.
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
createInternal(Path, EnumSet<CreateFlag>, FsPermission, int, short, long, Progressable, Options.ChecksumOpt, boolean) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of AbstractFileSystem.create(Path, EnumSet, Options.CreateOpts...) except that the opts have been declared explicitly.
createInternal(Path, EnumSet<CreateFlag>, FsPermission, int, short, long, Progressable, Options.ChecksumOpt, boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
createInternalValue() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Create a value to be used internally for joins.
createIOException(List<IOException>) - Static method in exception org.apache.hadoop.io.MultipleIOException
A convenient method to create an IOException.
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 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.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.
createLocalTempFile(File, String, boolean) - Static method in class org.apache.hadoop.fs.FileUtil
Create a tmp file for a base file.
createNewFile(Path) - Method in class org.apache.hadoop.fs.FileSystem
Creates the given Path as a brand-new zero-length file.
createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
Opens an FSDataOutputStream at the indicated Path with write-progress reporting.
createNonRecursive(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
Deprecated.
API only for 0.20-append
createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
Deprecated.
API only for 0.20-append
createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
Opens an FSDataOutputStream at the indicated Path with write-progress reporting.
createOutputStream(OutputStream) - Method in class org.apache.hadoop.io.compress.BZip2Codec
Create a CompressionOutputStream that will write to the given OutputStream.
createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.io.compress.BZip2Codec
Create a CompressionOutputStream that will write to the given OutputStream with the given Compressor.
createOutputStream(OutputStream) - Method in interface org.apache.hadoop.io.compress.CompressionCodec
Create a CompressionOutputStream that will write to the given OutputStream.
createOutputStream(OutputStream, Compressor) - Method in interface org.apache.hadoop.io.compress.CompressionCodec
Create a CompressionOutputStream that will write to the given OutputStream with the given Compressor.
createOutputStream(OutputStream) - Method in class org.apache.hadoop.io.compress.DefaultCodec
 
createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.io.compress.DefaultCodec
 
createOutputStream(OutputStream) - Method in class org.apache.hadoop.io.compress.GzipCodec
 
createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.io.compress.GzipCodec
 
createPool(JobConf, List<PathFilter>) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
createPool(JobConf, PathFilter...) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
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.
createRecord(String) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Creates a new AbstractMetricsRecord instance with the given recordName.
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.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.
createSocket() - Method in class org.apache.hadoop.net.SocksSocketFactory
 
createSocket(InetAddress, int) - Method in class org.apache.hadoop.net.SocksSocketFactory
 
createSocket(InetAddress, int, InetAddress, int) - Method in class org.apache.hadoop.net.SocksSocketFactory
 
createSocket(String, int) - Method in class org.apache.hadoop.net.SocksSocketFactory
 
createSocket(String, int, InetAddress, int) - Method in class org.apache.hadoop.net.SocksSocketFactory
 
createSocket() - Method in class org.apache.hadoop.net.StandardSocketFactory
 
createSocket(InetAddress, int) - Method in class org.apache.hadoop.net.StandardSocketFactory
 
createSocket(InetAddress, int, InetAddress, int) - Method in class org.apache.hadoop.net.StandardSocketFactory
 
createSocket(String, int) - Method in class org.apache.hadoop.net.StandardSocketFactory
 
createSocket(String, int, InetAddress, int) - Method in class org.apache.hadoop.net.StandardSocketFactory
 
createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.createSymlink(Path, Path, boolean);
createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.FileContext
Creates a symbolic link to an existing file.
createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
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 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.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
 
createWriter(Configuration, SequenceFile.Writer.Option...) - Static method in class org.apache.hadoop.io.SequenceFile
Create a new Writer with the given options.
createWriter(FileSystem, Configuration, Path, Class, Class) - Static method in class org.apache.hadoop.io.SequenceFile
createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType) - Static method in class org.apache.hadoop.io.SequenceFile
createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType, Progressable) - Static method in class org.apache.hadoop.io.SequenceFile
createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType, CompressionCodec) - Static method in class org.apache.hadoop.io.SequenceFile
createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType, CompressionCodec, Progressable, SequenceFile.Metadata) - Static method in class org.apache.hadoop.io.SequenceFile
createWriter(FileSystem, Configuration, Path, Class, Class, int, short, long, SequenceFile.CompressionType, CompressionCodec, Progressable, SequenceFile.Metadata) - Static method in class org.apache.hadoop.io.SequenceFile
createWriter(FileSystem, Configuration, Path, Class, Class, int, short, long, boolean, SequenceFile.CompressionType, CompressionCodec, SequenceFile.Metadata) - Static method in class org.apache.hadoop.io.SequenceFile
Deprecated.
createWriter(FileContext, Configuration, Path, Class, Class, SequenceFile.CompressionType, CompressionCodec, SequenceFile.Metadata, EnumSet<CreateFlag>, Options.CreateOpts...) - Static method in class org.apache.hadoop.io.SequenceFile
Construct the preferred type of SequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType, CompressionCodec, Progressable) - Static method in class org.apache.hadoop.io.SequenceFile
createWriter(Configuration, FSDataOutputStream, Class, Class, SequenceFile.CompressionType, CompressionCodec, SequenceFile.Metadata) - Static method in class org.apache.hadoop.io.SequenceFile
createWriter(Configuration, FSDataOutputStream, Class, Class, SequenceFile.CompressionType, CompressionCodec) - Static method in class org.apache.hadoop.io.SequenceFile
CSTRING_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
CsvRecordInput - Class in org.apache.hadoop.record
Deprecated.
Replaced by Avro.
CsvRecordInput(InputStream) - Constructor for class org.apache.hadoop.record.CsvRecordInput
Deprecated.
Creates a new instance of CsvRecordInput
CsvRecordOutput - Class in org.apache.hadoop.record
Deprecated.
Replaced by Avro.
CsvRecordOutput(OutputStream) - Constructor for class org.apache.hadoop.record.CsvRecordOutput
Deprecated.
Creates a new instance of CsvRecordOutput
CUR_DIR - Static variable in class org.apache.hadoop.fs.Path
 
curChar - Variable in class org.apache.hadoop.record.compiler.generated.RccTokenManager
Deprecated.
 
curReader - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
curReader - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
currentConfig() - Method in interface org.apache.hadoop.metrics2.MetricsSystemMXBean
 
currentToken - Variable in exception org.apache.hadoop.record.compiler.generated.ParseException
Deprecated.
This is the last token that has been consumed successfully.

D

DATA_FIELD_SEPERATOR - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
DATA_FILE_NAME - Static variable in class org.apache.hadoop.io.MapFile
The name of the data file.
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
 
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
 
datagramSocket - Variable in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
DataOutputOutputStream - Class in org.apache.hadoop.io
OutputStream implementation that wraps a DataOutput.
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
 
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
 
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.
debugStream - Variable in class org.apache.hadoop.record.compiler.generated.RccTokenManager
Deprecated.
 
decode(byte[]) - Static method in class org.apache.hadoop.io.Text
Converts the provided byte array to a String using the UTF-8 encoding.
decode(byte[], int, int) - Static method in class org.apache.hadoop.io.Text
 
decode(byte[], int, int, boolean) - Static method in class org.apache.hadoop.io.Text
Converts the provided byte array to a String using the UTF-8 encoding.
decodeVIntSize(byte) - Static method in class org.apache.hadoop.io.WritableUtils
Parse the first byte of a vint/vlong to determine the number of bytes
decompress(byte[], int, int) - Method in class org.apache.hadoop.io.compress.BlockDecompressorStream
 
decompress(byte[], int, int) - Method in interface org.apache.hadoop.io.compress.Decompressor
Fills specified buffer with uncompressed data.
decompress(byte[], int, int) - Method in class org.apache.hadoop.io.compress.DecompressorStream
 
Decompressor - Interface in org.apache.hadoop.io.compress
Specification of a stream-based 'de-compressor' which can be plugged into a CompressionInputStream to compress data.
decompressor - Variable in class org.apache.hadoop.io.compress.DecompressorStream
 
DecompressorStream - Class in org.apache.hadoop.io.compress
 
DecompressorStream(InputStream, Decompressor, int) - Constructor for class org.apache.hadoop.io.compress.DecompressorStream
 
DecompressorStream(InputStream, Decompressor) - Constructor for class org.apache.hadoop.io.compress.DecompressorStream
 
DecompressorStream(InputStream) - Constructor for class org.apache.hadoop.io.compress.DecompressorStream
Allow derived classes to directly set the underlying stream.
decr() - Method in class org.apache.hadoop.metrics2.lib.MutableGauge
Decrement the value of the metric by 1
decr() - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeInt
 
decr(int) - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeInt
decrement by delta
decr() - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeLong
 
decr(long) - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeLong
decrement by delta
DEFAULT - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
DEFAULT_BLOCK_SIZE - Static variable in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
DEFAULT_FILTER - Static variable in class org.apache.hadoop.fs.FileSystem
 
DEFAULT_FS - Static variable in class org.apache.hadoop.fs.FileSystem
 
DEFAULT_LOG_LEVEL - Static variable in class org.apache.hadoop.mapred.JobConf
Default logging level for map/reduce tasks.
DEFAULT_MAPRED_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
 
DEFAULT_PATH - Static variable in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
DEFAULT_PERM - Static variable in class org.apache.hadoop.fs.FileContext
Default permission for directory and symlink In previous versions, this default permission was also used to create files, so files created end up with ugo+x permission.
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_UMASK - Static variable in class org.apache.hadoop.fs.permission.FsPermission
 
DefaultCodec - Class in org.apache.hadoop.io.compress
 
DefaultCodec() - Constructor for class org.apache.hadoop.io.compress.DefaultCodec
 
DefaultMetricsSystem - Enum in org.apache.hadoop.metrics2.lib
The default metrics system singleton
DefaultStringifier<T> - Class in org.apache.hadoop.io
DefaultStringifier is the default implementation of the Stringifier interface which stringifies the objects using base64 encoding of the serialized version of the objects.
DefaultStringifier(Configuration, Class<T>) - Constructor for class org.apache.hadoop.io.DefaultStringifier
 
define(Class, WritableComparator) - Static method in class org.apache.hadoop.io.WritableComparator
Register an optimized comparator for a WritableComparable implementation.
define(Class, RecordComparator) - Static method in class org.apache.hadoop.record.RecordComparator
Deprecated.
Register an optimized comparator for a Record implementation.
DelegationToken - Interface in org.apache.hadoop.yarn.api.records
The Delegation tokens have a identifier which maps to AbstractDelegationTokenIdentifier.
delete(Path, boolean) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.delete(Path, boolean) except that Path f must be for this file system.
delete(Path, boolean) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
Implement the delete(Path, boolean) in checksum file system.
delete(Path, boolean) - Method in class org.apache.hadoop.fs.FileContext
Delete a file.
delete(Path) - Method in class org.apache.hadoop.fs.FileSystem
Deprecated.
delete(Path, boolean) - Method in class org.apache.hadoop.fs.FileSystem
Delete a file.
delete(Path, boolean) - Method in class org.apache.hadoop.fs.FilterFileSystem
Delete a file
delete(Path, boolean) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
delete(Path, boolean) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
delete(Path, boolean) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
Delete the given path to a file or directory.
delete(Path, boolean) - Method in class org.apache.hadoop.fs.s3.S3FileSystem
 
delete(Path, boolean) - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
delete(Path, boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
delete(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
delete(Path, boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
delete(FileSystem, String) - Static method in class org.apache.hadoop.io.BloomMapFile
 
delete(FileSystem, String) - Static method in class org.apache.hadoop.io.MapFile
Deletes the named map file.
delete(Key) - Method in class org.apache.hadoop.util.bloom.CountingBloomFilter
Removes a specified key from this counting Bloom filter.
deleteCheckpoint() - Method in class org.apache.hadoop.fs.TrashPolicy
Delete old trash checkpoint(s).
deleteLocalFiles() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated.
deleteLocalFiles(String) - Method in class org.apache.hadoop.mapred.JobConf
 
deleteOnExit(Path) - Method in class org.apache.hadoop.fs.FileContext
Mark a path to be deleted on JVM shutdown.
deleteOnExit(Path) - Method in class org.apache.hadoop.fs.FileSystem
Mark a path to be deleted when FileSystem is closed.
deletionInterval - Variable in class org.apache.hadoop.fs.TrashPolicy
 
DEPENDENT_FAILED - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
 
DEPRECATED_UMASK_LABEL - Static variable in class org.apache.hadoop.fs.permission.FsPermission
umask property label deprecated key and code in getUMask method to accommodate it may be removed in version .23
depth() - Method in class org.apache.hadoop.fs.Path
Return the number of elements in this path.
description() - Method in class org.apache.hadoop.metrics2.AbstractMetric
 
description() - Method in interface org.apache.hadoop.metrics2.MetricsInfo
 
description() - Method in interface org.apache.hadoop.metrics2.MetricsRecord
 
description() - Method in class org.apache.hadoop.metrics2.MetricsTag
 
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
 
deserialize(RecordInput, String) - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
Deprecated.
Deserialize the type information for a record
deserialize(RecordInput, String) - Method in class org.apache.hadoop.record.Record
Deprecated.
Deserialize a record with a tag (usually field name)
deserialize(RecordInput) - Method in class org.apache.hadoop.record.Record
Deprecated.
Deserialize a record without a tag
digest(byte[]) - Static method in class org.apache.hadoop.io.MD5Hash
Construct a hash value for a byte array.
digest(InputStream) - Static method in class org.apache.hadoop.io.MD5Hash
Construct a hash value for the content from the InputStream.
digest(byte[], int, int) - Static method in class org.apache.hadoop.io.MD5Hash
Construct a hash value for a byte array.
digest(String) - Static method in class org.apache.hadoop.io.MD5Hash
Construct a hash value for a String.
digest(UTF8) - Static method in class org.apache.hadoop.io.MD5Hash
Construct a hash value for a String.
DIR_DEFAULT_PERM - Static variable in class org.apache.hadoop.fs.FileContext
Default permission for directory
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
 
disable_tracing() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
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.
displayByteArray(byte[]) - Static method in class org.apache.hadoop.io.WritableUtils
 
displayJobList(JobStatus[]) - Method in class org.apache.hadoop.mapreduce.tools.CLI
 
displayJobList(JobStatus[], PrintWriter) - Method in class org.apache.hadoop.mapreduce.tools.CLI
 
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
 
DISTRIBUTEDSHELLSCRIPTLEN - Static variable in class org.apache.hadoop.yarn.applications.distributedshell.DSConstants
Environment key name denoting the file content length for the shell script.
DISTRIBUTEDSHELLSCRIPTLOCATION - Static variable in class org.apache.hadoop.yarn.applications.distributedshell.DSConstants
Environment key name pointing to the shell script's location
DISTRIBUTEDSHELLSCRIPTTIMESTAMP - Static variable in class org.apache.hadoop.yarn.applications.distributedshell.DSConstants
Environment key name denoting the file timestamp for the shell script.
DNSToSwitchMapping - Interface in org.apache.hadoop.net
An interface that must be implemented to allow pluggable DNS-name/IP-address to RackID resolvers.
Done() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
done() - Method in interface org.apache.hadoop.record.Index
Deprecated.
 
DOT_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
DOUBLE_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
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
 
DoubleTypeID - Static variable in class org.apache.hadoop.record.meta.TypeID
Deprecated.
 
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
DoubleWritable - Class in org.apache.hadoop.io
Writable for Double values.
DoubleWritable() - Constructor for class org.apache.hadoop.io.DoubleWritable
 
DoubleWritable(double) - Constructor for class org.apache.hadoop.io.DoubleWritable
 
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(String[]) - Static method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
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
DSConstants - Class in org.apache.hadoop.yarn.applications.distributedshell
Constants used in both Client and Application Master
DSConstants() - Constructor for class org.apache.hadoop.yarn.applications.distributedshell.DSConstants
 
dumpConfiguration(Configuration, Writer) - Static method in class org.apache.hadoop.conf.Configuration
Writes out all the parameters and their properties (final and resource) to the given Writer The format of the output would be { "properties" : [ {key1,value1,key1.isFinal,key1.resource}, {key2,value2, key2.isFinal,key2.resource}...
dumpTopology() - Method in class org.apache.hadoop.net.AbstractDNSToSwitchMapping
Generate a string listing the switch mapping implementation, the mapping for every known node and the number of nodes and unique switches known about -each entry to a separate line.
DynamicBloomFilter - Class in org.apache.hadoop.util.bloom
Implements a dynamic Bloom filter, as defined in the INFOCOM 2006 paper.
DynamicBloomFilter() - Constructor for class org.apache.hadoop.util.bloom.DynamicBloomFilter
Zero-args constructor for the serialization.
DynamicBloomFilter(int, int, int, int) - Constructor for class org.apache.hadoop.util.bloom.DynamicBloomFilter
Constructor.

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.
emitMetric(String, String, String) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
emitRecord(String, String, OutputRecord) - Method in class org.apache.hadoop.metrics.file.FileContext
Deprecated.
Emits a metrics record to a file.
emitRecord(String, String, OutputRecord) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
emitRecord(String, String, OutputRecord) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Sends a record to the metrics system.
emitRecord(String, String, OutputRecord) - Method in class org.apache.hadoop.metrics.spi.CompositeContext
 
emitRecord(String, String, OutputRecord) - Method in class org.apache.hadoop.metrics.spi.NoEmitMetricsContext
Do-nothing version of emitRecord
emitRecord(String, String, OutputRecord) - Method in class org.apache.hadoop.metrics.spi.NullContext
Do-nothing version of emitRecord
emitRecord(String, String, OutputRecord) - Method in class org.apache.hadoop.metrics.spi.NullContextWithUpdateThread
Do-nothing version of emitRecord
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
 
emptyText - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
enable_tracing() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
encode(String) - Static method in class org.apache.hadoop.io.Text
Converts the provided String to bytes using the UTF-8 encoding.
encode(String, boolean) - Static method in class org.apache.hadoop.io.Text
Converts the provided String to bytes using the UTF-8 encoding.
end() - Method in interface org.apache.hadoop.io.compress.Compressor
Closes the compressor and discards any unprocessed input.
end() - Method in interface org.apache.hadoop.io.compress.Decompressor
Closes the decompressor and discards any unprocessed input.
endColumn - Variable in class org.apache.hadoop.record.compiler.generated.Token
Deprecated.
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
endLine - Variable in class org.apache.hadoop.record.compiler.generated.Token
Deprecated.
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
endMap(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
 
endMap(TreeMap, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
Deprecated.
 
endMap(String) - Method in class org.apache.hadoop.record.CsvRecordInput
Deprecated.
 
endMap(TreeMap, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
Deprecated.
 
endMap(String) - Method in interface org.apache.hadoop.record.RecordInput
Deprecated.
Check the mark for end of the serialized map.
endMap(TreeMap, String) - Method in interface org.apache.hadoop.record.RecordOutput
Deprecated.
Mark the end of a serialized map.
endMap(String) - Method in class org.apache.hadoop.record.XmlRecordInput
Deprecated.
 
endMap(TreeMap, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
Deprecated.
 
endRecord() - Method in class org.apache.hadoop.metrics2.MetricsRecordBuilder
Syntactic sugar to add multiple records in a collector in a one liner.
endRecord(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
 
endRecord(Record, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
Deprecated.
 
endRecord(String) - Method in class org.apache.hadoop.record.CsvRecordInput
Deprecated.
 
endRecord(Record, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
Deprecated.
 
endRecord(String) - Method in interface org.apache.hadoop.record.RecordInput
Deprecated.
Check the mark for end of the serialized record.
endRecord(Record, String) - Method in interface org.apache.hadoop.record.RecordOutput
Deprecated.
Mark the end of a serialized record.
endRecord(String) - Method in class org.apache.hadoop.record.XmlRecordInput
Deprecated.
 
endRecord(Record, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
Deprecated.
 
endVector(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
 
endVector(ArrayList, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
Deprecated.
 
endVector(String) - Method in class org.apache.hadoop.record.CsvRecordInput
Deprecated.
 
endVector(ArrayList, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
Deprecated.
 
endVector(String) - Method in interface org.apache.hadoop.record.RecordInput
Deprecated.
Check the mark for end of the serialized vector.
endVector(ArrayList, String) - Method in interface org.apache.hadoop.record.RecordOutput
Deprecated.
Mark the end of a serialized vector.
endVector(String) - Method in class org.apache.hadoop.record.XmlRecordInput
Deprecated.
 
endVector(ArrayList, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
Deprecated.
 
ensureInflated() - Method in class org.apache.hadoop.io.CompressedWritable
Must be called by all methods which access fields to ensure that the data has been uncompressed.
entrySet() - Method in class org.apache.hadoop.io.MapWritable
entrySet() - Method in class org.apache.hadoop.io.SortedMapWritable
EnumSetWritable<E extends Enum<E>> - Class in org.apache.hadoop.io
A Writable wrapper for EnumSet.
EnumSetWritable(EnumSet<E>, Class<E>) - Constructor for class org.apache.hadoop.io.EnumSetWritable
Construct a new EnumSetWritable.
EnumSetWritable(EnumSet<E>) - Constructor for class org.apache.hadoop.io.EnumSetWritable
Construct a new EnumSetWritable.
eof - Variable in class org.apache.hadoop.io.compress.DecompressorStream
 
EOF - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
eol - Variable in exception org.apache.hadoop.record.compiler.generated.ParseException
Deprecated.
The end of line string for this machine.
equals(Object) - Method in class org.apache.hadoop.fs.AbstractFileSystem
 
equals(Object) - Method in class org.apache.hadoop.fs.FileChecksum
Return true if both the algorithms and the values are the same.
equals(Object) - Method in class org.apache.hadoop.fs.FileStatus
Compare if this object is equal to another object
equals(Object) - Method in class org.apache.hadoop.fs.LocatedFileStatus
Compare if this object is equal to another object
equals(Object) - Method in class org.apache.hadoop.fs.Path
 
equals(Object) - Method in class org.apache.hadoop.fs.permission.FsPermission
equals(Object) - Method in class org.apache.hadoop.io.BinaryComparable
Return true if bytes from {#getBytes()} match.
equals(Object) - Method in class org.apache.hadoop.io.BooleanWritable
 
equals(Object) - Method in class org.apache.hadoop.io.BytesWritable
Are the two byte sequences equal?
equals(Object) - Method in class org.apache.hadoop.io.ByteWritable
Returns true iff o is a ByteWritable with the same value.
equals(Object) - Method in class org.apache.hadoop.io.DoubleWritable
Returns true iff o is a DoubleWritable with the same value.
equals(Object) - Method in class org.apache.hadoop.io.EnumSetWritable
Returns true if o is an EnumSetWritable with the same value, or both are null.
equals(Object) - Method in class org.apache.hadoop.io.FloatWritable
Returns true iff o is a FloatWritable with the same value.
equals(Object) - Method in class org.apache.hadoop.io.IntWritable
Returns true iff o is a IntWritable with the same value.
equals(Object) - Method in class org.apache.hadoop.io.LongWritable
Returns true iff o is a LongWritable with the same value.
equals(Object) - Method in class org.apache.hadoop.io.MapWritable
equals(Object) - Method in class org.apache.hadoop.io.MD5Hash
Returns true iff o is an MD5Hash whose digest contains the same values.
equals(Object) - Method in class org.apache.hadoop.io.NullWritable
 
equals(Object) - Method in class org.apache.hadoop.io.ShortWritable
Returns true iff o is a ShortWritable with the same value.
equals(Object) - Method in class org.apache.hadoop.io.SortedMapWritable
 
equals(Object) - Method in class org.apache.hadoop.io.Text
Returns true iff o is a Text with the same contents.
equals(Object) - Method in class org.apache.hadoop.io.VIntWritable
Returns true iff o is a VIntWritable with the same value.
equals(Object) - Method in class org.apache.hadoop.io.VLongWritable
Returns true iff o is a VLongWritable with the same value.
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.AbstractCounters
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.ID
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.JobID
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
equals(Object) - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Return true iff compareTo(other) retn true.
equals(Object) - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
equals(Object) - Method in class org.apache.hadoop.mapreduce.TaskID
 
equals(Object) - Method in class org.apache.hadoop.metrics2.AbstractMetric
 
equals(Object) - Method in class org.apache.hadoop.metrics2.MetricsTag
 
equals(Object) - Method in class org.apache.hadoop.net.SocksSocketFactory
 
equals(Object) - Method in class org.apache.hadoop.net.StandardSocketFactory
 
equals(Object) - Method in class org.apache.hadoop.record.Buffer
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.record.meta.FieldTypeInfo
Deprecated.
Two FieldTypeInfos are equal if ach of their fields matches
equals(FieldTypeInfo) - Method in class org.apache.hadoop.record.meta.FieldTypeInfo
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.record.meta.MapTypeID
Deprecated.
Two map typeIDs are equal if their constituent elements have the same type
equals(Object) - Method in class org.apache.hadoop.record.meta.StructTypeID
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.record.meta.TypeID
Deprecated.
Two base typeIDs are equal if they refer to the same type
equals(Object) - Method in class org.apache.hadoop.record.meta.VectorTypeID
Deprecated.
Two vector typeIDs are equal if their constituent elements have the same type
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.ApplicationId
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.ContainerId
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.NodeId
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.Resource
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
 
EventCounter - Class in org.apache.hadoop.log.metrics
A log4J Appender that simply counts logging events in three levels: fatal, error and warn.
EventCounter() - Constructor for class org.apache.hadoop.log.metrics.EventCounter
 
EXECUTABLE - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
execute() - Method in class org.apache.hadoop.record.compiler.ant.RccTask
Deprecated.
Invoke the Hadoop record compiler on each record definition file
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
 
exists(Path) - Method in class org.apache.hadoop.fs.FileSystem
Check if exists.
ExpandBuff(boolean) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
expectedTokenSequences - Variable in exception org.apache.hadoop.record.compiler.generated.ParseException
Deprecated.
Each entry in this array is an array of integers.
expunge() - Method in class org.apache.hadoop.fs.Trash
Delete old checkpoint(s).
extractOutputKeyValue(String, String, String, List<Integer>, List<Integer>, int, boolean, boolean) - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 

F

FAILED - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
 
FAILED - Static variable in class org.apache.hadoop.mapred.JobStatus
 
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.
Field() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
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
 
FieldTypeInfo - Class in org.apache.hadoop.record.meta
Deprecated.
Replaced by Avro.
FILE_DEFAULT_PERM - Static variable in class org.apache.hadoop.fs.FileContext
Default permission for file
FILE_NAME_PROPERTY - Static variable in class org.apache.hadoop.metrics.file.FileContext
Deprecated.
 
FileAlreadyExistsException - Exception in org.apache.hadoop.fs
Used when target file already exists for any operation and is not configured to be overwritten.
FileAlreadyExistsException() - Constructor for exception org.apache.hadoop.fs.FileAlreadyExistsException
 
FileAlreadyExistsException(String) - Constructor for exception org.apache.hadoop.fs.FileAlreadyExistsException
 
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
 
FileChecksum - Class in org.apache.hadoop.fs
An abstract class representing file checksums for files.
FileChecksum() - Constructor for class org.apache.hadoop.fs.FileChecksum
 
FileContext - Class in org.apache.hadoop.fs
The FileContext class provides an interface to the application writer for using the Hadoop file system.
FileContext - Class in org.apache.hadoop.metrics.file
Deprecated.
FileContext() - Constructor for class org.apache.hadoop.metrics.file.FileContext
Deprecated.
Creates a new instance of FileContext
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
 
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
 
FileSink - Class in org.apache.hadoop.metrics2.sink
A metrics sink that writes to a file
FileSink() - Constructor for class org.apache.hadoop.metrics2.sink.FileSink
 
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
FileStatus - Class in org.apache.hadoop.fs
Interface that represents the client side information for a file.
FileStatus() - Constructor for class org.apache.hadoop.fs.FileStatus
 
FileStatus(long, boolean, int, long, long, Path) - Constructor for class org.apache.hadoop.fs.FileStatus
 
FileStatus(long, boolean, int, long, long, long, FsPermission, String, String, Path) - Constructor for class org.apache.hadoop.fs.FileStatus
Constructor for file systems on which symbolic links are not supported
FileStatus(long, boolean, int, long, long, long, FsPermission, String, String, Path, Path) - Constructor for class org.apache.hadoop.fs.FileStatus
 
FileSystem - Class in org.apache.hadoop.fs
An abstract base class for a fairly generic filesystem.
FileSystem() - Constructor for class org.apache.hadoop.fs.FileSystem
 
FileUtil - Class in org.apache.hadoop.fs
A collection of file-processing util methods
FileUtil() - Constructor for class org.apache.hadoop.fs.FileUtil
 
FillBuff() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
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
 
FilterFileSystem - Class in org.apache.hadoop.fs
A FilterFileSystem contains some other file system, which it uses as its basic file system, possibly transforming the data along the way or providing additional functionality.
FilterFileSystem() - Constructor for class org.apache.hadoop.fs.FilterFileSystem
 
FilterFileSystem(FileSystem) - Constructor for class org.apache.hadoop.fs.FilterFileSystem
 
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.
FinalApplicationStatus - Enum in org.apache.hadoop.yarn.api.records
Enumeration of various final states of an Application.
find(String) - Method in class org.apache.hadoop.io.Text
 
find(String, int) - Method in class org.apache.hadoop.io.Text
Finds any occurence of what in the backing buffer, starting as position start.
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.
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.
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.io.compress.BlockCompressorStream
 
finish() - Method in class org.apache.hadoop.io.compress.CompressionOutputStream
Finishes writing compressed data to the output stream without closing the underlying stream.
finish() - Method in interface org.apache.hadoop.io.compress.Compressor
When called, indicates that compression should end with the current contents of the input buffer.
finish() - Method in class org.apache.hadoop.io.compress.CompressorStream
 
finishApplicationMaster(FinishApplicationMasterRequest) - Method in interface org.apache.hadoop.yarn.api.AMRMProtocol
The interface used by an ApplicationMaster to notify the ResourceManager about its completion (success or failed).
FinishApplicationMasterResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a ApplicationMaster on it's completion.
finished() - Method in interface org.apache.hadoop.io.compress.Compressor
Returns true if the end of the compressed data output stream has been reached.
finished() - Method in interface org.apache.hadoop.io.compress.Decompressor
Returns true if the end of the decompressed data output stream has been reached.
firstKey() - Method in class org.apache.hadoop.io.SortedMapWritable
fix(FileSystem, Path, Class<? extends Writable>, Class<? extends Writable>, boolean, Configuration) - Static method in class org.apache.hadoop.io.MapFile
This method attempts to fix a corrupt MapFile by re-creating its index.
FLOAT_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
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
 
FloatTypeID - Static variable in class org.apache.hadoop.record.meta.TypeID
Deprecated.
 
FloatWritable - Class in org.apache.hadoop.io
A WritableComparable for floats.
FloatWritable() - Constructor for class org.apache.hadoop.io.FloatWritable
 
FloatWritable(float) - Constructor for class org.apache.hadoop.io.FloatWritable
 
flush() - Method in class org.apache.hadoop.io.compress.CompressionOutputStream
 
flush() - Method in class org.apache.hadoop.metrics.file.FileContext
Deprecated.
Flushes the output writer, forcing updates to disk.
flush() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Called each period after all records have been emitted, this method does nothing.
flush() - Method in class org.apache.hadoop.metrics.spi.CompositeContext
 
flush() - Method in interface org.apache.hadoop.metrics2.MetricsSink
Flush any buffered metrics
flush() - Method in class org.apache.hadoop.metrics2.sink.FileSink
 
forceKillApplication(KillApplicationRequest) - Method in interface org.apache.hadoop.yarn.api.ClientRMProtocol
The interface used by clients to request the ResourceManager to abort submitted application.
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
fromEscapedCompactString(String) - Static method in class org.apache.hadoop.mapred.Counters
Convert a stringified (by Counters.makeEscapedCompactString() counter representation into a counter object.
fromShort(short) - Method in class org.apache.hadoop.fs.permission.FsPermission
 
fromString(String) - Method in class org.apache.hadoop.io.DefaultStringifier
 
fromString(String) - Method in interface org.apache.hadoop.io.Stringifier
Restores the object from its string representation.
fs - Variable in class org.apache.hadoop.fs.FilterFileSystem
 
fs - Variable in class org.apache.hadoop.fs.TrashPolicy
 
fs - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
fs - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
FS_AUTOMATIC_CLOSE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for FS_AUTOMATIC_CLOSE_KEY
FS_AUTOMATIC_CLOSE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
FS_DEFAULT_NAME_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for FS_DEFAULT_NAME_KEY
FS_DEFAULT_NAME_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
FS_DEFAULT_NAME_KEY - Static variable in class org.apache.hadoop.fs.FileSystem
 
FS_DF_INTERVAL_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for FS_DF_INTERVAL_KEY
FS_DF_INTERVAL_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
FS_FILE_IMPL_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
FS_FTP_HOST_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
FS_FTP_HOST_PORT_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
FS_LOCAL_BLOCK_SIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Not used anywhere, looks like default value for FS_LOCAL_BLOCK_SIZE
FS_TRASH_CHECKPOINT_INTERVAL_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for FS_TRASH_CHECKPOINT_INTERVAL_KEY
FS_TRASH_CHECKPOINT_INTERVAL_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
FS_TRASH_INTERVAL_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for FS_TRASH_INTERVAL_KEY
FS_TRASH_INTERVAL_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
FsConstants - Interface in org.apache.hadoop.fs
FileSystem related constants.
FSDataInputStream - Class in org.apache.hadoop.fs
Utility that wraps a FSInputStream in a DataInputStream and buffers input through a BufferedInputStream.
FSDataInputStream(InputStream) - Constructor for class org.apache.hadoop.fs.FSDataInputStream
 
FSDataOutputStream - Class in org.apache.hadoop.fs
Utility that wraps a OutputStream in a DataOutputStream, buffers output through a BufferedOutputStream and creates a checksum file.
FSDataOutputStream(OutputStream) - Constructor for class org.apache.hadoop.fs.FSDataOutputStream
Deprecated.
FSDataOutputStream(OutputStream, FileSystem.Statistics) - Constructor for class org.apache.hadoop.fs.FSDataOutputStream
 
FSDataOutputStream(OutputStream, FileSystem.Statistics, long) - Constructor for class org.apache.hadoop.fs.FSDataOutputStream
 
FSError - Error in org.apache.hadoop.fs
Thrown for unexpected filesystem errors, presumed to reflect disk errors in the native filesystem.
FsPermission - Class in org.apache.hadoop.fs.permission
A class for file/directory permissions.
FsPermission(FsAction, FsAction, FsAction) - Constructor for class org.apache.hadoop.fs.permission.FsPermission
Construct by the given FsAction.
FsPermission(FsAction, FsAction, FsAction, boolean) - Constructor for class org.apache.hadoop.fs.permission.FsPermission
 
FsPermission(short) - Constructor for class org.apache.hadoop.fs.permission.FsPermission
Construct by the given mode.
FsPermission(FsPermission) - Constructor for class org.apache.hadoop.fs.permission.FsPermission
Copy constructor
FsPermission(String) - Constructor for class org.apache.hadoop.fs.permission.FsPermission
Construct by given mode, either in octal or symbolic format.
FsServerDefaults - Class in org.apache.hadoop.fs
Provides server default configuration values to clients.
FsServerDefaults() - Constructor for class org.apache.hadoop.fs.FsServerDefaults
 
FsServerDefaults(long, int, int, short, int, DataChecksum.Type) - Constructor for class org.apache.hadoop.fs.FsServerDefaults
 
FsStatus - Class in org.apache.hadoop.fs
This class is used to represent the capacity, free and used space on a FileSystem.
FsStatus(long, long, long) - Constructor for class org.apache.hadoop.fs.FsStatus
Construct a FsStatus object, using the specified statistics
FTP_SCHEME - Static variable in interface org.apache.hadoop.fs.FsConstants
 
FTPException - Exception in org.apache.hadoop.fs.ftp
A class to wrap a Throwable into a Runtime Exception.
FTPException(String) - Constructor for exception org.apache.hadoop.fs.ftp.FTPException
 
FTPException(Throwable) - Constructor for exception org.apache.hadoop.fs.ftp.FTPException
 
FTPException(String, Throwable) - Constructor for exception org.apache.hadoop.fs.ftp.FTPException
 
FTPFileSystem - Class in org.apache.hadoop.fs.ftp
A FileSystem backed by an FTP client provided by Apache Commons Net.
FTPFileSystem() - Constructor for class org.apache.hadoop.fs.ftp.FTPFileSystem
 
fullyDelete(File) - Static method in class org.apache.hadoop.fs.FileUtil
Delete a directory and all its contents.
fullyDelete(File, boolean) - Static method in class org.apache.hadoop.fs.FileUtil
Delete a directory and all its contents.
fullyDelete(FileSystem, Path) - Static method in class org.apache.hadoop.fs.FileUtil
fullyDeleteContents(File) - Static method in class org.apache.hadoop.fs.FileUtil
Delete the contents of a directory, not the directory itself.
fullyDeleteContents(File, boolean) - Static method in class org.apache.hadoop.fs.FileUtil
Delete the contents of a directory, not the directory itself.

G

GangliaContext - Class in org.apache.hadoop.metrics.ganglia
Context for sending metrics to Ganglia.
GangliaContext() - Constructor for class org.apache.hadoop.metrics.ganglia.GangliaContext
Creates a new instance of GangliaContext
gauge(MetricsInfo, int) - Method in interface org.apache.hadoop.metrics2.MetricsVisitor
Callback for integer value gauges
gauge(MetricsInfo, long) - Method in interface org.apache.hadoop.metrics2.MetricsVisitor
Callback for long value gauges
gauge(MetricsInfo, float) - Method in interface org.apache.hadoop.metrics2.MetricsVisitor
Callback for float value gauges
gauge(MetricsInfo, double) - Method in interface org.apache.hadoop.metrics2.MetricsVisitor
Callback for double value gauges
genCode(String, String, ArrayList<String>) - Method in class org.apache.hadoop.record.compiler.JFile
Deprecated.
Generate record code in given language.
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.
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.
generateParseException() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
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
 
GenericWritable - Class in org.apache.hadoop.io
A wrapper for Writable instances.
GenericWritable() - Constructor for class org.apache.hadoop.io.GenericWritable
 
get(String) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property, null if no such property exists.
get(String, String) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name.
get(URI, Configuration) - Static method in class org.apache.hadoop.fs.AbstractFileSystem
The main factory method for creating a file system.
get(URI, Configuration, String) - Static method in class org.apache.hadoop.fs.FileSystem
Get a filesystem instance based on the uri, the passed configuration and the user
get(Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
Returns the configured filesystem implementation.
get(URI, Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
Returns the FileSystem for this URI's scheme and authority.
get() - Method in class org.apache.hadoop.io.ArrayPrimitiveWritable
Get the original array.
get() - Method in class org.apache.hadoop.io.ArrayWritable
 
get() - Method in class org.apache.hadoop.io.BooleanWritable
Returns the value of the BooleanWritable
get() - Method in class org.apache.hadoop.io.BytesWritable
Deprecated.
get() - Method in class org.apache.hadoop.io.ByteWritable
Return the value of this ByteWritable.
get() - Method in class org.apache.hadoop.io.DoubleWritable
 
get() - Method in class org.apache.hadoop.io.EnumSetWritable
Return the value of this EnumSetWritable.
get() - Method in class org.apache.hadoop.io.FloatWritable
Return the value of this FloatWritable.
get() - Method in class org.apache.hadoop.io.GenericWritable
Return the wrapped instance.
get() - Method in class org.apache.hadoop.io.IntWritable
Return the value of this IntWritable.
get() - Method in class org.apache.hadoop.io.LongWritable
Return the value of this LongWritable.
get(Object) - Method in class org.apache.hadoop.io.MapWritable
get() - Static method in class org.apache.hadoop.io.NullWritable
Returns the single instance of this class.
get() - Method in class org.apache.hadoop.io.ObjectWritable
Return the instance, or null if none.
get() - Method in class org.apache.hadoop.io.ShortWritable
Return the value of this ShortWritable.
get(Object) - Method in class org.apache.hadoop.io.SortedMapWritable
get() - Method in class org.apache.hadoop.io.TwoDArrayWritable
 
get() - Method in class org.apache.hadoop.io.VIntWritable
Return the value of this VIntWritable.
get() - Method in class org.apache.hadoop.io.VLongWritable
Return the value of this LongWritable.
get(Class<? extends WritableComparable>) - Static method in class org.apache.hadoop.io.WritableComparator
Get a comparator for a WritableComparable implementation.
get(int) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Get ith child InputSplit.
get(int) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
Get ith child InputSplit.
get(int) - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Get ith Writable from Tuple.
get(String) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Get a metric by name
get(String, Collection<MetricsTag>) - Method in class org.apache.hadoop.metrics2.util.MetricsCache
Get the cached record
get(DataInput) - Static method in class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
Get a thread-local record input for the supplied DataInput.
get(DataOutput) - Static method in class org.apache.hadoop.record.BinaryRecordOutput
Deprecated.
Get a thread-local record output for the supplied DataOutput.
get() - Method in class org.apache.hadoop.record.Buffer
Deprecated.
Get the data from the Buffer.
getAccessTime() - Method in class org.apache.hadoop.fs.FileStatus
Get the access time of the file.
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.
getAdjustedEnd() - Method in class org.apache.hadoop.io.compress.SplitCompressionInputStream
After calling createInputStream, the values of start or end might change.
getAdjustedStart() - Method in class org.apache.hadoop.io.compress.SplitCompressionInputStream
After calling createInputStream, the values of start or end might change.
getAggregatorDescriptors(Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
getAlgorithmName() - Method in class org.apache.hadoop.fs.FileChecksum
The checksum algorithm name
getAllApplications(GetAllApplicationsRequest) - Method in interface org.apache.hadoop.yarn.api.ClientRMProtocol
The interface used by clients to get a report of all Applications in the cluster from the ResourceManager.
GetAllApplicationsRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The request from clients to get a report of all Applications in the cluster from the ResourceManager.
GetAllApplicationsResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting an ApplicationReport for all applications.
getAllFileInfo() - Method in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
 
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.
getAllJobStatuses() - Method in class org.apache.hadoop.mapreduce.Cluster
Get job status for all jobs in the cluster.
getAllocatedContainers() - Method in interface org.apache.hadoop.yarn.api.records.AMResponse
Get the list of newly allocated Container by the ResourceManager.
getAllPartialJobs() - Method in interface org.apache.hadoop.mapreduce.v2.hs.HistoryStorage
Get all of the cached jobs.
getAllQueues() - Method in interface org.apache.hadoop.yarn.client.YarnClient
Get information (QueueInfo) about all queues, recursively if there is a hierarchy
getAllQueues() - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
getAllQueues() - Method in interface org.hadoop.yarn.client.YarnClient
Get information (QueueInfo) about all queues, recursively if there is a hierarchy
getAllQueues() - Method in class org.hadoop.yarn.client.YarnClientImpl
 
getAllRecords() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Retrieves all the records managed by this MetricsContext.
getAllServiceResponse() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.StartContainerResponse
Get the responses from all auxiliary services running on the NodeManager.
getAllStatistics() - Static method in class org.apache.hadoop.fs.AbstractFileSystem
 
getAllStatistics() - Static method in class org.apache.hadoop.fs.FileContext
 
getAllStatistics() - Static method in class org.apache.hadoop.fs.FileSystem
Return the FileSystem classes that have Statistics
getAllTaskTypes() - Static method in class org.apache.hadoop.mapreduce.TaskID
 
getAMContainerSpec() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the ContainerLaunchContext to describe the Container with which the ApplicationMaster is launched.
getAMResponse() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
Get the AMResponse sent by the ResourceManager.
getApplicationACLs() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
Get the ApplicationACLs for the application.
getApplicationACLs() - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get the ApplicationACLs for the application.
getApplicationAttemptId() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
Get the ApplicationAttemptId being managed by the ApplicationMaster.
getApplicationAttemptId() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
Get the ApplicationAttemptId being managed by the ApplicationMaster.
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.api.records.ContainerId
Get the ApplicationAttemptId of the application to which the Container was assigned.
getApplicationId() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportRequest
Get the ApplicationId of the application.
getApplicationId() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse
Get the new ApplicationId allocated by the ResourceManager.
getApplicationId() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.KillApplicationRequest
Get the ApplicationId of the application to be aborted.
getApplicationId() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
Get the ApplicationId of the ApplicationAttempId.
getApplicationId() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the ApplicationId of the application.
getApplicationId() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the ApplicationId of the submitted application.
getApplicationList() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetAllApplicationsResponse
Get ApplicationReport for all applications.
getApplicationList() - Method in interface org.apache.hadoop.yarn.client.YarnClient
Get a report (ApplicationReport) of all Applications in the cluster.
getApplicationList() - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
getApplicationList() - Method in interface org.hadoop.yarn.client.YarnClient
Get a report (ApplicationReport) of all Applications in the cluster.
getApplicationList() - Method in class org.hadoop.yarn.client.YarnClientImpl
 
getApplicationName() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the application name.
getApplicationReport(GetApplicationReportRequest) - Method in interface org.apache.hadoop.yarn.api.ClientRMProtocol
The interface used by clients to get a report of an Application from the ResourceManager.
getApplicationReport() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportResponse
Get the ApplicationReport for the application.
getApplicationReport(ApplicationId) - Method in interface org.apache.hadoop.yarn.client.YarnClient
Get a report of the given Application.
getApplicationReport(ApplicationId) - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
getApplicationReport(ApplicationId) - Method in interface org.hadoop.yarn.client.YarnClient
Get a report of the given Application.
getApplicationReport(ApplicationId) - Method in class org.hadoop.yarn.client.YarnClientImpl
 
GetApplicationReportRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The request sent by a client to the ResourceManager to get an ApplicationReport for an application.
GetApplicationReportResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting an application report.
getApplicationResourceUsageReport() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Retrieve the structure containing the job resources for this application
getApplications() - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
Get the running applications of the queue.
getApplicationSubmissionContext() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.SubmitApplicationRequest
Get the ApplicationSubmissionContext for the application.
getApproxChkSumLength(long) - Static method in class org.apache.hadoop.fs.ChecksumFileSystem
 
getArchiveClassPaths() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the archive entries in classpath as an array of Path
getArchiveTimestamps() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the timestamps of the archives.
getAsk(int) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
getAskCount() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
getAskList() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
Get the list of ResourceRequest to update the ResourceManager about the application's resource requirements.
getAssignedJobID() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
 
getAttemptId() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
Get the attempt id of the Application.
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.
getAttribute(String) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Convenience method for subclasses to access factory attributes.
getAttributeTable(String) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Returns an attribute-value map derived from the factory attributes by finding all factory attributes that begin with contextName.tableName.
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.
getAvailableResources() - Method in interface org.apache.hadoop.yarn.api.records.AMResponse
Get the available headroom for resources in the cluster for the application.
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
 
getBeginColumn() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
getBeginLine() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
getBlackListedTaskTrackerCount() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of blacklisted trackers in the cluster.
getBlackListedTaskTrackers() - Method in class org.apache.hadoop.mapreduce.Cluster
Get blacklisted trackers.
getBlacklistedTrackerNames() - Method in class org.apache.hadoop.mapred.ClusterStatus
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.
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.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
 
getBlockLocations() - Method in class org.apache.hadoop.fs.LocatedFileStatus
Get the file's block locations
getBlockSize() - Method in class org.apache.hadoop.fs.FileStatus
Get the block size of the file.
getBlockSize(Path) - Method in class org.apache.hadoop.fs.FileSystem
Deprecated.
Use getFileStatus() instead
getBlockSize() - Method in class org.apache.hadoop.fs.FsServerDefaults
 
getBoolean(String, boolean) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a boolean.
getBoundingValsQuery() - Method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
 
getBytes() - Method in class org.apache.hadoop.fs.FileChecksum
The value of the checksum in bytes
getBytes() - Method in class org.apache.hadoop.io.BinaryComparable
Return representative byte array for this instance.
getBytes() - Method in class org.apache.hadoop.io.BytesWritable
Get the data backing the BytesWritable.
getBytes() - Method in class org.apache.hadoop.io.Text
Returns the raw bytes; however, only data up to Text.getLength() is valid.
getBytesPerChecksum() - Method in class org.apache.hadoop.fs.FsServerDefaults
 
getBytesPerSum() - Method in class org.apache.hadoop.fs.ChecksumFileSystem
Return the bytes Per Checksum
getBytesRead() - Method in interface org.apache.hadoop.io.compress.Compressor
Return number of uncompressed bytes input so far.
getBytesWritten() - Method in interface org.apache.hadoop.io.compress.Compressor
Return number of compressed bytes output so far.
getCacheArchives() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get cache archives set in the Configuration
getCacheFiles() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get cache files set in the Configuration
getCancelTokensWhenComplete() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
 
getCanonicalServiceName() - Method in class org.apache.hadoop.fs.AbstractFileSystem
Get a canonical name for this file system.
getCanonicalServiceName() - Method in class org.apache.hadoop.fs.FileSystem
Get a canonical service name for this file system.
getCanonicalUri() - Method in class org.apache.hadoop.fs.FileSystem
Resolve the uri's hostname and add the default port if not in the uri
getCanonicalUri() - Method in class org.apache.hadoop.fs.FilterFileSystem
Returns a qualified URI whose scheme and authority identify this FileSystem.
getCapability() - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
Get the total Resource on the node.
getCapability() - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
Get the Resource capability of the request.
getCapacity() - Method in class org.apache.hadoop.fs.FsStatus
Return the capacity in bytes of the file system
getCapacity() - Method in class org.apache.hadoop.io.BytesWritable
Get the capacity, which is the maximum size that could handled without resizing the backing storage.
getCapacity() - Method in class org.apache.hadoop.record.Buffer
Deprecated.
Get the capacity, which is the maximum count that could handled without resizing the backing storage.
getCapacity() - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
Get the configured capacity of the queue.
getChecksumFile(Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
Return the name of the checksum file associated with a file.
getChecksumFileLength(Path, long) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
Return the length of the checksum file given the size of the actual file.
getChecksumLength(long, int) - Static method in class org.apache.hadoop.fs.ChecksumFileSystem
Calculated the length of the checksum file in bytes.
getChecksumType() - Method in class org.apache.hadoop.fs.FsServerDefaults
 
getChildFileSystems() - Method in class org.apache.hadoop.fs.FileSystem
Get all the immediate child FileSystems embedded in this FileSystem.
getChildFileSystems() - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getChildFileSystems() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getChildQueueInfos(String) - Method in interface org.apache.hadoop.yarn.client.YarnClient
Get information (QueueInfo) about all the immediate children queues of the given queue
getChildQueueInfos(String) - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
getChildQueueInfos(String) - Method in interface org.hadoop.yarn.client.YarnClient
Get information (QueueInfo) about all the immediate children queues of the given queue
getChildQueueInfos(String) - Method in class org.hadoop.yarn.client.YarnClientImpl
 
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() - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
Get the child queues of the queue.
getChildren() - Method in class org.apache.hadoop.mapred.JobQueueInfo
 
getClass(String, Class<?>) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a Class.
getClass(String, Class<? extends U>, Class<U>) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a Class implementing the interface specified by xface.
getClass(byte) - Method in class org.apache.hadoop.io.AbstractMapWritable
 
getClass(T) - Static method in class org.apache.hadoop.util.ReflectionUtils
Return the correctly-typed Class of the given object.
getClassByName(String) - Method in class org.apache.hadoop.conf.Configuration
Load a class by name.
getClassByNameOrNull(String) - Method in class org.apache.hadoop.conf.Configuration
Load a class by name, returning null rather than throwing an exception if it couldn't be loaded.
getClasses(String, Class<?>...) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as an array of Class.
getClassLoader() - Method in class org.apache.hadoop.conf.Configuration
Get the ClassLoader for this job.
getCleanupProgress() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getCleanupTaskReports(JobID) - Method in class org.apache.hadoop.mapred.JobClient
Get the information of the current state of the cleanup tasks of a job.
getClientToken() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the client token for communicating with the ApplicationMaster.
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(GetClusterMetricsRequest) - Method in interface org.apache.hadoop.yarn.api.ClientRMProtocol
The interface used by clients to get metrics about the cluster from the ResourceManager.
getClusterMetrics() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetClusterMetricsResponse
Get the YarnClusterMetrics for the cluster.
GetClusterMetricsRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The request sent by clients to get cluster metrics from the ResourceManager.
GetClusterMetricsResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting cluster metrics.
getClusterNodes(GetClusterNodesRequest) - Method in interface org.apache.hadoop.yarn.api.ClientRMProtocol
The interface used by clients to get a report of all nodes in the cluster from the ResourceManager.
GetClusterNodesRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The request from clients to get a report of all nodes in the cluster from the ResourceManager.
GetClusterNodesResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting a NodeReport for all nodes.
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.
getClusterTimestamp() - Method in class org.apache.hadoop.yarn.api.records.ApplicationId
Get the start time of the ResourceManager which is used to generate globally unique ApplicationId.
getCodec(Path) - Method in class org.apache.hadoop.io.compress.CompressionCodecFactory
Find the relevant compression codec for the given file based on its filename suffix.
getCodecByClassName(String) - Method in class org.apache.hadoop.io.compress.CompressionCodecFactory
Find the relevant compression codec for the codec's canonical class name.
getCodecByName(String) - Method in class org.apache.hadoop.io.compress.CompressionCodecFactory
Find the relevant compression codec for the codec's canonical class name or by codec alias.
getCodecClassByName(String) - Method in class org.apache.hadoop.io.compress.CompressionCodecFactory
Find the relevant compression codec for the codec's canonical class name or by codec alias and returns its implemetation class.
getCodecClasses(Configuration) - Static method in class org.apache.hadoop.io.compress.CompressionCodecFactory
Get the list of codecs listed in the configuration
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.
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 interface org.apache.hadoop.mapreduce.JobContext
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
 
getCommands() - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get the list of commands for launching the container.
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.
getCompletedContainersStatuses() - Method in interface org.apache.hadoop.yarn.api.records.AMResponse
Get the list of completed containers' statuses.
getCompletionPollInterval(Configuration) - Static method in class org.apache.hadoop.mapreduce.Job
The interval at which waitForCompletion() should check.
getComponentType() - Method in class org.apache.hadoop.io.ArrayPrimitiveWritable
 
getCompressedData() - Method in class org.apache.hadoop.io.compress.BlockDecompressorStream
 
getCompressedData() - Method in class org.apache.hadoop.io.compress.DecompressorStream
 
getCompressMapOutput() - Method in class org.apache.hadoop.mapred.JobConf
Are the outputs of the maps be compressed?
getCompressor(CompressionCodec, Configuration) - Static method in class org.apache.hadoop.io.compress.CodecPool
Get a Compressor for the given CompressionCodec from the pool or a new one.
getCompressor(CompressionCodec) - Static method in class org.apache.hadoop.io.compress.CodecPool
 
getCompressorType() - Method in class org.apache.hadoop.io.compress.BZip2Codec
Get the type of Compressor needed by this CompressionCodec.
getCompressorType() - Method in interface org.apache.hadoop.io.compress.CompressionCodec
Get the type of Compressor needed by this CompressionCodec.
getCompressorType() - Method in class org.apache.hadoop.io.compress.DefaultCodec
 
getCompressorType() - Method in class org.apache.hadoop.io.compress.GzipCodec
 
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 interface org.apache.hadoop.conf.Configurable
Return the configuration used by this object.
getConf() - Method in class org.apache.hadoop.conf.Configured
 
getConf() - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getConf() - Method in class org.apache.hadoop.io.AbstractMapWritable
 
getConf() - Method in class org.apache.hadoop.io.compress.BZip2Codec
Return the configuration used by this object.
getConf() - Method in class org.apache.hadoop.io.compress.DefaultCodec
 
getConf() - Method in class org.apache.hadoop.io.EnumSetWritable
Return the configuration used by this object.
getConf() - Method in class org.apache.hadoop.io.GenericWritable
 
getConf() - Method in class org.apache.hadoop.io.ObjectWritable
 
getConf() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Return the configuration used by this object.
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.join.CompositeRecordReader
Return the configuration used by this object.
getConf() - Method in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
 
getConf() - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
 
getConf() - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
 
getConf() - Method in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
getConf() - Method in class org.apache.hadoop.net.AbstractDNSToSwitchMapping
 
getConf() - Method in class org.apache.hadoop.net.ScriptBasedMapping
 
getConf() - Method in class org.apache.hadoop.net.SocksSocketFactory
 
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.
getConfResourceAsInputStream(String) - Method in class org.apache.hadoop.conf.Configuration
Get an input stream attached to the configuration resource with the given name.
getConfResourceAsReader(String) - Method in class org.apache.hadoop.conf.Configuration
Get a Reader attached to the configuration resource with the given name.
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.DBRecordReader
 
getContainerId() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusRequest
Get the ContainerId of container for which to obtain the ContainerStatus.
getContainerId() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.StopContainerRequest
Get the ContainerId of the container to be stopped.
getContainerId() - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get ContainerId of container to be launched.
getContainerId() - Method in interface org.apache.hadoop.yarn.api.records.ContainerStatus
Get the ContainerId of the container.
getContainerLaunchContext() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.StartContainerRequest
Get the ContainerLaunchContext for the container to be started by the NodeManager.
getContainerStatus(GetContainerStatusRequest) - Method in interface org.apache.hadoop.yarn.api.ContainerManager
The api used by the ApplicationMaster to request for current status of a Container from the NodeManager.
getContainerStatus() - Method in interface org.apache.hadoop.yarn.api.records.Container
Get the ContainerStatus of the container.
GetContainerStatusRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The request sent by the ApplicationMaster to the NodeManager to get ContainerStatus of a container.
GetContainerStatusResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the NodeManager to the ApplicationMaster when asked to obtain the status of a container.
getContainerToken() - Method in interface org.apache.hadoop.yarn.api.records.Container
Get the ContainerToken for the container.
getContainerTokens() - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get security tokens (if security is enabled).
getContentSummary(Path) - Method in class org.apache.hadoop.fs.FileSystem
Return the ContentSummary of a given Path.
getContentSummary(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getContentSummary(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getContextFactory() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Returns the factory by which this context was created.
getContextName() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Returns the context name.
getCount() - Method in class org.apache.hadoop.record.Buffer
Deprecated.
Get the current count of the buffer.
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(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(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
 
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.mapreduce.Job
Gets the counters for this job.
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.
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.
getCurrentCapacity() - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
Get the current capacity of the queue.
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Get the current key
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.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.RecordReader
Get the current key
getCurrentKey() - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Get the current key.
getCurrentTrashDir() - Method in class org.apache.hadoop.fs.TrashPolicy
Get the current working directory of the Trash Policy
getCurrentValue(V) - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Get the current value.
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.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.RecordReader
Get the current value.
getCurrentValue() - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Get the current value.
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
 
getDeclaredClass() - Method in class org.apache.hadoop.io.ObjectWritable
Return the class this is meant to be.
getDeclaredComponentType() - Method in class org.apache.hadoop.io.ArrayPrimitiveWritable
 
getDecommissionedTaskTrackerCount() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of decommissioned trackers in the cluster.
getDecompressor(CompressionCodec) - Static method in class org.apache.hadoop.io.compress.CodecPool
Get a Decompressor for the given CompressionCodec from the pool or a new one.
getDecompressorType() - Method in class org.apache.hadoop.io.compress.BZip2Codec
Get the type of Decompressor needed by this CompressionCodec.
getDecompressorType() - Method in interface org.apache.hadoop.io.compress.CompressionCodec
Get the type of Decompressor needed by this CompressionCodec.
getDecompressorType() - Method in class org.apache.hadoop.io.compress.DefaultCodec
 
getDecompressorType() - Method in class org.apache.hadoop.io.compress.GzipCodec
 
getDefault() - Static method in class org.apache.hadoop.fs.permission.FsPermission
Get the default permission for directory and symlink.
getDefaultBlockSize() - Method in class org.apache.hadoop.fs.FileSystem
Return the number of bytes that large input files should be optimally be split into to minimize i/o time.
getDefaultBlockSize(Path) - Method in class org.apache.hadoop.fs.FileSystem
Return the number of bytes that large input files should be optimally be split into to minimize i/o time.
getDefaultBlockSize() - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getDefaultBlockSize(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getDefaultBlockSize() - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
getDefaultBlockSize() - Method in class org.apache.hadoop.fs.s3.S3FileSystem
 
getDefaultBlockSize() - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
getDefaultBlockSize() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getDefaultBlockSize(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getDefaultCompressionType(Configuration) - Static method in class org.apache.hadoop.io.SequenceFile
Get the compression type for the reduce outputs
getDefaultExtension() - Method in class org.apache.hadoop.io.compress.BZip2Codec
.bz2 is recognized as the default extension for compressed BZip2 files
getDefaultExtension() - Method in interface org.apache.hadoop.io.compress.CompressionCodec
Get the default filename extension for this kind of compression.
getDefaultExtension() - Method in class org.apache.hadoop.io.compress.DefaultCodec
 
getDefaultExtension() - Method in class org.apache.hadoop.io.compress.GzipCodec
 
getDefaultFileSystem() - Method in class org.apache.hadoop.fs.FileContext
 
getDefaultMaps() - Method in class org.apache.hadoop.mapred.JobClient
Get status information about the max available Maps in the cluster.
getDefaultPort() - Method in class org.apache.hadoop.fs.FileSystem
Get the default port for this file system.
getDefaultReduces() - Method in class org.apache.hadoop.mapred.JobClient
Get status information about the max available Reduces in the cluster.
getDefaultReplication() - Method in class org.apache.hadoop.fs.FileSystem
Get the default replication.
getDefaultReplication(Path) - Method in class org.apache.hadoop.fs.FileSystem
Get the default replication for a path.
getDefaultReplication() - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getDefaultReplication(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getDefaultReplication() - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
getDefaultReplication() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getDefaultReplication(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getDefaultUri(Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
Get the default filesystem URI from a configuration.
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(String) - Method in class org.apache.hadoop.fs.FileSystem
Get a new delegation token for this file system.
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() - Method in interface org.apache.hadoop.mapreduce.v2.api.protocolrecords.CancelDelegationTokenRequest
 
getDelegationToken() - Method in interface org.apache.hadoop.mapreduce.v2.api.protocolrecords.RenewDelegationTokenRequest
 
getDelegationToken(GetDelegationTokenRequest) - Method in interface org.apache.hadoop.yarn.api.ClientRMProtocol
The interface used by clients to get delegation token, enabling the containers to be able to talk to the service using those tokens.
getDelegationToken() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.CancelDelegationTokenRequest
 
getDelegationToken() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RenewDelegationTokenRequest
 
GetDelegationTokenRequest - Interface in org.apache.hadoop.mapreduce.v2.api.protocolrecords
 
GetDelegationTokenRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The request issued by the client to get a delegation token from the ResourceManager.
GetDelegationTokenResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
Response to a GetDelegationTokenRequest request from the client.
getDelegationTokens(String) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Get one or more delegation tokens associated with the filesystem.
getDelegationTokens(Path, String) - Method in class org.apache.hadoop.fs.FileContext
Get delegation tokens for the file systems accessed for a given path.
getDelegationTokens(String) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getDependentJobs() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
getDependingJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
 
getDeserializer(Class<T>) - Method in class org.apache.hadoop.io.serializer.avro.AvroSerialization
 
getDeserializer(Class<Serializable>) - Method in class org.apache.hadoop.io.serializer.JavaSerialization
 
getDeserializer(Class<Writable>) - Method in class org.apache.hadoop.io.serializer.WritableSerialization
 
getDiagnostics() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the diagnositic information of the application in case of errors.
getDiagnostics() - Method in interface org.apache.hadoop.yarn.api.records.ContainerStatus
Get diagnostic messages for failed containers.
getDigest() - Method in class org.apache.hadoop.io.MD5Hash
Returns the digest bytes.
getDigester() - Static method in class org.apache.hadoop.io.MD5Hash
Create a thread local MD5 digester
getDirDefault() - Static method in class org.apache.hadoop.fs.permission.FsPermission
Get the default permission for directory.
getDirectoryCount() - Method in class org.apache.hadoop.fs.ContentSummary
 
getDisplayName() - Method in interface org.apache.hadoop.mapreduce.Counter
Get the display name of the counter.
getDisplayName() - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
Get the display name of the group.
getDmax(String) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
getDU(File) - Static method in class org.apache.hadoop.fs.FileUtil
Takes an input dir and returns the du on that local directory.
getElementType() - Method in class org.apache.hadoop.io.EnumSetWritable
Returns the class of all the elements of the underlying EnumSetWriable.
getElementTypeID() - Method in class org.apache.hadoop.record.meta.VectorTypeID
Deprecated.
 
getEmptier() - Method in class org.apache.hadoop.fs.Trash
Return a Runnable that periodically empties the trash of all users, intended to be run by the superuser.
getEmptier() - Method in class org.apache.hadoop.fs.TrashPolicy
Return a Runnable that periodically empties the trash of all users, intended to be run by the superuser.
getEndColumn() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
getEndLine() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
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.
getEnum(String, T) - Method in class org.apache.hadoop.conf.Configuration
Return value matching this enumerated type.
getEnvironment() - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get environment variables for the container.
getError() - Static method in class org.apache.hadoop.log.metrics.EventCounter
 
getEventId() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Returns event Id.
getExceptions() - Method in exception org.apache.hadoop.io.MultipleIOException
 
getExecutable(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Get the URI of the application's executable.
getExitStatus() - Method in interface org.apache.hadoop.yarn.api.records.ContainerStatus
Get the exit status for the container.
getFactory(Class) - Static method in class org.apache.hadoop.io.WritableFactories
Define a factory for a class.
getFailedJobList() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getFailedJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
 
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.
getFatal() - Static method in class org.apache.hadoop.log.metrics.EventCounter
 
getFieldID() - Method in class org.apache.hadoop.record.meta.FieldTypeInfo
Deprecated.
get the field's id (name)
getFieldNames() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getFieldTypeInfos() - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
Deprecated.
Return a collection of field type infos
getFieldTypeInfos() - Method in class org.apache.hadoop.record.meta.StructTypeID
Deprecated.
 
getFile(String, String) - Method in class org.apache.hadoop.conf.Configuration
Get a local file name under a directory named in dirsProp with the given path.
getFile() - Method in interface org.apache.hadoop.yarn.api.records.URL
Get the file of the URL.
getFileBlockLocations(Path, long, long) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.getFileBlockLocations(Path, long, long) except that Path f must be for this file system.
getFileBlockLocations(Path, long, long) - Method in class org.apache.hadoop.fs.FileContext
Return blockLocation of the given file for the given offset and len.
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.hadoop.fs.FileSystem
Return an array containing hostnames, offset and size of portions of the given file.
getFileBlockLocations(Path, long, long) - Method in class org.apache.hadoop.fs.FileSystem
Return an array containing hostnames, offset and size of portions of the given file.
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
Return null if the file doesn't exist; otherwise, get the locations of the various chunks of the file file from KFS.
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getFileBlockLocations(Path, long, long) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getFileBlockLocations(FileSystem, FileStatus) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
 
getFileBufferSize() - Method in class org.apache.hadoop.fs.FsServerDefaults
 
getFileChecksum(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.getFileChecksum(Path) except that Path f must be for this file system.
getFileChecksum(Path) - Method in class org.apache.hadoop.fs.FileContext
Get the checksum of a file.
getFileChecksum(Path) - Method in class org.apache.hadoop.fs.FileSystem
Get the checksum of a file.
getFileChecksum(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
Get the checksum of a file.
getFileChecksum(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getFileChecksum(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getFileClassPaths() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the file entries in classpath as an array of Path
getFileContext(AbstractFileSystem, Configuration) - Static method in class org.apache.hadoop.fs.FileContext
Create a FileContext with specified FS as default using the specified config.
getFileContext(AbstractFileSystem) - Static method in class org.apache.hadoop.fs.FileContext
Create a FileContext for specified file system using the default config.
getFileContext() - Static method in class org.apache.hadoop.fs.FileContext
Create a FileContext using the default config read from the $HADOOP_CONFIG/core.xml, Unspecified key-values for config are defaulted from core-defaults.xml in the release jar.
getFileContext(URI) - Static method in class org.apache.hadoop.fs.FileContext
Create a FileContext for specified URI using the default config.
getFileContext(URI, Configuration) - Static method in class org.apache.hadoop.fs.FileContext
Create a FileContext for specified default URI using the specified config.
getFileContext(Configuration) - Static method in class org.apache.hadoop.fs.FileContext
Create a FileContext using the passed config.
getFileCount() - Method in class org.apache.hadoop.fs.ContentSummary
 
getFileDefault() - Static method in class org.apache.hadoop.fs.permission.FsPermission
Get the default permission for file.
getFileInfo(JobId) - Method in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
 
getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.getFileLinkStatus(Path) except that an UnresolvedLinkException may be thrown if a symlink is encountered in the path leading up to the final path component.
getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.FileContext
Return a file status object that represents the path.
getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getFileName() - Method in class org.apache.hadoop.metrics.file.FileContext
Deprecated.
Returns the configured file name, or null.
getFileStatus(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.getFileStatus(Path) except that an UnresolvedLinkException may be thrown if a symlink is encountered in the path.
getFileStatus(Path) - Method in class org.apache.hadoop.fs.FileContext
Return a file status object that represents the path.
getFileStatus(Path) - Method in class org.apache.hadoop.fs.FileSystem
Return a file status object that represents the path.
getFileStatus(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
Get file status.
getFileStatus(Path) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
getFileStatus(Path) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
getFileStatus(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
getFileStatus(Path) - Method in class org.apache.hadoop.fs.s3.S3FileSystem
FileStatus for S3 file systems.
getFileStatus(Path) - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
getFileStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getFileStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getFileSystem(Configuration) - Method in class org.apache.hadoop.fs.Path
Return the FileSystem that owns this Path.
getFileSystem() - Method in class org.apache.hadoop.mapreduce.Cluster
Get the file system where job-specific files are stored
getFileTimestamps() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the timestamps of the files.
getFinalApplicationStatus() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the final finish status of the application.
getFinalParameters() - Method in class org.apache.hadoop.conf.Configuration
Get the set of parameters marked final.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.Job
Get finish time of the job.
getFinishTime() - Method in class org.apache.hadoop.mapreduce.JobStatus
Get the finish time of the job.
getFinishTime() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the finish time of the application.
getFloat(String, float) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a float.
getFormatMinSplitSize() - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Get the lower bound on split size imposed by the format.
getFormatMinSplitSize() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFormat
 
getFs() - Method in class org.apache.hadoop.mapred.JobClient
Get a filesystem handle.
getFsStatus(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.getFsStatus(Path) except that Path f must be for this file system.
getFsStatus() - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.getFsStatus(Path).
getFsStatus(Path) - Method in class org.apache.hadoop.fs.FileContext
Returns a status object describing the use and capacity of the file system denoted by the Parh argument p.
getFsStatus() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getFullJob(JobId) - Method in interface org.apache.hadoop.mapreduce.v2.hs.HistoryStorage
Get a fully parsed job.
getGroup() - Method in class org.apache.hadoop.fs.FileStatus
Get the group associated with the file.
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.
getGroupAction() - Method in class org.apache.hadoop.fs.permission.FsPermission
Return group FsAction.
getGroupingComparator() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the user defined RawComparator comparator for grouping keys of inputs to the reduce.
getGroupNames() - Method in class org.apache.hadoop.mapred.Counters
 
getGroupNames() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Returns the names of all counter classes.
getGroups(String) - Method in interface org.apache.hadoop.security.GroupMappingServiceProvider
Get all various group memberships of a given user.
getHeader(boolean) - Static method in class org.apache.hadoop.fs.ContentSummary
Return the header of the output.
getHealthReport() - Method in interface org.apache.hadoop.yarn.api.records.NodeHealthStatus
Get the diagnostic health report of the node.
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
 
getHomeDirectory() - Method in class org.apache.hadoop.fs.AbstractFileSystem
Return the current user's home directory in this file system.
getHomeDirectory() - Method in class org.apache.hadoop.fs.FileContext
Return the current user's home directory in this file system.
getHomeDirectory() - Method in class org.apache.hadoop.fs.FileSystem
Return the current user's home directory in this filesystem.
getHomeDirectory() - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getHomeDirectory() - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
getHomeDirectory() - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
getHomeDirectory() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getHomeDirectory() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getHost() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
Get the host on which the ApplicationMaster is running.
getHost() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the host on which the ApplicationMaster is running.
getHost() - Method in class org.apache.hadoop.yarn.api.records.NodeId
Get the hostname of the node.
getHost() - Method in interface org.apache.hadoop.yarn.api.records.URL
Get the host of the URL.
getHostName() - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
Get the host/rack on which the allocation is desired.
getHosts() - Method in class org.apache.hadoop.fs.BlockLocation
Get the list of hosts (hostname) hosting this block
getHttpAddress() - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
Get the http address of the node.
getId(Class) - Method in class org.apache.hadoop.io.AbstractMapWritable
 
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
getId() - Method in class org.apache.hadoop.yarn.api.records.ApplicationId
Get the short integer identifier of the ApplicationId which is unique for all applications started by a particular instance of the ResourceManager.
getId() - Method in interface org.apache.hadoop.yarn.api.records.Container
Get the globally unique identifier for the container.
getId() - Method in class org.apache.hadoop.yarn.api.records.ContainerId
Get the identifier of the ContainerId.
getIdentifier() - Method in interface org.apache.hadoop.yarn.api.records.ContainerToken
Get the token identifier.
getIdentifier() - Method in interface org.apache.hadoop.yarn.api.records.DelegationToken
Get the token identifier.
GetImage() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
getIncludeApplications() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
Is information about active applications required?
getIncludeChildQueues() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
Is information about child queues required?
getInfo() - Static method in class org.apache.hadoop.log.metrics.EventCounter
 
getInitialWorkingDirectory() - Method in class org.apache.hadoop.fs.AbstractFileSystem
Some file systems like LocalFileSystem have an initial workingDir that is used as the starting workingDir.
getInitialWorkingDirectory() - Method in class org.apache.hadoop.fs.FileSystem
Note: with the new FilesContext class, getWorkingDirectory() will be removed.
getInitialWorkingDirectory() - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getInitialWorkingDirectory() - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
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
 
getInputDirRecursive(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
getInputFieldNames() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
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.
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.
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 interface org.apache.hadoop.mapreduce.MapContext
Get the input split for this map.
getInputTableName() - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
getInstance(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.fs.TrashPolicy
Get an instance of the configured TrashPolicy based on the value of the configuration paramater fs.trash.classname.
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.
getInstance(Cluster, Configuration) - Static method in class org.apache.hadoop.mapreduce.Job
getInstance(Cluster, JobStatus, Configuration) - Static method in class org.apache.hadoop.mapreduce.Job
Creates a new Job with no particular Cluster and given Configuration and JobStatus.
getInstances(String, Class<U>) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a List of objects implementing the interface specified by xface.
getInt(String, int) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as an int.
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.
getIsNodeHealthy() - Method in interface org.apache.hadoop.yarn.api.records.NodeHealthStatus
Is the node healthy?
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.
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.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.jobcontrol.Job
 
getJobConf() - Method in interface org.apache.hadoop.mapred.TaskAttemptContext
 
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 interface org.apache.hadoop.mapred.RunningJob
Get the path of the submitted job configuration.
getJobFile() - Method in class org.apache.hadoop.mapreduce.Job
Get the path of the submitted job configuration.
getJobFile() - Method in class org.apache.hadoop.mapreduce.JobStatus
Get the configuration file for the job.
getJobHistoryUrl(JobID) - Method in class org.apache.hadoop.mapreduce.Cluster
Get the job history file path for a given job id.
getJobId() - Method in class org.apache.hadoop.mapred.JobStatus
Deprecated.
use getJobID instead
getJobID() - Method in class org.apache.hadoop.mapred.JobStatus
 
getJobID() - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated.
This method is deprecated and will be removed. Applications should rather use RunningJob.getID().
getJobID() - Method in class org.apache.hadoop.mapred.TaskAttemptID
 
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.JobStatus
 
getJobID() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
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.
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 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.JobStatus
Get the user-specified job name.
getJobName() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
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
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
getJobsFromQueue(String) - Method in class org.apache.hadoop.mapred.JobClient
Gets all the jobs which were added to particular Job Queue
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
 
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
 
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.
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.mapreduce.lib.fieldsel.FieldSelectionHelper
 
getKeyClass() - Method in class org.apache.hadoop.io.WritableComparator
Returns the WritableComparable implementation class.
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
 
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
getKeyTypeID() - Method in class org.apache.hadoop.record.meta.MapTypeID
Deprecated.
get the TypeID of the map's key element
getKind() - Method in interface org.apache.hadoop.yarn.api.records.ContainerToken
Get the token kind.
getKind() - Method in interface org.apache.hadoop.yarn.api.records.DelegationToken
Get the token kind.
getKind() - Method in class org.apache.hadoop.yarn.security.client.RMDelegationTokenIdentifier
 
getLastHealthReportTime() - Method in interface org.apache.hadoop.yarn.api.records.NodeHealthStatus
Get the last timestamp at which the health report was received.
getLen() - Method in class org.apache.hadoop.fs.FileStatus
Get the length of this file, in bytes.
getLength() - Method in class org.apache.hadoop.fs.BlockLocation
Get the length of the block
getLength() - Method in class org.apache.hadoop.fs.ContentSummary
 
getLength() - Method in class org.apache.hadoop.fs.FileChecksum
The length of the checksum in bytes
getLength(Path) - Method in class org.apache.hadoop.fs.FileSystem
Deprecated.
Use getFileStatus() instead
getLength() - Method in class org.apache.hadoop.io.BinaryComparable
Return n st bytes 0..n-1 from {#getBytes()} are valid.
getLength() - Method in class org.apache.hadoop.io.BytesWritable
Get the current size of the buffer.
getLength() - Method in class org.apache.hadoop.io.Text
Returns the number of bytes in the byte array
getLength() - Method in class org.apache.hadoop.mapred.FileSplit
The number of bytes in the file to process.
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.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.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.
getLengths() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns an array containing the lengths of the files in the split
getLinkTarget(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.getLinkTarget(Path);
getLinkTarget(Path) - Method in class org.apache.hadoop.fs.FileContext
Returns the target of the given symbolic link as it was specified when the link was created.
getLinkTarget(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getLocal(Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
Get the local file system.
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().
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().
getLocalDirs() - Method in class org.apache.hadoop.mapred.JobConf
 
getLocalFSFileContext() - Static method in class org.apache.hadoop.fs.FileContext
 
getLocalFSFileContext(Configuration) - Static method in class org.apache.hadoop.fs.FileContext
 
getLocalPath(String, String) - Method in class org.apache.hadoop.conf.Configuration
Get a local file under a directory named by dirsProp with the given path.
getLocalPath(String) - Method in class org.apache.hadoop.mapred.JobConf
Constructs a local file name.
getLocalResources() - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get LocalResource required by the container.
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.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.
getLogParams(JobID, TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.Cluster
Get log parameters for the specified jobID or taskAttemptID
getLong(String, long) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a long.
getLongBytes(String, long) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a long or human readable format.
getMapContext(MapContext<KEYIN, VALUEIN, KEYOUT, VALUEOUT>) - Method in class org.apache.hadoop.mapreduce.lib.map.WrappedMapper
Get a wrapped Mapper.Context for custom implementations.
getMapDebugScript() - Method in class org.apache.hadoop.mapred.JobConf
Get the map task's debug script.
getMapOutputCompressorClass(Class<? extends CompressionCodec>) - Method in class org.apache.hadoop.mapred.JobConf
Get the CompressionCodec for compressing the map outputs.
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.
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.
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.
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.
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.
getMaximumCapacity() - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
Get the maximum capacity of the queue.
getMaximumResourceCapability() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse
Get the maximum capability for any Resource allocated by the ResourceManager in the cluster.
getMaximumResourceCapability() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
Get the maximum capability for any Resource allocated by the ResourceManager in the cluster.
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.
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.
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.
getMaxTaskFailuresPerTracker() - Method in class org.apache.hadoop.mapred.JobConf
Expert: Get the maximum no.
getMaxVirtualMemoryForTask() - Method in class org.apache.hadoop.mapred.JobConf
getMemory() - Method in class org.apache.hadoop.yarn.api.records.Resource
Get memory of the resource.
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.
getMessage() - Method in exception org.apache.hadoop.fs.viewfs.NotInMountpointException
 
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
 
getMessage() - Method in exception org.apache.hadoop.record.compiler.generated.ParseException
Deprecated.
This method has the standard behavior when this object has been created using the standard constructors.
getMessage() - Method in error org.apache.hadoop.record.compiler.generated.TokenMgrError
Deprecated.
You can also modify the body of this method to customize your error messages.
getMetric(String) - Method in class org.apache.hadoop.metrics.spi.OutputRecord
Returns the metric object which can be a Float, Integer, Short or Byte.
getMetricNames() - Method in class org.apache.hadoop.metrics.spi.OutputRecord
Returns the set of metric names.
getMetrics(MetricsCollector, boolean) - Method in interface org.apache.hadoop.metrics2.MetricsSource
Get metrics from the source
getMetricsCopy() - Method in class org.apache.hadoop.metrics.spi.OutputRecord
Returns a copy of this record's metrics.
getMinimumResourceCapability() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse
Get the minimum capability for any Resource allocated by the ResourceManager in the cluster.
getMinimumResourceCapability() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
Get the minimum capability for any Resource allocated by the ResourceManager in the cluster.
getMinSplitSize(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Get the minimum split size
getModificationTime() - Method in class org.apache.hadoop.fs.FileStatus
Get the modification time of the file.
getMountPoints() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getMountPoints() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getName() - Method in class org.apache.hadoop.fs.FileSystem
Deprecated.
call #getUri() instead.
getName() - Method in class org.apache.hadoop.fs.Path
Returns the final component of this path.
getName() - Method in interface org.apache.hadoop.mapreduce.Counter
 
getName() - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
Get the internal name of the group
getName() - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
Deprecated.
return the name of the record
getName() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the user-defined name of the application.
getNamed(String, Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
Deprecated.
call #get(URI,Configuration) instead.
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.
getNames() - Method in class org.apache.hadoop.fs.BlockLocation
Get the list of names (hostname:port) hosting this block
getNeededMem() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getNeededResources() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
Get the needed Resource
getNestedStructTypeInfo(String) - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
Deprecated.
Return the type info of a nested record.
getNewApplication(GetNewApplicationRequest) - Method in interface org.apache.hadoop.yarn.api.ClientRMProtocol
The interface used by clients to obtain a new ApplicationId for submitting new applications.
getNewApplication() - Method in interface org.apache.hadoop.yarn.client.YarnClient
Obtain a new ApplicationId for submitting new applications.
getNewApplication() - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
getNewApplication() - Method in interface org.hadoop.yarn.client.YarnClient
Obtain a new ApplicationId for submitting new applications.
getNewApplication() - Method in class org.hadoop.yarn.client.YarnClientImpl
 
GetNewApplicationRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The request sent by clients to get a new ApplicationId for submitting an application.
GetNewApplicationResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to the client for a request to get a new ApplicationId for submitting applications.
getNextExpirationTime() - Method in interface org.apache.hadoop.mapreduce.v2.api.protocolrecords.RenewDelegationTokenResponse
 
getNextExpirationTime() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RenewDelegationTokenResponse
 
getNextToken() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
getNextToken() - Method in class org.apache.hadoop.record.compiler.generated.RccTokenManager
Deprecated.
 
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
 
getNodeHealthStatus() - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
Get the NodeHealthStatus of the node.
getNodeHttpAddress() - Method in interface org.apache.hadoop.yarn.api.records.Container
Get the http uri of the node on which the container is allocated.
getNodeId() - Method in interface org.apache.hadoop.yarn.api.records.Container
Get the identifier of the node on which the container is allocated.
getNodeId() - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
Get the NodeId of the node.
getNodeReports() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesResponse
Get NodeReport for all nodes in the cluster.
getNodeReports() - Method in interface org.apache.hadoop.yarn.client.YarnClient
Get a report of all nodes (NodeReport) in the cluster.
getNodeReports() - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
getNodeReports() - Method in interface org.hadoop.yarn.client.YarnClient
Get a report of all nodes (NodeReport) in the cluster.
getNodeReports() - Method in class org.hadoop.yarn.client.YarnClientImpl
 
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
 
getNumber() - Method in class org.apache.hadoop.metrics.spi.MetricValue
 
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.
getNumClusterNodes() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
Get the number of hosts available on the cluster.
getNumContainers() - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
Get the number of running containers on the node.
getNumContainers() - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
Get the number of containers required with the given specifications.
getNumExcludedNodes() - Method in class org.apache.hadoop.mapred.ClusterStatus
Get the number of excluded hosts in the cluster.
getNumLinesPerSplit(JobContext) - Static method in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
Get the number of lines per split
getNumMapTasks() - Method in class org.apache.hadoop.mapred.JobConf
Get configured the number of reduce tasks for this job.
getNumNodeManagers() - Method in interface org.apache.hadoop.yarn.api.records.YarnClusterMetrics
Get the number of NodeManagers in the cluster.
getNumPaths() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns the number of Paths in the split
getNumReduceTasks() - Method in class org.apache.hadoop.mapred.JobConf
Get configured the number of reduce tasks for this job.
getNumReduceTasks() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get configured the number of reduce tasks for this job.
getNumReservedContainers() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
Get the number of reserved containers
getNumReservedSlots() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getNumTasksToExecutePerJvm() - Method in class org.apache.hadoop.mapred.JobConf
Get the number of tasks that a spawned JVM should execute
getNumUsedContainers() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
Get the number of used containers
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() - Method in class org.apache.hadoop.fs.BlockLocation
Get the start offset of file associated with this block
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.
getOriginalTrackingUrl() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the original not-proxied tracking url for the application.
getOtherAction() - Method in class org.apache.hadoop.fs.permission.FsPermission
Return other FsAction.
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(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(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputFormat
Get the output committer for this output format.
getOutputCommitter() - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Get the OutputCommitter for the task-attempt.
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
 
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.
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.
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.
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.
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.fs.FileStatus
Get the owner of the file.
getParent() - Method in class org.apache.hadoop.fs.Path
Returns the parent of a path or null if at root.
getPartialJobs(Long, Long, String, String, Long, Long, Long, Long, JobState) - Method in interface org.apache.hadoop.mapreduce.v2.hs.HistoryStorage
Look for a set of partial jobs.
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(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.
getPartitionFile(Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
Get the path to the SequenceFile storing the sorted partition keyset.
getPassword() - Method in interface org.apache.hadoop.yarn.api.records.ContainerToken
Get the token password
getPassword() - Method in interface org.apache.hadoop.yarn.api.records.DelegationToken
Get the token password
getPath() - Method in class org.apache.hadoop.fs.FileStatus
 
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
getPattern(String, Pattern) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a Pattern.
getPattern() - Method in interface org.apache.hadoop.yarn.api.records.LocalResource
Get the pattern that should be used to extract entries from the archive (only used when type is PATTERN).
getPeriod() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Returns the timer period.
getPermission() - Method in class org.apache.hadoop.fs.FileStatus
Get FsPermission associated with the file.
getPort() - Method in class org.apache.hadoop.yarn.api.records.NodeId
Get the port for communicating with the node.
getPort() - Method in interface org.apache.hadoop.yarn.api.records.URL
Get the port of the URL.
getPos() - Method in exception org.apache.hadoop.fs.ChecksumException
 
getPos() - Method in class org.apache.hadoop.fs.FSDataInputStream
Get the current position in the input stream.
getPos() - Method in class org.apache.hadoop.fs.FSDataOutputStream
Get the current position in the output stream.
getPos() - Method in interface org.apache.hadoop.fs.Seekable
Return the current offset from the start of the file
getPos() - Method in class org.apache.hadoop.io.compress.CompressionInputStream
This method returns the current position in the stream.
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 interface org.apache.hadoop.mapred.RecordReader
Returns the current position in the input.
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. 
getPriority() - Method in class org.apache.hadoop.mapreduce.Job
Get scheduling info of the job.
getPriority() - Method in class org.apache.hadoop.mapreduce.JobStatus
Return the priority of the job
getPriority() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the Priority of the application.
getPriority() - Method in interface org.apache.hadoop.yarn.api.records.Container
Get the Priority at which the Container was allocated.
getPriority() - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
Get the Priority of the request.
getProblems() - Method in exception org.apache.hadoop.mapred.InvalidInputException
Get the complete list of the problems reported.
getProblems() - Method in exception org.apache.hadoop.mapreduce.lib.input.InvalidInputException
Get the complete list of the problems reported.
getProfileEnabled() - Method in class org.apache.hadoop.mapred.JobConf
Get whether the task profiling is enabled.
getProfileEnabled() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get whether the task profiling is enabled.
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.
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.
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 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.SequenceFileAsTextRecordReader
 
getProgress() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
Return the progress within the input split
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
The current progress of the record reader through its data.
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
return progress based on the amount of data processed so far.
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextRecordReader
 
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
Return the progress within the input split
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Report progress as the minimum of all child RR progress.
getProgress() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Request progress from proxied RR.
getProgress() - Method in class org.apache.hadoop.mapreduce.RecordReader
The current progress of the record reader through its data.
getProgress() - Method in interface org.apache.hadoop.mapreduce.TaskAttemptContext
The current progress of the task attempt.
getProgress() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
Get the current progress of application.
getProgressible() - Method in interface org.apache.hadoop.mapred.JobContext
Get the progress mechanism for reporting progress.
getProgressible() - Method in interface org.apache.hadoop.mapred.TaskAttemptContext
 
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.
getPropertySources(String) - Method in class org.apache.hadoop.conf.Configuration
Gets information about why a property was set.
getProps() - Method in class org.apache.hadoop.conf.Configuration
 
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() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the queue to which the application was submitted.
getQueue() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the queue to which the application is being submitted.
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
getQueueAclsInfo() - Method in interface org.apache.hadoop.yarn.client.YarnClient
Get information about acls for current user on all the existing queues.
getQueueAclsInfo() - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
getQueueAclsInfo() - Method in interface org.hadoop.yarn.client.YarnClient
Get information about acls for current user on all the existing queues.
getQueueAclsInfo() - Method in class org.hadoop.yarn.client.YarnClientImpl
 
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
getQueueInfo(GetQueueInfoRequest) - Method in interface org.apache.hadoop.yarn.api.ClientRMProtocol
The interface used by clients to get information about queues from the ResourceManager.
getQueueInfo() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoResponse
Get the QueueInfo for the specified queue.
getQueueInfo(String) - Method in interface org.apache.hadoop.yarn.client.YarnClient
Get information (QueueInfo) about a given queue.
getQueueInfo(String) - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
getQueueInfo(String) - Method in interface org.hadoop.yarn.client.YarnClient
Get information (QueueInfo) about a given queue.
getQueueInfo(String) - Method in class org.hadoop.yarn.client.YarnClientImpl
 
GetQueueInfoRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The request sent by clients to get queue information from the ResourceManager.
GetQueueInfoResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting information about queues in the system.
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.mapreduce.QueueAclsInfo
Get queue name.
getQueueName() - Method in class org.apache.hadoop.mapreduce.QueueInfo
Get the queue name from JobQueueInfo
getQueueName() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
Get the queue name for which to get queue information.
getQueueName() - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
Get the name of the queue.
getQueueName() - Method in interface org.apache.hadoop.yarn.api.records.QueueUserACLInfo
Get the queue name of the queue.
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.
getQueueState() - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
Get the QueueState of the queue.
getQueueUserAcls(GetQueueUserAclsInfoRequest) - Method in interface org.apache.hadoop.yarn.api.ClientRMProtocol
The interface used by clients to get information about queue acls for current user from the ResourceManager.
GetQueueUserAclsInfoRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The request sent by clients to the ResourceManager to get queue acls for the current user.
GetQueueUserAclsInfoResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to clients seeking queue acls for the user.
getQuota() - Method in class org.apache.hadoop.fs.ContentSummary
Return the directory quota
getRackName() - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
Get the rack name for the node.
getRange(String, String) - Method in class org.apache.hadoop.conf.Configuration
Parse the given attribute as a set of integer ranges
getRaw(String) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property, without doing variable expansion.If the key is deprecated, it returns the value of the first key which replaces the deprecated key and is not null.
getRaw() - Method in class org.apache.hadoop.fs.LocalFileSystem
 
getRawFileSystem() - Method in class org.apache.hadoop.fs.ChecksumFileSystem
get the raw file system
getRawFileSystem() - Method in class org.apache.hadoop.fs.FilterFileSystem
Get the raw file system
getReader(Class<Object>) - Method in class org.apache.hadoop.io.serializer.avro.AvroReflectSerialization
 
getReader(Class<T>) - Method in class org.apache.hadoop.io.serializer.avro.AvroSerialization
Create and return Avro DatumReader for the given class.
getReader(Class<SpecificRecord>) - Method in class org.apache.hadoop.io.serializer.avro.AvroSpecificSerialization
 
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.
getReboot() - Method in interface org.apache.hadoop.yarn.api.records.AMResponse
Should the ApplicationMaster reboot for being horribly out-of-sync with the ResourceManager as deigned by AMResponse.getResponseId()?
getRecordName() - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
Returns the record name.
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.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.
getRecursive() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
Is information on the entire child queue hierarchy required?
getReduceDebugScript() - Method in class org.apache.hadoop.mapred.JobConf
Get the reduce task's debug Script
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.
getReducerContext(ReduceContext<KEYIN, VALUEIN, KEYOUT, VALUEOUT>) - Method in class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer
A a wrapped Reducer.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.
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.
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.
getRelease(int) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
getReleaseCount() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
getReleaseList() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
Get the list of ContainerId of containers being released by the ApplicationMaster.
getRemaining() - Method in class org.apache.hadoop.fs.FsStatus
Return the number of remaining bytes on the file system
getRemaining() - Method in interface org.apache.hadoop.io.compress.Decompressor
Returns the number of bytes remaining in the compressed data buffer.
getRenewer() - Method in interface org.apache.hadoop.mapreduce.v2.api.protocolrecords.GetDelegationTokenRequest
 
getRenewer() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenRequest
 
getReplication() - Method in class org.apache.hadoop.fs.FileStatus
Get the replication factor of a file.
getReplication(Path) - Method in class org.apache.hadoop.fs.FileSystem
Deprecated.
Use getFileStatus() instead
getReplication() - Method in class org.apache.hadoop.fs.FsServerDefaults
 
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
 
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.
getReservedResources() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
Get the reserved Resource
getResource(String) - Method in class org.apache.hadoop.conf.Configuration
Get the URL for the named resource.
getResource() - Method in interface org.apache.hadoop.yarn.api.records.Container
Get the Resource allocated to the container.
getResource() - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get the Resource allocated to the container by the ResourceManager.
getResource() - Method in interface org.apache.hadoop.yarn.api.records.LocalResource
Get the location of the resource to be localized.
getResource(String) - Method in class org.apache.hadoop.yarn.util.ApplicationClassLoader
 
getResponseId() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
Get the response id used to track duplicate responses.
getResponseId() - Method in interface org.apache.hadoop.yarn.api.records.AMResponse
Get the last response id.
getRMDelegationToken() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenResponse
 
getRMDelegationToken(Text) - Method in interface org.apache.hadoop.yarn.client.YarnClient
Get a delegation token so as to be able to talk to YARN using those tokens.
getRMDelegationToken(Text) - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
getRMDelegationToken(Text) - Method in interface org.hadoop.yarn.client.YarnClient
Get a delegation token so as to be able to talk to YARN using those tokens.
getRMDelegationToken(Text) - Method in class org.hadoop.yarn.client.YarnClientImpl
 
getRootQueueInfos() - Method in interface org.apache.hadoop.yarn.client.YarnClient
Get information (QueueInfo) about top level queues.
getRootQueueInfos() - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
getRootQueueInfos() - Method in interface org.hadoop.yarn.client.YarnClient
Get information (QueueInfo) about top level queues.
getRootQueueInfos() - Method in class org.hadoop.yarn.client.YarnClientImpl
 
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.
getRpcPort() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
Get the RPC port on which the ApplicationMaster is responding.
getRpcPort() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the RPC port of the ApplicationMaster.
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.
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
 
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(Object) - Method in class org.apache.hadoop.io.serializer.avro.AvroReflectSerialization
 
getSchema(T) - Method in class org.apache.hadoop.io.serializer.avro.AvroSerialization
Return an Avro Schema instance for the given class.
getSchema(SpecificRecord) - Method in class org.apache.hadoop.io.serializer.avro.AvroSpecificSerialization
 
getScheme() - Method in interface org.apache.hadoop.yarn.api.records.URL
Get the scheme of the URL.
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
 
getSerializer(Class<T>) - Method in class org.apache.hadoop.io.serializer.avro.AvroSerialization
 
getSerializer(Class<Serializable>) - Method in class org.apache.hadoop.io.serializer.JavaSerialization
 
getSerializer(Class<Writable>) - Method in class org.apache.hadoop.io.serializer.WritableSerialization
 
getServerDefaults() - Method in class org.apache.hadoop.fs.AbstractFileSystem
Return a set of server default configuration values.
getServerDefaults() - Method in class org.apache.hadoop.fs.FileSystem
Return a set of server default configuration values
getServerDefaults(Path) - Method in class org.apache.hadoop.fs.FileSystem
Return a set of server default configuration values
getServerDefaults() - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getServerDefaults(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getServerDefaults() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getServerDefaults(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getServerDefaults() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getService() - Method in interface org.apache.hadoop.yarn.api.records.ContainerToken
Get the service to which the token is allocated.
getService() - Method in interface org.apache.hadoop.yarn.api.records.DelegationToken
Get the service to which the token is allocated.
getServiceData() - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get application-specific binary service data.
getServiceResponse(String) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.StartContainerResponse
Get the response from a single auxiliary service running on the NodeManager
getSessionId() - Method in class org.apache.hadoop.mapred.JobConf
Deprecated.
getSetupProgress() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getSetupTaskReports(JobID) - Method in class org.apache.hadoop.mapred.JobClient
Get the information of the current state of the setup tasks of a job.
getShuffleSecretKey(Credentials) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
 
getSize() - Method in class org.apache.hadoop.io.BytesWritable
Deprecated.
getSize() - Method in interface org.apache.hadoop.yarn.api.records.LocalResource
Get the size of the resource to be localized.
getSkipOutputPath(Configuration) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
Get the directory to which skipped records are written.
getSlope(String) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
getSocketAddr(String, String, int) - Method in class org.apache.hadoop.conf.Configuration
Get the socket address for name property as a InetSocketAddress.
getSortComparator() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the RawComparator comparator used to compare keys.
getSource(String) - Method in class org.apache.hadoop.metrics2.MetricsSystem
 
getSpaceConsumed() - Method in class org.apache.hadoop.fs.ContentSummary
Retuns (disk) space consumed
getSpaceQuota() - Method in class org.apache.hadoop.fs.ContentSummary
Returns (disk) space quota
getSpeculativeExecution() - Method in class org.apache.hadoop.mapred.JobConf
Should speculative execution be used for this job? Defaults to true.
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.
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.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.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.
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.input.FileSplit
The position of the first byte in the file to process.
getStartOffsets() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns an array containing the start offsets of the files in the split
getStartTime() - Method in class org.apache.hadoop.mapreduce.Job
Get start time of the job.
getStartTime() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getStartTime() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the start time of the application.
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.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 interface org.apache.hadoop.yarn.api.records.Container
Get the current ContainerState of the container.
getState() - Method in interface org.apache.hadoop.yarn.api.records.ContainerStatus
Get the ContainerState of the container.
getStatement() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getStateName() - Method in enum org.apache.hadoop.mapreduce.QueueState
 
getStatistics() - Method in class org.apache.hadoop.fs.AbstractFileSystem
 
getStatistics(URI) - Static method in class org.apache.hadoop.fs.AbstractFileSystem
Get the statistics for a particular file system.
getStatistics(URI) - Static method in class org.apache.hadoop.fs.FileContext
Get the statistics for a particular file system
getStatistics() - Static method in class org.apache.hadoop.fs.FileSystem
Deprecated.
getStatistics(String, Class<? extends FileSystem>) - Static method in class org.apache.hadoop.fs.FileSystem
Get the statistics for a particular file system
getStatus() - Method in class org.apache.hadoop.fs.FileSystem
Returns a status object describing the use and capacity of the file system.
getStatus(Path) - Method in class org.apache.hadoop.fs.FileSystem
Returns a status object describing the use and capacity of the file system.
getStatus(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
Returns a status object describing the use and capacity of the file system.
getStatus(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
Returns a status object describing the use and capacity of the file system.
getStatus() - Method in class org.apache.hadoop.mapreduce.Job
 
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.
getStatus() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusResponse
Get the ContainerStatus of the container.
getStickyBit() - Method in class org.apache.hadoop.fs.permission.FsPermission
 
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
 
getStringCollection(String) - Method in class org.apache.hadoop.conf.Configuration
Get the comma delimited values of the name property as a collection of Strings.
getStrings(String) - Method in class org.apache.hadoop.conf.Configuration
Get the comma delimited values of the name property as an array of Strings.
getStrings(String, String...) - Method in class org.apache.hadoop.conf.Configuration
Get the comma delimited values of the name property as an array of Strings.
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
GetSuffix(int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
getSum() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.DoubleValueSum
 
getSum() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueSum
 
getSupportedCompressionAlgorithms() - Static method in class org.apache.hadoop.io.file.tfile.TFile
Get names of supported compression algorithms.
getSwitchMap() - Method in class org.apache.hadoop.net.AbstractDNSToSwitchMapping
Get a copy of the map (for diagnostics)
getSwitchMap() - Method in class org.apache.hadoop.net.CachedDNSToSwitchMapping
Get the (host x switch) map.
getSymlink() - Method in class org.apache.hadoop.fs.FileStatus
 
getSymlink() - Method in interface org.apache.hadoop.mapreduce.JobContext
Deprecated.
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.
getTableName() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
getTabSize(int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
getTag(String) - Method in class org.apache.hadoop.metrics.spi.OutputRecord
Returns a tag object which is can be a String, Integer, Short or Byte.
getTag(String) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Get a tag by name
getTagNames() - Method in class org.apache.hadoop.metrics.spi.OutputRecord
Returns the set of tag names
getTagsCopy() - Method in class org.apache.hadoop.metrics.spi.OutputRecord
Returns a copy of this record's tags.
getTaskAttemptID() - Method in interface org.apache.hadoop.mapred.TaskAttemptContext
 
getTaskAttemptId() - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Returns task id.
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.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
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.
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.
getTaskID() - Method in class org.apache.hadoop.mapred.TaskAttemptID
 
getTaskId() - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
Deprecated.
getTaskID() - Method in class org.apache.hadoop.mapred.TaskReport
The id of the task.
getTaskID() - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
Returns the TaskID object that this task attempt belongs to
getTaskIDsPattern(String, Integer, Boolean, Integer) - Static method in class org.apache.hadoop.mapred.TaskID
getTaskIDsPattern(String, Integer, TaskType, Integer) - Static method in class org.apache.hadoop.mapred.TaskID
Deprecated.
getTaskLogURL(TaskAttemptID, String) - Static method in class org.apache.hadoop.mapreduce.tools.CLI
 
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.
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.
getTaskTrackerCount() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of active trackers in the cluster.
getTaskTrackerExpiryInterval() - Method in class org.apache.hadoop.mapreduce.Cluster
Get the tasktracker expiry interval for the cluster
getTaskTrackerHttp() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
http location of the tasktracker where this task ran.
getTaskTrackerName() - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
Gets the tasktracker's name.
getTaskTrackers() - Method in class org.apache.hadoop.mapred.ClusterStatus
Get the number of task trackers in the cluster.
getTaskType() - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
Returns the TaskType of the TaskAttemptID
getTaskType() - Method in class org.apache.hadoop.mapreduce.TaskID
Get the type of the task
getTaskType(char) - Static method in class org.apache.hadoop.mapreduce.TaskID
Gets the TaskType corresponding to the character
getThreadState() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getTimestamp() - Method in interface org.apache.hadoop.yarn.api.records.LocalResource
Get the original timestamp of the resource to be localized, used for verification.
getTmax(String) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
getToken(int) - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
getTopologyPaths() - Method in class org.apache.hadoop.fs.BlockLocation
Get the list of network topology paths for each of the hosts.
getTotalJobSubmissions() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the total number of job submissions in the cluster.
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.
getTrackingUrl() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
Get the tracking URL for the ApplicationMaster.
getTrackingUrl() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the tracking url for the application.
getTrashCanLocation(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getTrimmed(String) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a trimmed String, null if no such property exists.
getTrimmedStringCollection(String) - Method in class org.apache.hadoop.conf.Configuration
Get the comma delimited values of the name property as a collection of Strings, trimmed of the leading and trailing whitespace.
getTrimmedStrings(String) - Method in class org.apache.hadoop.conf.Configuration
Get the comma delimited values of the name property as an array of Strings, trimmed of the leading and trailing whitespace.
getTrimmedStrings(String, String...) - Method in class org.apache.hadoop.conf.Configuration
Get the comma delimited values of the name property as an array of Strings, trimmed of the leading and trailing whitespace.
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
 
getType() - Method in interface org.apache.hadoop.yarn.api.records.LocalResource
Get the LocalResourceType of the resource to be localized.
getTypeID() - Method in class org.apache.hadoop.record.meta.FieldTypeInfo
Deprecated.
get the field's TypeID object
getTypes() - Method in class org.apache.hadoop.io.GenericWritable
Return all classes that may be wrapped.
getTypeVal() - Method in class org.apache.hadoop.record.meta.TypeID
Deprecated.
Get the type value.
getUgi() - Method in class org.apache.hadoop.fs.FileContext
Gets the ugi in the file-context
getUMask() - Method in class org.apache.hadoop.fs.FileContext
 
getUMask(Configuration) - Static method in class org.apache.hadoop.fs.permission.FsPermission
Get the user file creation mask (umask) UMASK_LABEL config param has umask value that is either symbolic or octal.
getUnderlyingCounter() - Method in interface org.apache.hadoop.mapreduce.Counter
 
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.
getUnits(String) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
getUri() - Method in class org.apache.hadoop.fs.AbstractFileSystem
Returns a URI whose scheme and authority identify this FileSystem.
getUri() - Method in class org.apache.hadoop.fs.FileSystem
Returns a URI whose scheme and authority identify this FileSystem.
getUri() - Method in class org.apache.hadoop.fs.FilterFileSystem
Returns a URI whose scheme and authority identify this FileSystem.
getUri() - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
getUri() - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
getUri() - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
getUri() - Method in class org.apache.hadoop.fs.s3.S3FileSystem
 
getUri() - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
getUri() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getUriDefaultPort() - Method in class org.apache.hadoop.fs.AbstractFileSystem
The default port of this file system.
getUriDefaultPort() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getUriPath(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Get the path-part of a pathname.
getUsed() - Method in class org.apache.hadoop.fs.FileSystem
Return the total size of all files in the filesystem.
getUsed() - Method in class org.apache.hadoop.fs.FilterFileSystem
Return the total size of all files in the filesystem.
getUsed() - Method in class org.apache.hadoop.fs.FsStatus
Return the number of bytes used on the file system
getUsed() - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
Get used Resource on the node.
getUsedMem() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getUsedMemory() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated.
getUsedResources() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
Get the used Resource
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 interface org.apache.hadoop.mapreduce.JobContext
Get the reported username for this job.
getUser() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the user who submitted the application.
getUser() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the user submitting the application.
getUser() - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get the user to whom the container has been allocated.
getUserAcls() - Method in interface org.apache.hadoop.yarn.api.records.QueueUserACLInfo
Get the list of QueueACL for the given user.
getUserAclsInfoList() - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetQueueUserAclsInfoResponse
Get the QueueUserACLInfo per queue for the user.
getUserAction() - Method in class org.apache.hadoop.fs.permission.FsPermission
Return user FsAction.
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
 
getValByRegex(String) - Method in class org.apache.hadoop.conf.Configuration
get keys matching the the regex
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.lib.fieldsel.FieldSelectionHelper
 
getValue() - Method in class org.apache.hadoop.util.PureJavaCrc32
getValue() - Method in class org.apache.hadoop.util.PureJavaCrc32C
getValueAggregatorDescriptor(String, Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
getValueClass() - Method in class org.apache.hadoop.io.ArrayWritable
 
getValueClass() - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
The class of value that must be passed to SequenceFileRecordReader.next(Object, Object)..
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.
getValueTypeID() - Method in class org.apache.hadoop.record.meta.MapTypeID
Deprecated.
get the TypeID of the map's value element
getVectorSize() - Method in class org.apache.hadoop.util.bloom.BloomFilter
 
getVersion() - Method in class org.apache.hadoop.io.VersionedWritable
Return the version number of the current implementation.
getVIntSize(long) - Static method in class org.apache.hadoop.io.WritableUtils
Get the encoded length if an integer is stored in a variable-length format
getVIntSize(long) - Static method in class org.apache.hadoop.record.Utils
Deprecated.
Get the encoded length if an integer is stored in a variable-length format
getVisibility() - Method in interface org.apache.hadoop.yarn.api.records.LocalResource
Get the LocalResourceVisibility of the resource to be localized.
getWaitingJobList() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getWaitingJobs() - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
 
getWarn() - Static method in class org.apache.hadoop.log.metrics.EventCounter
 
getWorkingDirectory() - Method in class org.apache.hadoop.fs.FileContext
Gets the working directory for wd-relative names (such a "foo/bar").
getWorkingDirectory() - Method in class org.apache.hadoop.fs.FileSystem
Get the current working directory for the given file system
getWorkingDirectory() - Method in class org.apache.hadoop.fs.FilterFileSystem
Get the current working directory for the given file system
getWorkingDirectory() - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
getWorkingDirectory() - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
getWorkingDirectory() - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
getWorkingDirectory() - Method in class org.apache.hadoop.fs.s3.S3FileSystem
 
getWorkingDirectory() - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
getWorkingDirectory() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
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.
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.
getWrappedStream() - Method in class org.apache.hadoop.fs.FSDataInputStream
Get a reference to the wrapped input stream.
getWrappedStream() - Method in class org.apache.hadoop.fs.FSDataOutputStream
Get a reference to the wrapped output stream.
getWriteAllCounters() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Get the "writeAllCounters" option
getWritePacketSize() - Method in class org.apache.hadoop.fs.FsServerDefaults
 
getWriter(Class<Object>) - Method in class org.apache.hadoop.io.serializer.avro.AvroReflectSerialization
 
getWriter(Class<T>) - Method in class org.apache.hadoop.io.serializer.avro.AvroSerialization
Create and return Avro DatumWriter for the given class.
getWriter(Class<SpecificRecord>) - Method in class org.apache.hadoop.io.serializer.avro.AvroSpecificSerialization
 
getYarnApplicationState() - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
Get the YarnApplicationState of the application.
getYarnClusterMetrics() - Method in interface org.apache.hadoop.yarn.client.YarnClient
Get metrics (YarnClusterMetrics) about the cluster.
getYarnClusterMetrics() - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
getYarnClusterMetrics() - Method in interface org.hadoop.yarn.client.YarnClient
Get metrics (YarnClusterMetrics) about the cluster.
getYarnClusterMetrics() - Method in class org.hadoop.yarn.client.YarnClientImpl
 
GlobFilter - Class in org.apache.hadoop.fs
A filter for POSIX glob pattern with brace expansions.
GlobFilter(String) - Constructor for class org.apache.hadoop.fs.GlobFilter
Creates a glob filter with the specified file pattern.
GlobFilter(String, PathFilter) - Constructor for class org.apache.hadoop.fs.GlobFilter
Creates a glob filter with the specified file pattern and an user filter.
GlobFilter - Class in org.apache.hadoop.metrics2.filter
A glob pattern filter for metrics.
GlobFilter() - Constructor for class org.apache.hadoop.metrics2.filter.GlobFilter
 
globStatus(Path) - Method in class org.apache.hadoop.fs.FileSystem
Return all the files that match filePattern and are not checksum files.
globStatus(Path, PathFilter) - Method in class org.apache.hadoop.fs.FileSystem
Return an array of FileStatus objects whose path names match pathPattern and is accepted by the user-supplied path filter.
GROUP - Static variable in class org.apache.hadoop.mapreduce.lib.map.RegexMapper
 
GroupMappingServiceProvider - Interface in org.apache.hadoop.security
An interface for the implementation of a user-to-groups mapping service used by Groups.
GT_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
GzipCodec - Class in org.apache.hadoop.io.compress
This class creates gzip compressors/decompressors.
GzipCodec() - Constructor for class org.apache.hadoop.io.compress.GzipCodec
 

H

HADOOP_RPC_SOCKET_FACTORY_CLASS_DEFAULT_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_AUTHENTICATION - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_AUTHORIZATION - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_GROUP_MAPPING - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_GROUPS_CACHE_SECS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_SERVICE_USER_NAME_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SOCKS_SERVER_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_UTIL_HASH_TYPE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for HADOOP_UTIL_HASH_TYPE_KEY
HADOOP_UTIL_HASH_TYPE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HadoopIllegalArgumentException - Exception in org.apache.hadoop
Indicates that a method has been passed illegal or invalid argument.
HadoopIllegalArgumentException(String) - Constructor for exception org.apache.hadoop.HadoopIllegalArgumentException
Constructs exception with the specified detail message.
halfDigest() - Method in class org.apache.hadoop.io.MD5Hash
Construct a half-sized version of this MD5.
has(int) - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Return true if tuple has an element at the position provided.
hash(Key) - Method in class org.apache.hadoop.util.bloom.HashFunction
Hashes a specified key into several integers.
HASH_COUNT - Static variable in class org.apache.hadoop.io.BloomMapFile
 
hashBytes(byte[], int, int) - Static method in class org.apache.hadoop.io.WritableComparator
Compute hash for binary data.
hashBytes(byte[], int) - Static method in class org.apache.hadoop.io.WritableComparator
Compute hash for binary data.
hashCode() - Method in class org.apache.hadoop.fs.AbstractFileSystem
 
hashCode() - Method in class org.apache.hadoop.fs.FileChecksum
hashCode() - Method in class org.apache.hadoop.fs.FileStatus
Returns a hash code value for the object, which is defined as the hash code of the path name.
hashCode() - Method in class org.apache.hadoop.fs.LocatedFileStatus
Returns a hash code value for the object, which is defined as the hash code of the path name.
hashCode() - Method in class org.apache.hadoop.fs.Path
 
hashCode() - Method in class org.apache.hadoop.fs.permission.FsPermission
hashCode() - Method in class org.apache.hadoop.io.BinaryComparable
Return a hash of the bytes returned from {#getBytes()}.
hashCode() - Method in class org.apache.hadoop.io.BooleanWritable
 
hashCode() - Method in class org.apache.hadoop.io.BytesWritable
 
hashCode() - Method in class org.apache.hadoop.io.ByteWritable
 
hashCode() - Method in class org.apache.hadoop.io.DoubleWritable
 
hashCode() - Method in class org.apache.hadoop.io.EnumSetWritable
hashCode() - Method in class org.apache.hadoop.io.FloatWritable
 
hashCode() - Method in class org.apache.hadoop.io.IntWritable
 
hashCode() - Method in class org.apache.hadoop.io.LongWritable
 
hashCode() - Method in class org.apache.hadoop.io.MapWritable
hashCode() - Method in class org.apache.hadoop.io.MD5Hash
Returns a hash code value for this object.
hashCode() - Method in class org.apache.hadoop.io.NullWritable
 
hashCode() - Method in class org.apache.hadoop.io.ShortWritable
hash code
hashCode() - Method in class org.apache.hadoop.io.SortedMapWritable
 
hashCode() - Method in class org.apache.hadoop.io.Text
 
hashCode() - Method in class org.apache.hadoop.io.VIntWritable
 
hashCode() - Method in class org.apache.hadoop.io.VLongWritable
 
hashCode() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
 
hashCode() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
 
hashCode() - Method in class org.apache.hadoop.mapreduce.ID
 
hashCode() - Method in class org.apache.hadoop.mapreduce.JobID
 
hashCode() - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
 
hashCode() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
 
hashCode(byte[], int, int, int) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
 
hashCode() - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
 
hashCode() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
hashCode() - Method in class org.apache.hadoop.mapreduce.TaskID
 
hashCode() - Method in class org.apache.hadoop.metrics2.AbstractMetric
 
hashCode() - Method in class org.apache.hadoop.metrics2.MetricsTag
 
hashCode() - Method in class org.apache.hadoop.net.SocksSocketFactory
 
hashCode() - Method in class org.apache.hadoop.net.StandardSocketFactory
 
hashCode() - Method in class org.apache.hadoop.record.Buffer
Deprecated.
 
hashCode() - Method in class org.apache.hadoop.record.meta.FieldTypeInfo
Deprecated.
We use a basic hashcode implementation, since this class will likely not be used as a hashmap key
hashCode() - Method in class org.apache.hadoop.record.meta.MapTypeID
Deprecated.
We use a basic hashcode implementation, since this class will likely not be used as a hashmap key
hashCode() - Method in class org.apache.hadoop.record.meta.StructTypeID
Deprecated.
 
hashCode() - Method in class org.apache.hadoop.record.meta.TypeID
Deprecated.
We use a basic hashcode implementation, since this class will likely not be used as a hashmap key
hashCode() - Method in class org.apache.hadoop.record.meta.VectorTypeID
Deprecated.
We use a basic hashcode implementation, since this class will likely not be used as a hashmap key
hashCode() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.ApplicationId
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.ContainerId
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.NodeId
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.Resource
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
 
HashFunction - Class in org.apache.hadoop.util.bloom
Implements a hash object that returns a certain number of hashed values.
HashFunction(int, int, int) - Constructor for class org.apache.hadoop.util.bloom.HashFunction
Constructor.
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 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.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 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
 
headerPattern - Static variable in class org.apache.hadoop.mapreduce.tools.CLI
 
headMap(WritableComparable) - Method in class org.apache.hadoop.io.SortedMapWritable
hexchars - Static variable in class org.apache.hadoop.record.Utils
Deprecated.
 
hflush() - Method in class org.apache.hadoop.fs.FSDataOutputStream
 
hflush() - Method in interface org.apache.hadoop.fs.Syncable
Flush out the data in client's user buffer.
HistoryFileManager - Class in org.apache.hadoop.mapreduce.v2.hs
This class provides a way to interact with history files in a thread safe manor.
HistoryFileManager() - Constructor for class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
 
HistoryStorage - Interface in org.apache.hadoop.mapreduce.v2.hs
Provides an API to query jobs that have finished.
hsync() - Method in class org.apache.hadoop.fs.FSDataOutputStream
 
hsync() - Method in interface org.apache.hadoop.fs.Syncable
Similar to posix fsync, flush out the data in client's user buffer all the way to the disk device (but the disk may have it in its cache).

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.
ident - Variable in class org.apache.hadoop.mapred.join.Parser.Node
 
ident - Variable in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
IDENT_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
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
 
image - Variable in class org.apache.hadoop.record.compiler.generated.Token
Deprecated.
The string image of the token.
in - Variable in class org.apache.hadoop.io.compress.CompressionInputStream
The input stream to be compressed.
inBuf - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
Include() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
INCLUDE_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
incr() - Method in class org.apache.hadoop.metrics2.lib.MutableCounter
Increment the metric value by 1.
incr() - Method in class org.apache.hadoop.metrics2.lib.MutableCounterInt
 
incr(int) - Method in class org.apache.hadoop.metrics2.lib.MutableCounterInt
Increment the value by a delta
incr() - Method in class org.apache.hadoop.metrics2.lib.MutableCounterLong
 
incr(long) - Method in class org.apache.hadoop.metrics2.lib.MutableCounterLong
Increment the value by a delta
incr() - Method in class org.apache.hadoop.metrics2.lib.MutableGauge
Increment the value of the metric by 1
incr() - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeInt
 
incr(int) - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeInt
Increment by delta
incr() - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeLong
 
incr(long) - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeLong
Increment by delta
incr() - Method in interface org.apache.hadoop.record.Index
Deprecated.
 
incrAllCounters(Counters) - Method in class org.apache.hadoop.mapred.Counters
Increments multiple counters by their amounts in another Counters instance.
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
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.
increment(long) - Method in interface org.apache.hadoop.mapreduce.Counter
Increment this counter by the given value
INCREMENT - Static variable in class org.apache.hadoop.metrics.spi.MetricValue
 
incrMetric(String, int) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
Increments the named metric by the specified value.
incrMetric(String, long) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
Increments the named metric by the specified value.
incrMetric(String, short) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
Increments the named metric by the specified value.
incrMetric(String, byte) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
Increments the named metric by the specified value.
incrMetric(String, float) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
Increments the named metric by the specified value.
Index - Interface in org.apache.hadoop.record
Deprecated.
Replaced by Avro.
INDEX_FILE_NAME - Static variable in class org.apache.hadoop.io.MapFile
The name of the index file.
info() - Method in class org.apache.hadoop.metrics2.AbstractMetric
 
info(String, String) - Static method in class org.apache.hadoop.metrics2.lib.Interns
Get a metric info object
info() - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
 
info() - Method in class org.apache.hadoop.metrics2.lib.MutableCounter
 
info() - Method in class org.apache.hadoop.metrics2.lib.MutableGauge
 
info() - Method in class org.apache.hadoop.metrics2.MetricsTag
 
init(JobConf) - Method in class org.apache.hadoop.mapred.JobClient
Connect to the default cluster
init(Configuration) - Method in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
 
init(String, ContextFactory) - Method in class org.apache.hadoop.metrics.file.FileContext
Deprecated.
 
init(String, ContextFactory) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
init(String, ContextFactory) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Initializes the context.
init(String, ContextFactory) - Method in class org.apache.hadoop.metrics.spi.CompositeContext
 
init(String, ContextFactory) - Method in class org.apache.hadoop.metrics.spi.NoEmitMetricsContext
 
init(String, ContextFactory) - Method in class org.apache.hadoop.metrics.spi.NullContextWithUpdateThread
 
init(Class<?>) - Method in class org.apache.hadoop.metrics2.lib.MutableRates
Initialize the registry with all the methods in a protocol so they all show up in the first snapshot.
init(SubsetConfiguration) - Method in interface org.apache.hadoop.metrics2.MetricsPlugin
Initialize the plugin
init(String) - Method in class org.apache.hadoop.metrics2.MetricsSystem
 
init(SubsetConfiguration) - Method in class org.apache.hadoop.metrics2.sink.FileSink
 
init(String[]) - Method in class org.apache.hadoop.yarn.applications.distributedshell.ApplicationMaster
Parse command line options
init(String[]) - Method in class org.apache.hadoop.yarn.applications.distributedshell.Client
Parse command line options
init(Configuration) - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
init(Configuration) - Method in class org.hadoop.yarn.client.YarnClientImpl
 
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.FileSystem
Called after a new FileSystem instance is constructed.
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.FilterFileSystem
Called after a new FileSystem instance is constructed.
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.LocalFileSystem
 
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
initialize(URI) - Method in class org.apache.hadoop.fs.s3.MigrationTool
 
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.s3.S3FileSystem
 
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
initialize(Configuration, FileSystem, Path) - Method in class org.apache.hadoop.fs.TrashPolicy
Used to setup the trash policy.
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
Called after a new FileSystem instance is constructed.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.RecordReader
Called once at initialization.
initialize(String) - Static method in enum org.apache.hadoop.metrics2.lib.DefaultMetricsSystem
Convenience method to initialize the metrics system
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.
inMiniClusterMode() - Static method in enum org.apache.hadoop.metrics2.lib.DefaultMetricsSystem
 
InnerJoinRecordReader<K extends WritableComparable> - Class in org.apache.hadoop.mapred.join
Full inner join.
InnerJoinRecordReader<K extends WritableComparable<?>> - Class in org.apache.hadoop.mapreduce.lib.join
Full inner join.
Input() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
INPUT_BOUNDING_QUERY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Input query to get the max and min values of the jdbc.input.query
INPUT_CLASS_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Class name implementing DBWritable which will hold input tuples
INPUT_CLASS_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Class name implementing DBWritable which will hold input tuples
INPUT_CONDITIONS_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
WHERE clause in the input SELECT statement
INPUT_CONDITIONS_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
WHERE clause in the input SELECT statement
INPUT_COUNT_QUERY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Input query to get the count of records
INPUT_COUNT_QUERY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Input query to get the count of records
INPUT_DIR - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
INPUT_DIR_RECURSIVE - Static variable in class org.apache.hadoop.mapred.FileInputFormat
 
INPUT_DIR_RECURSIVE - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
INPUT_FIELD_NAMES_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Field names in the Input table
INPUT_FIELD_NAMES_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Field names in the Input table
INPUT_FORMAT - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
INPUT_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_stream - Variable in class org.apache.hadoop.record.compiler.generated.RccTokenManager
Deprecated.
 
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
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
 
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
 
inputStream - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
instance() - Static method in enum org.apache.hadoop.metrics2.lib.DefaultMetricsSystem
 
INT_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
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
 
InterfaceAudience - Class in org.apache.hadoop.classification
Annotation to inform users of a package, class or method's intended audience.
InterfaceStability - Class in org.apache.hadoop.classification
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
InterfaceStability() - Constructor for class org.apache.hadoop.classification.InterfaceStability
 
Interns - Class in org.apache.hadoop.metrics2.lib
Helpers to create interned metrics info
Interns() - Constructor for class org.apache.hadoop.metrics2.lib.Interns
 
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
 
IntTypeID - Static variable in class org.apache.hadoop.record.meta.TypeID
Deprecated.
 
IntWritable - Class in org.apache.hadoop.io
A WritableComparable for ints.
IntWritable() - Constructor for class org.apache.hadoop.io.IntWritable
 
IntWritable(int) - Constructor for class org.apache.hadoop.io.IntWritable
 
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
 
InvalidPathException - Exception in org.apache.hadoop.fs
Path string is invalid either because it has invalid characters or due to other file system specific reasons.
InvalidPathException(String) - Constructor for exception org.apache.hadoop.fs.InvalidPathException
Constructs exception with the specified detail message.
InvalidPathException(String, String) - Constructor for exception org.apache.hadoop.fs.InvalidPathException
Constructs exception with the specified detail message.
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_COMPRESSION_CODEC_LZO_CLASS_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Codec class that implements Lzo compression algorithm
IO_FILE_BUFFER_SIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IO_FILE_BUFFER_SIZE_KEY
IO_FILE_BUFFER_SIZE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IO_MAP_INDEX_INTERVAL_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IO_MAP_INDEX_INTERVAL_DEFAULT
IO_MAP_INDEX_INTERVAL_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IO_MAP_INDEX_SKIP_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IO_MAP_INDEX_SKIP_KEY
IO_MAP_INDEX_SKIP_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IO_MAPFILE_BLOOM_ERROR_RATE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IO_MAPFILE_BLOOM_ERROR_RATE_KEY
IO_MAPFILE_BLOOM_ERROR_RATE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IO_MAPFILE_BLOOM_SIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IO_MAPFILE_BLOOM_SIZE_KEY
IO_MAPFILE_BLOOM_SIZE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IO_NATIVE_LIB_AVAILABLE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IO_NATIVE_LIB_AVAILABLE_KEY
IO_NATIVE_LIB_AVAILABLE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IO_SEQFILE_COMPRESS_BLOCKSIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IO_SEQFILE_COMPRESS_BLOCKSIZE_KEY
IO_SEQFILE_COMPRESS_BLOCKSIZE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IO_SERIALIZATIONS_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IO_SKIP_CHECKSUM_ERRORS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IO_SKIP_CHECKSUM_ERRORS_KEY
IO_SKIP_CHECKSUM_ERRORS_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IO_SORT_FACTOR_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IO_SORT_FACTOR_DEFAULT
IO_SORT_FACTOR_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Deprecated.
Moved to mapreduce, see mapreduce.task.io.sort.factor in mapred-default.xml See https://issues.apache.org/jira/browse/HADOOP-6801
IO_SORT_MB_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IO_SORT_MB_DEFAULT
IO_SORT_MB_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Deprecated.
Moved to mapreduce, see mapreduce.task.io.sort.mb in mapred-default.xml See https://issues.apache.org/jira/browse/HADOOP-6801
IOUtils - Class in org.apache.hadoop.io
An utility class for I/O related functionality.
IOUtils() - Constructor for class org.apache.hadoop.io.IOUtils
 
IPC_CLIENT_CONNECT_MAX_RETRIES_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IPC_CLIENT_CONNECT_MAX_RETRIES_KEY
IPC_CLIENT_CONNECT_MAX_RETRIES_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IPC_CLIENT_CONNECTION_MAXIDLETIME_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IPC_CLIENT_CONNECTION_MAXIDLETIME_KEY
IPC_CLIENT_CONNECTION_MAXIDLETIME_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IPC_CLIENT_IDLETHRESHOLD_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IPC_CLIENT_IDLETHRESHOLD_DEFAULT
IPC_CLIENT_IDLETHRESHOLD_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IPC_CLIENT_KILL_MAX_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IPC_CLIENT_KILL_MAX_KEY
IPC_CLIENT_KILL_MAX_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IPC_CLIENT_TCPNODELAY_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Defalt value for IPC_CLIENT_TCPNODELAY_KEY
IPC_CLIENT_TCPNODELAY_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IPC_SERVER_LISTEN_QUEUE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IPC_SERVER_LISTEN_QUEUE_SIZE_KEY
IPC_SERVER_LISTEN_QUEUE_SIZE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IPC_SERVER_TCPNODELAY_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IPC_SERVER_TCPNODELAY_KEY
IPC_SERVER_TCPNODELAY_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
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
 
isAbsolute() - Method in class org.apache.hadoop.fs.Path
There is some ambiguity here.
isAbsolute() - Method in class org.apache.hadoop.metrics.spi.MetricValue
 
isAbsoluteAndSchemeAuthorityNull() - Method in class org.apache.hadoop.fs.Path
Is an absolute path (ie a slash relative path part) AND a scheme is null AND authority is null.
isBlacklisted() - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
Whether tracker is blacklisted
isChecksumFile(Path) - Static method in class org.apache.hadoop.fs.ChecksumFileSystem
Return true iff file is a checksum file name.
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
 
isCorrupt() - Method in class org.apache.hadoop.fs.BlockLocation
Get the corrupt flag.
isDeclaredComponentType(Class<?>) - Method in class org.apache.hadoop.io.ArrayPrimitiveWritable
 
isDeprecated(String) - Static method in class org.apache.hadoop.conf.Configuration
checks whether the given key is deprecated.
isDir() - Method in class org.apache.hadoop.fs.FileStatus
isDirectory() - Method in class org.apache.hadoop.fs.FileStatus
Is this a directory?
isDirectory(Path) - Method in class org.apache.hadoop.fs.FileSystem
True iff the named path is a directory.
isDirectory(Path) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
isEmpty() - Method in class org.apache.hadoop.io.MapWritable
isEmpty() - Method in class org.apache.hadoop.io.SortedMapWritable
isEnabled() - Method in class org.apache.hadoop.fs.Trash
Returns whether the trash is enabled for this filesystem
isEnabled() - Method in class org.apache.hadoop.fs.TrashPolicy
Returns whether the Trash Policy is enabled for this filesystem
isFile() - Method in class org.apache.hadoop.fs.FileStatus
Is this a file?
isFile(Path) - Method in class org.apache.hadoop.fs.FileSystem
True iff the named path is a regular file.
isFile(Path) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
isFile(Path) - Method in class org.apache.hadoop.fs.s3.S3FileSystem
 
isIncrement() - Method in class org.apache.hadoop.metrics.spi.MetricValue
 
isJobComplete() - Method in class org.apache.hadoop.mapreduce.JobStatus
Returns true if the status is for a completed job.
isMap() - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
Deprecated.
isMap() - Method in class org.apache.hadoop.mapreduce.TaskID
Deprecated.
isMappingSingleSwitch(DNSToSwitchMapping) - Static method in class org.apache.hadoop.net.AbstractDNSToSwitchMapping
Query for a DNSToSwitchMapping instance being on a single switch.
isMapTask() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
isMonitoring() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Returns true if monitoring is currently in progress.
isMonitoring() - Method in class org.apache.hadoop.metrics.spi.CompositeContext
Return true if all subcontexts are monitoring.
isMultiNamedOutput(JobConf, String) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
Returns if a named output is multiple.
isNegativeVInt(byte) - Static method in class org.apache.hadoop.io.WritableUtils
Given the first byte of a vint/vlong, determine the sign
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.
isSingleSwitch() - Method in class org.apache.hadoop.net.AbstractDNSToSwitchMapping
Predicate that indicates that the switch mapping is known to be single-switch.
isSingleSwitch() - Method in class org.apache.hadoop.net.CachedDNSToSwitchMapping
Delegate the switch topology query to the raw mapping, via AbstractDNSToSwitchMapping.isMappingSingleSwitch(DNSToSwitchMapping)
isSingleSwitchByScriptPolicy() - Method in class org.apache.hadoop.net.AbstractDNSToSwitchMapping
 
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.
isSymlink() - Method in class org.apache.hadoop.fs.FileStatus
Is this a symbolic link?
isUber() - Method in class org.apache.hadoop.mapreduce.Job
 
isUber() - Method in class org.apache.hadoop.mapreduce.JobStatus
Whether job running in uber mode
isUriPathAbsolute() - Method in class org.apache.hadoop.fs.Path
True if the path component (i.e.
iterator() - Method in class org.apache.hadoop.conf.Configuration
Get an Iterator to go through the list of String key-value pairs in the configuration.
iterator() - Method in class org.apache.hadoop.io.EnumSetWritable
 
iterator() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
 
iterator() - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Return an iterator over the elements in this tuple.

J

JavaSerialization - Class in org.apache.hadoop.io.serializer
An experimental Serialization for Java Serializable classes.
JavaSerialization() - Constructor for class org.apache.hadoop.io.serializer.JavaSerialization
 
JavaSerializationComparator<T extends Serializable & Comparable<T>> - Class in org.apache.hadoop.io.serializer
A RawComparator that uses a JavaSerialization Deserializer to deserialize objects that are then compared via their Comparable interfaces.
JavaSerializationComparator() - Constructor for class org.apache.hadoop.io.serializer.JavaSerializationComparator
 
JBoolean - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JBoolean() - Constructor for class org.apache.hadoop.record.compiler.JBoolean
Deprecated.
Creates a new instance of JBoolean
JBuffer - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JBuffer() - Constructor for class org.apache.hadoop.record.compiler.JBuffer
Deprecated.
Creates a new instance of JBuffer
JByte - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JByte() - Constructor for class org.apache.hadoop.record.compiler.JByte
Deprecated.
 
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
 
JDouble - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JDouble() - Constructor for class org.apache.hadoop.record.compiler.JDouble
Deprecated.
Creates a new instance of JDouble
JField<T> - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JField(String, T) - Constructor for class org.apache.hadoop.record.compiler.JField
Deprecated.
Creates a new instance of JField
JFile - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JFile(String, ArrayList<JFile>, ArrayList<JRecord>) - Constructor for class org.apache.hadoop.record.compiler.JFile
Deprecated.
Creates a new instance of JFile
JFloat - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JFloat() - Constructor for class org.apache.hadoop.record.compiler.JFloat
Deprecated.
Creates a new instance of JFloat
JInt - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JInt() - Constructor for class org.apache.hadoop.record.compiler.JInt
Deprecated.
Creates a new instance of JInt
jj_nt - Variable in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
jjFillToken() - Method in class org.apache.hadoop.record.compiler.generated.RccTokenManager
Deprecated.
 
jjnewLexState - Static variable in class org.apache.hadoop.record.compiler.generated.RccTokenManager
Deprecated.
 
jjstrLiteralImages - Static variable in class org.apache.hadoop.record.compiler.generated.RccTokenManager
Deprecated.
 
JLong - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JLong() - Constructor for class org.apache.hadoop.record.compiler.JLong
Deprecated.
Creates a new instance of JLong
JMap - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JMap(JType, JType) - Constructor for class org.apache.hadoop.record.compiler.JMap
Deprecated.
Creates a new instance of JMap
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 - 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_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
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.
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.
JobContext - Interface in org.apache.hadoop.mapred
 
JobContext - Interface in org.apache.hadoop.mapreduce
A read-only view of the job that is provided to the tasks while they are running.
JobControl - Class in org.apache.hadoop.mapred.jobcontrol
 
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.
JobCounter - Enum in org.apache.hadoop.mapreduce
 
JobID - Class in org.apache.hadoop.mapred
JobID represents the immutable and unique identifier for the job.
JobID(String, int) - Constructor for class org.apache.hadoop.mapred.JobID
Constructs a JobID object
JobID() - Constructor for class org.apache.hadoop.mapred.JobID
 
JobID - Class in org.apache.hadoop.mapreduce
JobID represents the immutable and unique identifier for the job.
JobID(String, int) - Constructor for class org.apache.hadoop.mapreduce.JobID
Constructs a JobID object
JobID() - Constructor for class org.apache.hadoop.mapreduce.JobID
 
JOBID_REGEX - Static variable in class org.apache.hadoop.mapreduce.JobID
 
jobListCache - Variable in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
 
JobPriority - Enum in org.apache.hadoop.mapred
Used to describe the priority of the running job.
JobPriority - Enum in org.apache.hadoop.mapreduce
Used to describe the priority of the running job.
JobQueueInfo - Class in org.apache.hadoop.mapred
Class that contains the information regarding the Job Queues which are maintained by the Hadoop Map/Reduce framework.
JobQueueInfo() - Constructor for class org.apache.hadoop.mapred.JobQueueInfo
Default constructor for Job Queue Info.
JobQueueInfo(String, String) - Constructor for class org.apache.hadoop.mapred.JobQueueInfo
Construct a new JobQueueInfo object using the queue name and the scheduling information passed.
JobStatus - Class in org.apache.hadoop.mapred
Describes the current status of a job.
JobStatus() - Constructor for class org.apache.hadoop.mapred.JobStatus
 
JobStatus(JobID, float, float, float, int, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, int, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, int, JobPriority, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, int, JobPriority, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, int, JobPriority, String, String, String, String, boolean) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, int, JobPriority, String, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, int, JobPriority, String, String, String, String, String, boolean) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus - Class in org.apache.hadoop.mapreduce
Describes the current status of a job.
JobStatus() - Constructor for class org.apache.hadoop.mapreduce.JobStatus
 
JobStatus(JobID, float, float, float, float, JobStatus.State, JobPriority, String, String, String, String) - Constructor for class org.apache.hadoop.mapreduce.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, JobStatus.State, JobPriority, String, String, String, String, String) - Constructor for class org.apache.hadoop.mapreduce.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, JobStatus.State, JobPriority, String, String, String, String, String, boolean) - Constructor for class org.apache.hadoop.mapreduce.JobStatus
Create a job status object for a given jobid.
jobsToComplete() - Method in class org.apache.hadoop.mapred.JobClient
Get the jobs that are not completed and not failed.
jobSubmit(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Submit a job to the Map-Reduce framework.
JOIN_COMPARATOR - Static variable in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
 
JOIN_EXPR - Static variable in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
 
JoinRecordReader<K extends WritableComparable> - Class in org.apache.hadoop.mapred.join
Base class for Composite joins returning Tuples of arbitrary Writables.
JoinRecordReader(int, JobConf, int, Class<? extends WritableComparator>) - Constructor for class org.apache.hadoop.mapred.join.JoinRecordReader
 
JoinRecordReader<K extends WritableComparable<?>> - Class in org.apache.hadoop.mapreduce.lib.join
Base class for Composite joins returning Tuples of arbitrary Writables.
JoinRecordReader(int, Configuration, int, Class<? extends WritableComparator>) - Constructor for class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader
 
JRecord - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JRecord(String, ArrayList<JField<JType>>) - Constructor for class org.apache.hadoop.record.compiler.JRecord
Deprecated.
Creates a new instance of JRecord
JString - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JString() - Constructor for class org.apache.hadoop.record.compiler.JString
Deprecated.
Creates a new instance of JString
JType - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JType() - Constructor for class org.apache.hadoop.record.compiler.JType
Deprecated.
 
JVector - Class in org.apache.hadoop.record.compiler
Deprecated.
Replaced by Avro.
JVector(JType) - Constructor for class org.apache.hadoop.record.compiler.JVector
Deprecated.
Creates a new instance of JVector

K

key() - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
Return the key this RecordReader would supply on a call to next(K,V)
key(K) - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
Clone the key at the head of this RecordReader into the object provided.
key() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Return the key for the current join or the value at the top of the RecordReader heap.
key(K) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Clone the key at the top of this RR into the given object.
key() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Return the key at the head of this RR.
key(K) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Clone the key at the head of this RR into the object supplied.
key - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
key() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Return the key for the current join or the value at the top of the RecordReader heap.
key(K) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Clone the key at the top of this RR into the given object.
key() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Return the key at the head of this RR.
key(K) - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Clone the key at the head of this RR into the object supplied.
KEY_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
 
KEY_VALUE_SEPERATOR - Static variable in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
keyclass - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
KeyFieldBasedComparator<K,V> - Class in org.apache.hadoop.mapred.lib
This comparator implementation provides a subset of the features provided by the Unix/GNU Sort.
KeyFieldBasedComparator() - Constructor for class org.apache.hadoop.mapred.lib.KeyFieldBasedComparator
 
KeyFieldBasedComparator<K,V> - Class in org.apache.hadoop.mapreduce.lib.partition
This comparator implementation provides a subset of the features provided by the Unix/GNU Sort.
KeyFieldBasedComparator() - Constructor for class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
 
KeyFieldBasedPartitioner<K2,V2> - Class in org.apache.hadoop.mapred.lib
Defines a way to partition keys based on certain key fields (also see KeyFieldBasedComparator.
KeyFieldBasedPartitioner() - Constructor for class org.apache.hadoop.mapred.lib.KeyFieldBasedPartitioner
 
KeyFieldBasedPartitioner<K2,V2> - Class in org.apache.hadoop.mapreduce.lib.partition
Defines a way to partition keys based on certain key fields (also see KeyFieldBasedComparator.
KeyFieldBasedPartitioner() - Constructor for class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
 
keySet() - Method in class org.apache.hadoop.io.MapWritable
keySet() - Method in class org.apache.hadoop.io.SortedMapWritable
KeyValueLineRecordReader - Class in org.apache.hadoop.mapred
This class treats a line in the input as a key/value pair separated by a separator character.
KeyValueLineRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.mapred.KeyValueLineRecordReader
 
KeyValueLineRecordReader - Class in org.apache.hadoop.mapreduce.lib.input
This class treats a line in the input as a key/value pair separated by a separator character.
KeyValueLineRecordReader(Configuration) - Constructor for class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
 
KeyValueTextInputFormat - Class in org.apache.hadoop.mapred
An InputFormat for plain text files.
KeyValueTextInputFormat() - Constructor for class org.apache.hadoop.mapred.KeyValueTextInputFormat
 
KeyValueTextInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
An InputFormat for plain text files.
KeyValueTextInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.KeyValueTextInputFormat
 
kids - Variable in class org.apache.hadoop.mapred.join.CompositeRecordReader
 
kids - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
 
killApplication(ApplicationId) - Method in interface org.apache.hadoop.yarn.client.YarnClient
Kill an application identified by given ID.
killApplication(ApplicationId) - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
 
killApplication(ApplicationId) - Method in interface org.hadoop.yarn.client.YarnClient
Kill an application identified by given ID.
killApplication(ApplicationId) - Method in class org.hadoop.yarn.client.YarnClientImpl
 
KillApplicationRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The request sent by the client to the ResourceManager to abort a submitted application.
KillApplicationResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to the client aborting a submitted application.
KILLED - Static variable in class org.apache.hadoop.mapred.JobStatus
 
killJob() - Method in interface org.apache.hadoop.mapred.RunningJob
Kill the running job.
killJob() - Method in class org.apache.hadoop.mapreduce.Job
Kill the running job.
killJob() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
killTask(TaskAttemptID, boolean) - Method in interface org.apache.hadoop.mapred.RunningJob
Kill indicated task attempt.
killTask(String, boolean) - Method in interface org.apache.hadoop.mapred.RunningJob
Deprecated.
Applications should rather use RunningJob.killTask(TaskAttemptID, boolean)
killTask(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.Job
Kill indicated task attempt.
kind - Variable in class org.apache.hadoop.record.compiler.generated.Token
Deprecated.
An integer that describes the kind of this token.
KIND_NAME - Static variable in class org.apache.hadoop.yarn.security.client.RMDelegationTokenIdentifier
 
KosmosFileSystem - Class in org.apache.hadoop.fs.kfs
A FileSystem backed by KFS.
KosmosFileSystem() - Constructor for class org.apache.hadoop.fs.kfs.KosmosFileSystem
 

L

lastKey() - Method in class org.apache.hadoop.io.SortedMapWritable
LazyOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
A Convenience class that creates output lazily.
LazyOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.LazyOutputFormat
 
LazyOutputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.output
A Convenience class that creates output lazily.
LazyOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.LazyOutputFormat
 
LBRACE_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
LEFT_OFFSET_PROPERTY_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
 
length() - Method in class org.apache.hadoop.fs.AvroFSInput
 
LexicalError(boolean, int, int, int, String, char) - Static method in error org.apache.hadoop.record.compiler.generated.TokenMgrError
Deprecated.
Returns a detailed message for the Error when it is thrown by the token manager to indicate a lexical error.
lexStateNames - Static variable in class org.apache.hadoop.record.compiler.generated.RccTokenManager
Deprecated.
 
limits() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
 
line - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
LINES_PER_MAP - Static variable in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
 
list(File) - Static method in class org.apache.hadoop.fs.FileUtil
A wrapper for File.list().
listCorruptFileBlocks(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
 
listCorruptFileBlocks(Path) - Method in class org.apache.hadoop.fs.FileContext
 
listCorruptFileBlocks(Path) - Method in class org.apache.hadoop.fs.FileSystem
 
listCorruptFileBlocks(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
listFiles(Path, boolean) - Method in class org.apache.hadoop.fs.FileSystem
List the statuses and block locations of the files in the given path.
listFiles(File) - Static method in class org.apache.hadoop.fs.FileUtil
A wrapper for File.listFiles().
listLocatedStatus(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.listLocatedStatus(Path) except that Path f must be for this file system.
listLocatedStatus(Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
List the statuses of the files/directories in the given path if the path is a directory.
listLocatedStatus(Path) - Method in class org.apache.hadoop.fs.FileContext
List the statuses of the files/directories in the given path if the path is a directory.
listLocatedStatus(Path) - Method in class org.apache.hadoop.fs.FileSystem
List the statuses of the files/directories in the given path if the path is a directory.
listLocatedStatus(Path, PathFilter) - Method in class org.apache.hadoop.fs.FileSystem
Listing a directory The returned results include its block location if it is a file The results are filtered by the given path filter
listLocatedStatus(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
List files and its block locations in a directory.
listStatus(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.Util.listStatus(Path) except that Path f must be for this file system.
listStatus(Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
List the statuses of the files/directories in the given path if the path is a directory.
listStatus(Path) - Method in class org.apache.hadoop.fs.FileContext
List the statuses of the files/directories in the given path if the path is a directory.
listStatus(Path) - Method in class org.apache.hadoop.fs.FileSystem
List the statuses of the files/directories in the given path if the path is a directory.
listStatus(Path, PathFilter) - Method in class org.apache.hadoop.fs.FileSystem
Filter files/directories in the given path using the user-supplied path filter.
listStatus(Path[]) - Method in class org.apache.hadoop.fs.FileSystem
Filter files/directories in the given list of paths using default path filter.
listStatus(Path[], PathFilter) - Method in class org.apache.hadoop.fs.FileSystem
Filter files/directories in the given list of paths using user-supplied path filter.
listStatus(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
List files in a directory.
listStatus(Path) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
listStatus(Path) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
listStatus(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
listStatus(Path) - Method in class org.apache.hadoop.fs.s3.S3FileSystem
 
listStatus(Path) - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
If f is a file, this method will make a single call to S3.
listStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
listStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
listStatus(JobConf) - Method in class org.apache.hadoop.mapred.FileInputFormat
List input directories.
listStatus(JobConf) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
List input directories.
listStatus(JobConf) - Method in class org.apache.hadoop.mapred.SequenceFileInputFormat
 
listStatus(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
List input directories.
listStatus(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFormat
 
listStatusIterator(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.listStatus(Path) except that Path f must be for this file system.
listStatusIterator(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
load(Configuration, String, Class<K>) - Static method in class org.apache.hadoop.io.DefaultStringifier
Restores the object from the configuration.
loadArray(Configuration, String, Class<K>) - Static method in class org.apache.hadoop.io.DefaultStringifier
Restores the array of objects from the configuration.
loadClass(Configuration, String) - Static method in class org.apache.hadoop.io.ObjectWritable
Find and load the class with given name className by first finding it in the specified conf.
loadClass(String) - Method in class org.apache.hadoop.yarn.util.ApplicationClassLoader
 
loadClass(String, boolean) - Method in class org.apache.hadoop.yarn.util.ApplicationClassLoader
 
loadTokens(String, JobConf) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
load job token from a file
LOCAL_FS_URI - Static variable in interface org.apache.hadoop.fs.FsConstants
 
LocalFileSystem - Class in org.apache.hadoop.fs
Implement the FileSystem API for the checksumed local filesystem.
LocalFileSystem() - Constructor for class org.apache.hadoop.fs.LocalFileSystem
 
LocalFileSystem(FileSystem) - Constructor for class org.apache.hadoop.fs.LocalFileSystem
 
LocalResource - Interface in org.apache.hadoop.yarn.api.records
LocalResource represents a local resource required to run a container.
LocalResourceType - Enum in org.apache.hadoop.yarn.api.records
LocalResourceType specifies the type of a resource localized by the NodeManager.
LocalResourceVisibility - Enum in org.apache.hadoop.yarn.api.records
LocalResourceVisibility specifies the visibility of a resource localized by the NodeManager.
LocatedFileStatus - Class in org.apache.hadoop.fs
This class defines a FileStatus that includes a file's block locations.
LocatedFileStatus(FileStatus, BlockLocation[]) - Constructor for class org.apache.hadoop.fs.LocatedFileStatus
Constructor
LocatedFileStatus(long, boolean, int, long, long, long, FsPermission, String, String, Path, Path, BlockLocation[]) - Constructor for class org.apache.hadoop.fs.LocatedFileStatus
Constructor
lock(Path, boolean) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
Deprecated.
LOG - Static variable in class org.apache.hadoop.fs.FileContext
 
LOG - Static variable in class org.apache.hadoop.fs.FileSystem
 
LOG - Static variable in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
LOG - Static variable in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
LOG - Static variable in class org.apache.hadoop.io.compress.CompressionCodecFactory
 
log(Log) - Method in class org.apache.hadoop.mapred.Counters
Logs the current counter values.
LOG - Static variable in class org.apache.hadoop.mapred.FileInputFormat
 
LOG - Static variable in class org.apache.hadoop.mapred.FileOutputCommitter
 
LOG - Static variable in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
 
LOG - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
LOG - Static variable in class org.apache.hadoop.mapreduce.counters.AbstractCounters
 
LOG - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionMapper
 
LOG - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionReducer
 
LOG - Static variable in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
 
logSpec() - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
 
logSpec() - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
logThreadInfo(Log, String, long) - Static method in class org.apache.hadoop.util.ReflectionUtils
Log the current thread stacks at INFO level.
LONG_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
LONG_VALUE_MAX - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
 
LONG_VALUE_MAX - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
LONG_VALUE_MIN - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
 
LONG_VALUE_MIN - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
LONG_VALUE_SUM - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
 
LONG_VALUE_SUM - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
 
LongSumReducer<K> - Class in org.apache.hadoop.mapred.lib
A Reducer that sums long values.
LongSumReducer() - Constructor for class org.apache.hadoop.mapred.lib.LongSumReducer
 
LongSumReducer<KEY> - Class in org.apache.hadoop.mapreduce.lib.reduce
 
LongSumReducer() - Constructor for class org.apache.hadoop.mapreduce.lib.reduce.LongSumReducer
 
LongTypeID - Static variable in class org.apache.hadoop.record.meta.TypeID
Deprecated.
 
LongValueMax - Class in org.apache.hadoop.mapred.lib.aggregate
This class implements a value aggregator that maintain the maximum of a sequence of long values.
LongValueMax() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.LongValueMax
 
LongValueMax - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements a value aggregator that maintain the maximum of a sequence of long values.
LongValueMax() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMax
the default constructor
LongValueMin - Class in org.apache.hadoop.mapred.lib.aggregate
This class implements a value aggregator that maintain the minimum of a sequence of long values.
LongValueMin() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.LongValueMin
 
LongValueMin - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements a value aggregator that maintain the minimum of a sequence of long values.
LongValueMin() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMin
the default constructor
LongValueSum - Class in org.apache.hadoop.mapred.lib.aggregate
This class implements a value aggregator that sums up a sequence of long values.
LongValueSum() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.LongValueSum
 
LongValueSum - Class in org.apache.hadoop.mapreduce.lib.aggregate
This class implements a value aggregator that sums up a sequence of long values.
LongValueSum() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.LongValueSum
the default constructor
LongWritable - Class in org.apache.hadoop.io
A WritableComparable for longs.
LongWritable() - Constructor for class org.apache.hadoop.io.LongWritable
 
LongWritable(long) - Constructor for class org.apache.hadoop.io.LongWritable
 
lowerBound(List<? extends T>, T, Comparator<? super T>) - Static method in class org.apache.hadoop.io.file.tfile.Utils
Lower bound binary search.
lowerBound(List<? extends Comparable<? super T>>, T) - Static method in class org.apache.hadoop.io.file.tfile.Utils
Lower bound binary search.
LT_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 

M

main(String[]) - Static method in class org.apache.hadoop.conf.Configuration
For debugging.
main(String[]) - Static method in class org.apache.hadoop.fs.s3.MigrationTool
 
main(String[]) - Static method in class org.apache.hadoop.fs.Trash
Run an emptier.
main(String[]) - Static method in class org.apache.hadoop.io.compress.CompressionCodecFactory
A little test program.
main(String[]) - Static method in class org.apache.hadoop.io.file.tfile.TFile
Dumping the TFile information.
main(String[]) - Static method in class org.apache.hadoop.io.MapFile
 
main(String[]) - Static method in class org.apache.hadoop.mapred.JobClient
 
main(String[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
create and run an Aggregate based map/reduce job.
main(String[]) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Submit a pipes job based on the command line arguments.
main(String[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
create and run an Aggregate based map/reduce job.
main(String[]) - Static method in class org.apache.hadoop.mapreduce.lib.partition.InputSampler
 
main(String[]) - Static method in class org.apache.hadoop.mapreduce.tools.CLI
 
main(String[]) - Static method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
main(String[]) - Static method in class org.apache.hadoop.yarn.applications.distributedshell.ApplicationMaster
 
main(String[]) - Static method in class org.apache.hadoop.yarn.applications.distributedshell.Client
 
makeCompactString() - Method in class org.apache.hadoop.mapred.Counters
 
makeComparator(String) - Static method in class org.apache.hadoop.io.file.tfile.TFile
Make a raw comparator from a string name.
makeEscapedCompactString() - Method in class org.apache.hadoop.mapred.Counters
Represent the counter in a textual format that can be converted back to its object form
makeQualified(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Make the path fully qualified to this file system
makeQualified(Path) - Method in class org.apache.hadoop.fs.FileContext
Make the path fully qualified if it is isn't.
makeQualified(Path) - Method in class org.apache.hadoop.fs.FileSystem
Make sure that a path specifies a FileSystem.
makeQualified(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
Make sure that a path specifies a FileSystem.
makeQualified(FileSystem) - Method in class org.apache.hadoop.fs.Path
Deprecated.
makeQualified(URI, Path) - Method in class org.apache.hadoop.fs.Path
Returns a qualified path object.
makeShellPath(String) - Static method in class org.apache.hadoop.fs.FileUtil
Convert a os-native filename to a path that works for the shell.
makeShellPath(File) - Static method in class org.apache.hadoop.fs.FileUtil
Convert a os-native filename to a path that works for the shell.
makeShellPath(File, boolean) - Static method in class org.apache.hadoop.fs.FileUtil
Convert a os-native filename to a path that works for the shell.
makeSplit(Path, long, long, String[]) - Method in class org.apache.hadoop.mapred.FileInputFormat
A factory that makes the split for this class.
makeSplit(Path, long, long, String[]) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
A factory that makes the split for this class.
map(K1, V1, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Do nothing.
map(K1, V1, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorMapper
the map function.
map(K1, V1, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorReducer
Do nothing.
map(Object, Object, OutputCollector, Reporter) - Method in class org.apache.hadoop.mapred.lib.ChainMapper
Chains the map(...) methods of the Mappers in the chain.
map(K, V, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
The identify function.
map(K, V, OutputCollector<K, V>, Reporter) - Method in class org.apache.hadoop.mapred.lib.IdentityMapper
The identify function.
map(K, V, OutputCollector<V, K>, Reporter) - Method in class org.apache.hadoop.mapred.lib.InverseMapper
The inverse function.
map(K, Text, OutputCollector<Text, LongWritable>, Reporter) - Method in class org.apache.hadoop.mapred.lib.RegexMapper
 
map(K, Text, OutputCollector<Text, LongWritable>, Reporter) - Method in class org.apache.hadoop.mapred.lib.TokenCountMapper
 
map(K1, V1, OutputCollector<K2, V2>, Reporter) - Method in interface org.apache.hadoop.mapred.Mapper
Maps a single input key/value pair into an intermediate key/value pair.
map(K1, V1, Mapper<K1, V1, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorMapper
the map function.
map(K, V, Mapper<K, V, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionMapper
The identify function.
map(K, V, Mapper<K, V, V, K>.Context) - Method in class org.apache.hadoop.mapreduce.lib.map.InverseMapper
The inverse function.
map(K, Text, Mapper<K, Text, Text, LongWritable>.Context) - Method in class org.apache.hadoop.mapreduce.lib.map.RegexMapper
 
map(Object, Text, Mapper<Object, Text, Text, IntWritable>.Context) - Method in class org.apache.hadoop.mapreduce.lib.map.TokenCounterMapper
 
map(KEYIN, VALUEIN, Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Mapper
Called once for each key/value pair in the input split.
Map() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
MAP_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
 
MAP_OUTPUT_KEY_VALUE_SPEC - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
MAP_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
MapContext<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Interface in org.apache.hadoop.mapreduce
The context that is given to the Mapper.
MapFile - Class in org.apache.hadoop.io
A file-based map from keys to values.
MapFile() - Constructor for class org.apache.hadoop.io.MapFile
 
MapFileOutputFormat - Class in org.apache.hadoop.mapred
An OutputFormat that writes MapFiles.
MapFileOutputFormat() - Constructor for class org.apache.hadoop.mapred.MapFileOutputFormat
 
MapFileOutputFormat - Class in org.apache.hadoop.mapreduce.lib.output
An OutputFormat that writes MapFiles.
MapFileOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.MapFileOutputFormat
 
Mapper<K1,V1,K2,V2> - Interface in org.apache.hadoop.mapred
Maps input key/value pairs to a set of intermediate key/value pairs.
Mapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce
Maps input key/value pairs to a set of intermediate key/value pairs.
Mapper() - Constructor for class org.apache.hadoop.mapreduce.Mapper
 
mapProgress() - Method in class org.apache.hadoop.mapred.JobStatus
 
mapProgress() - Method in interface org.apache.hadoop.mapred.RunningJob
Get the progress of the job's map-tasks, as a float between 0.0 and 1.0.
mapProgress() - Method in class org.apache.hadoop.mapreduce.Job
Get the progress of the job's map-tasks, as a float between 0.0 and 1.0.
MAPRED_LOCAL_DIR_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Property name for the configuration property mapreduce.cluster.local.dir
MAPRED_MAP_TASK_ENV - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the maximum virutal memory available to the map tasks.
MAPRED_MAP_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the java command line options for the map tasks.
MAPRED_MAP_TASK_LOG_LEVEL - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the logging Level for the map task.
MAPRED_MAP_TASK_ULIMIT - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.
Configuration key to set the maximum virtual memory available to the map tasks (in kilo-bytes). This has been deprecated and will no longer have any effect.
MAPRED_REDUCE_TASK_ENV - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the maximum virutal memory available to the reduce tasks.
MAPRED_REDUCE_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the java command line options for the reduce tasks.
MAPRED_REDUCE_TASK_LOG_LEVEL - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the logging Level for the reduce task.
MAPRED_REDUCE_TASK_ULIMIT - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.
Configuration key to set the maximum virtual memory available to the reduce tasks (in kilo-bytes). This has been deprecated and will no longer have any effect.
MAPRED_TASK_DEFAULT_MAXVMEM_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
MAPRED_TASK_ENV - Static variable in class org.apache.hadoop.mapred.JobConf
MAPRED_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
MAPRED_TASK_MAXPMEM_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
MAPRED_TASK_MAXVMEM_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
MAPRED_TASK_ULIMIT - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.
Configuration key to set the maximum virtual memory available to the child map and reduce tasks (in kilo-bytes). This has been deprecated and will no longer have any effect.
MapReduceBase - Class in org.apache.hadoop.mapred
Base class for Mapper and Reducer implementations.
MapReduceBase() - Constructor for class org.apache.hadoop.mapred.MapReduceBase
 
MapRunnable<K1,V1,K2,V2> - Interface in org.apache.hadoop.mapred
Expert: Generic interface for Mappers.
MapRunner<K1,V1,K2,V2> - Class in org.apache.hadoop.mapred
Default MapRunnable implementation.
MapRunner() - Constructor for class org.apache.hadoop.mapred.MapRunner
 
MapTypeID - Class in org.apache.hadoop.record.meta
Deprecated.
Replaced by Avro.
MapTypeID(TypeID, TypeID) - Constructor for class org.apache.hadoop.record.meta.MapTypeID
Deprecated.
 
MapWritable - Class in org.apache.hadoop.io
A Writable Map.
MapWritable() - Constructor for class org.apache.hadoop.io.MapWritable
Default constructor.
MapWritable(MapWritable) - Constructor for class org.apache.hadoop.io.MapWritable
Copy constructor.
mark(int) - Method in class org.apache.hadoop.io.compress.DecompressorStream
 
mark() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
 
MarkableIterator<VALUE> - Class in org.apache.hadoop.mapreduce
MarkableIterator is a wrapper iterator class that implements the MarkableIteratorInterface.
MarkableIterator(Iterator<VALUE>) - Constructor for class org.apache.hadoop.mapreduce.MarkableIterator
Create a new iterator layered on the input iterator
markSupported() - Method in class org.apache.hadoop.io.compress.DecompressorStream
 
MAX_COUNTER_LIMIT - Static variable in class org.apache.hadoop.mapred.Counters
 
MAX_NUM_UNIQUE_VALUES - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
 
MAX_TRIE_DEPTH - Static variable in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
maxAvailableData - Variable in class org.apache.hadoop.io.compress.CompressionInputStream
 
MAXIMUM_FP - Static variable in interface org.apache.hadoop.util.bloom.RemoveScheme
MaximumFP Selection.
maxNextCharInd - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
MBeans - Class in org.apache.hadoop.metrics2.util
This util class provides a method to register an MBean using our standard naming convention as described in the doc for {link MBeans.register(String, String, Object)
MBeans() - Constructor for class org.apache.hadoop.metrics2.util.MBeans
 
MD5_LEN - Static variable in class org.apache.hadoop.io.MD5Hash
 
MD5Hash - Class in org.apache.hadoop.io
A Writable for MD5 hash values.
MD5Hash() - Constructor for class org.apache.hadoop.io.MD5Hash
Constructs an MD5Hash.
MD5Hash(String) - Constructor for class org.apache.hadoop.io.MD5Hash
Constructs an MD5Hash from a hex string.
MD5Hash(byte[]) - Constructor for class org.apache.hadoop.io.MD5Hash
Constructs an MD5Hash with a specified value.
membershipTest(Key) - Method in class org.apache.hadoop.util.bloom.BloomFilter
 
membershipTest(Key) - Method in class org.apache.hadoop.util.bloom.CountingBloomFilter
 
membershipTest(Key) - Method in class org.apache.hadoop.util.bloom.DynamicBloomFilter
 
MetaBlockAlreadyExists - Exception in org.apache.hadoop.io.file.tfile
Exception - Meta Block with the same name already exists.
MetaBlockDoesNotExist - Exception in org.apache.hadoop.io.file.tfile
Exception - No such Meta Block with the given name.
Metric - Annotation Type in org.apache.hadoop.metrics2.annotation
Annotation interface for a single metric
Metrics - Annotation Type in org.apache.hadoop.metrics2.annotation
Annotation interface for a group of metrics
metrics() - Method in interface org.apache.hadoop.metrics2.MetricsRecord
Get the metrics of the record
MetricsCache - Class in org.apache.hadoop.metrics2.util
A metrics cache for sinks that don't support sparse updates.
MetricsCache() - Constructor for class org.apache.hadoop.metrics2.util.MetricsCache
 
MetricsCache(int) - Constructor for class org.apache.hadoop.metrics2.util.MetricsCache
Construct a metrics cache
MetricsCollector - Interface in org.apache.hadoop.metrics2
The metrics collector interface
MetricsException - Exception in org.apache.hadoop.metrics2
A general metrics exception wrapper
MetricsException(String) - Constructor for exception org.apache.hadoop.metrics2.MetricsException
Construct the exception with a message
MetricsException(String, Throwable) - Constructor for exception org.apache.hadoop.metrics2.MetricsException
Construct the exception with a message and a cause
MetricsException(Throwable) - Constructor for exception org.apache.hadoop.metrics2.MetricsException
Construct the exception with a cause
MetricsFilter - Class in org.apache.hadoop.metrics2
The metrics filter interface
MetricsFilter() - Constructor for class org.apache.hadoop.metrics2.MetricsFilter
 
MetricsInfo - Interface in org.apache.hadoop.metrics2
Interface to provide immutable meta info for metrics
MetricsPlugin - Interface in org.apache.hadoop.metrics2
The plugin interface for the metrics framework
MetricsRecord - Interface in org.apache.hadoop.metrics2
An immutable snapshot of metrics with a timestamp
MetricsRecordBuilder - Class in org.apache.hadoop.metrics2
The metrics record builder interface
MetricsRecordBuilder() - Constructor for class org.apache.hadoop.metrics2.MetricsRecordBuilder
 
MetricsRecordImpl - Class in org.apache.hadoop.metrics.spi
An implementation of MetricsRecord.
MetricsRecordImpl(String, AbstractMetricsContext) - Constructor for class org.apache.hadoop.metrics.spi.MetricsRecordImpl
Creates a new instance of FileRecord
MetricsRegistry - Class in org.apache.hadoop.metrics2.lib
An optional metrics registry class for creating and maintaining a collection of MetricsMutables, making writing metrics source easier.
MetricsRegistry(String) - Constructor for class org.apache.hadoop.metrics2.lib.MetricsRegistry
Construct the registry with a record name
MetricsRegistry(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.MetricsRegistry
Construct the registry with a metadata object
metricsServers - Variable in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
MetricsSink - Interface in org.apache.hadoop.metrics2
The metrics sink interface
MetricsSource - Interface in org.apache.hadoop.metrics2
The metrics source interface
MetricsSystem - Class in org.apache.hadoop.metrics2
The metrics system interface
MetricsSystem() - Constructor for class org.apache.hadoop.metrics2.MetricsSystem
 
MetricsSystemMXBean - Interface in org.apache.hadoop.metrics2
The JMX interface to the metrics system
MetricsTag - Class in org.apache.hadoop.metrics2
Immutable tag for metrics (for grouping on host/queue/username etc.)
MetricsTag(MetricsInfo, String) - Constructor for class org.apache.hadoop.metrics2.MetricsTag
Construct the tag with name, description and value
MetricsVisitor - Interface in org.apache.hadoop.metrics2
A visitor interface for metrics
MetricValue - Class in org.apache.hadoop.metrics.spi
A Number that is either an absolute or an incremental amount.
MetricValue(Number, boolean) - Constructor for class org.apache.hadoop.metrics.spi.MetricValue
Creates a new instance of MetricValue
MigrationTool - Class in org.apache.hadoop.fs.s3
This class is a tool for migrating data from an older to a newer version of an S3 filesystem.
MigrationTool() - Constructor for class org.apache.hadoop.fs.s3.MigrationTool
 
MINIMUM_FN - Static variable in interface org.apache.hadoop.util.bloom.RemoveScheme
MinimumFN Selection.
mkdir(Path, FsPermission, boolean) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.mkdir(Path, FsPermission, boolean) except that the Path f must be fully qualified and the permission is absolute (i.e.
mkdir(Path, FsPermission, boolean) - Method in class org.apache.hadoop.fs.FileContext
Make(create) a directory and all the non-existent parents.
mkdir(Path, FsPermission, boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
mkdirs(Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
 
mkdirs(FileSystem, Path, FsPermission) - Static method in class org.apache.hadoop.fs.FileSystem
create a directory with the provided permission The permission of the directory is set to be the provided permission as in setPermission, not permission&~umask
mkdirs(Path) - Method in class org.apache.hadoop.fs.FileSystem
Call FileSystem.mkdirs(Path, FsPermission) with default permission.
mkdirs(Path, FsPermission) - Method in class org.apache.hadoop.fs.FileSystem
Make the given file and all non-existent parents into directories.
mkdirs(Path, FsPermission) - Method in class org.apache.hadoop.fs.FilterFileSystem
Make the given file and all non-existent parents into directories.
mkdirs(Path, FsPermission) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
mkdirs(Path, FsPermission) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
mkdirs(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
Creates the specified directory hierarchy.
mkdirs(Path, FsPermission) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
Make the given file and all non-existent parents into directories.
mkdirs(Path, FsPermission) - Method in class org.apache.hadoop.fs.s3.S3FileSystem
 
mkdirs(Path, FsPermission) - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
mkdirs(Path, FsPermission) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
Module() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
MODULE_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
ModuleName() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
monitorAndPrintJob(JobConf, RunningJob) - Method in class org.apache.hadoop.mapred.JobClient
Monitor a job and print status in real-time as progress is made and tasks fail.
monitorAndPrintJob() - Method in class org.apache.hadoop.mapreduce.Job
Monitor a job and print status in real-time as progress is made and tasks fail.
moveFromLocalFile(Path[], Path) - Method in class org.apache.hadoop.fs.FileSystem
The src files is on the local disk.
moveFromLocalFile(Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
The src file is on the local disk.
moveFromLocalFile(Path, Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
moveToAppropriateTrash(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.fs.Trash
In case of the symlinks or mount points, one has to move the appropriate trashbin in the actual volume of the path p being deleted.
moveToLocalFile(Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
The src file is under FS, and the dst is on the local disk.
moveToTrash(Path) - Method in class org.apache.hadoop.fs.Trash
Move a file or directory to the current trash directory.
moveToTrash(Path) - Method in class org.apache.hadoop.fs.TrashPolicy
Move a file or directory to the current trash directory.
MultiFileInputFormat<K,V> - Class in org.apache.hadoop.mapred
MultiFileInputFormat() - Constructor for class org.apache.hadoop.mapred.MultiFileInputFormat
 
MultiFileSplit - Class in org.apache.hadoop.mapred
A sub-collection of input files.
MultiFileSplit(JobConf, Path[], long[]) - Constructor for class org.apache.hadoop.mapred.MultiFileSplit
 
MultiFilterRecordReader<K extends WritableComparable,V extends Writable> - Class in org.apache.hadoop.mapred.join
Base class for Composite join returning values derived from multiple sources, but generally not tuples.
MultiFilterRecordReader(int, JobConf, int, Class<? extends WritableComparator>) - Constructor for class org.apache.hadoop.mapred.join.MultiFilterRecordReader
 
MultiFilterRecordReader<K extends WritableComparable<?>,V extends Writable> - Class in org.apache.hadoop.mapreduce.lib.join
Base class for Composite join returning values derived from multiple sources, but generally not tuples.
MultiFilterRecordReader(int, Configuration, int, Class<? extends WritableComparator>) - Constructor for class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader
 
MultipleInputs - Class in org.apache.hadoop.mapred.lib
This class supports MapReduce jobs that have multiple input paths with a different InputFormat and Mapper for each path
MultipleInputs() - Constructor for class org.apache.hadoop.mapred.lib.MultipleInputs
 
MultipleInputs - Class in org.apache.hadoop.mapreduce.lib.input
This class supports MapReduce jobs that have multiple input paths with a different InputFormat and Mapper for each path
MultipleInputs() - Constructor for class org.apache.hadoop.mapreduce.lib.input.MultipleInputs
 
MultipleIOException - Exception in org.apache.hadoop.io
Encapsulate a list of IOException into an IOException
MultipleOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
This abstract class extends the FileOutputFormat, allowing to write the output data to different output files.
MultipleOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.MultipleOutputFormat
 
MultipleOutputs - Class in org.apache.hadoop.mapred.lib
The MultipleOutputs class simplifies writting to additional outputs other than the job default output via the OutputCollector passed to the map() and reduce() methods of the Mapper and Reducer implementations.
MultipleOutputs(JobConf) - Constructor for class org.apache.hadoop.mapred.lib.MultipleOutputs
Creates and initializes multiple named outputs support, it should be instantiated in the Mapper/Reducer configure method.
MultipleOutputs<KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce.lib.output
The MultipleOutputs class simplifies writing output data to multiple outputs
MultipleOutputs(TaskInputOutputContext<?, ?, KEYOUT, VALUEOUT>) - Constructor for class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
Creates and initializes multiple outputs support, it should be instantiated in the Mapper/Reducer setup method.
MultipleSequenceFileOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
This class extends the MultipleOutputFormat, allowing to write the output data to different output files in sequence file output format.
MultipleSequenceFileOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.MultipleSequenceFileOutputFormat
 
MultipleTextOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
This class extends the MultipleOutputFormat, allowing to write the output data to different output files in Text output format.
MultipleTextOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.MultipleTextOutputFormat
 
MultithreadedMapper<K1,V1,K2,V2> - Class in org.apache.hadoop.mapreduce.lib.map
Multithreaded implementation for @link org.apache.hadoop.mapreduce.Mapper.
MultithreadedMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
 
MultithreadedMapRunner<K1,V1,K2,V2> - Class in org.apache.hadoop.mapred.lib
Multithreaded implementation for @link org.apache.hadoop.mapred.MapRunnable.
MultithreadedMapRunner() - Constructor for class org.apache.hadoop.mapred.lib.MultithreadedMapRunner
 
MutableCounter - Class in org.apache.hadoop.metrics2.lib
The mutable counter (monotonically increasing) metric interface
MutableCounter(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.MutableCounter
 
MutableCounterInt - Class in org.apache.hadoop.metrics2.lib
A mutable int counter for implementing metrics sources
MutableCounterLong - Class in org.apache.hadoop.metrics2.lib
A mutable long counter
MutableGauge - Class in org.apache.hadoop.metrics2.lib
The mutable gauge metric interface
MutableGauge(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.MutableGauge
 
MutableGaugeInt - Class in org.apache.hadoop.metrics2.lib
A mutable int gauge
MutableGaugeLong - Class in org.apache.hadoop.metrics2.lib
A mutable long gauge
MutableMetric - Class in org.apache.hadoop.metrics2.lib
The mutable metric interface
MutableMetric() - Constructor for class org.apache.hadoop.metrics2.lib.MutableMetric
 
MutableRate - Class in org.apache.hadoop.metrics2.lib
A convenient mutable metric for throughput measurement
MutableRates - Class in org.apache.hadoop.metrics2.lib
Helper class to manage a group of mutable rate metrics
MutableStat - Class in org.apache.hadoop.metrics2.lib
A mutable metric with stats.
MutableStat(String, String, String, String, boolean) - Constructor for class org.apache.hadoop.metrics2.lib.MutableStat
Construct a sample statistics metric
MutableStat(String, String, String, String) - Constructor for class org.apache.hadoop.metrics2.lib.MutableStat
Construct a snapshot stat metric with extended stat off by default
MySQLDataDrivenDBRecordReader<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A RecordReader that reads records from a MySQL table via DataDrivenDBRecordReader
MySQLDataDrivenDBRecordReader(DBInputFormat.DBInputSplit, Class<T>, Configuration, Connection, DBConfiguration, String, String[], String) - Constructor for class org.apache.hadoop.mapreduce.lib.db.MySQLDataDrivenDBRecordReader
 
MySQLDBRecordReader<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A RecordReader that reads records from a MySQL table.
MySQLDBRecordReader(DBInputFormat.DBInputSplit, Class<T>, Configuration, Connection, DBConfiguration, String, String[], String) - Constructor for class org.apache.hadoop.mapreduce.lib.db.MySQLDBRecordReader
 

N

name() - Method in class org.apache.hadoop.metrics2.AbstractMetric
 
name() - Method in interface org.apache.hadoop.metrics2.MetricsInfo
 
name() - Method in interface org.apache.hadoop.metrics2.MetricsRecord
 
name() - Method in class org.apache.hadoop.metrics2.MetricsTag
 
NativeS3FileSystem - Class in org.apache.hadoop.fs.s3native
A FileSystem for reading and writing files stored on Amazon S3.
NativeS3FileSystem() - Constructor for class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
NativeS3FileSystem(NativeFileSystemStore) - Constructor for class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
NATURAL_ORDER - Static variable in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
needsDictionary() - Method in interface org.apache.hadoop.io.compress.Decompressor
Returns true if a preset dictionary is needed for decompression.
needsInput() - Method in interface org.apache.hadoop.io.compress.Compressor
Returns true if the input data buffer is empty and #setInput() should be called to provide more input.
needsInput() - Method in interface org.apache.hadoop.io.compress.Decompressor
Returns true if the input data buffer is empty and Decompressor.setInput(byte[], int, int) should be called to provide more input.
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Check whether task needs a commit.
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
This method implements the new interface by calling the old method.
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Did this task write any files in the work directory?
needsTaskCommit(TaskAttemptContext, Path) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
Check whether task needs a commit.
NET_TOPOLOGY_NODE_SWITCH_MAPPING_IMPL_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
NET_TOPOLOGY_SCRIPT_FILE_NAME_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
NET_TOPOLOGY_SCRIPT_NUMBER_ARGS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for NET_TOPOLOGY_SCRIPT_NUMBER_ARGS_KEY
NET_TOPOLOGY_SCRIPT_NUMBER_ARGS_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
newCounter(String, String, int) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable integer counter
newCounter(MetricsInfo, int) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable integer counter
newCounter(String, String, long) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable long integer counter
newCounter(MetricsInfo, long) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable long integer counter
newGauge(String, String, int) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable integer gauge
newGauge(MetricsInfo, int) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable integer gauge
newGauge(String, String, long) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable long integer gauge
newGauge(MetricsInfo, long) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable long integer gauge
newInstance(URI, Configuration, String) - Static method in class org.apache.hadoop.fs.FileSystem
Returns the FileSystem for this URI's scheme and authority and the passed user.
newInstance(URI, Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
Returns the FileSystem for this URI's scheme and authority.
newInstance(Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
Returns a unique configured filesystem implementation.
newInstance(Class<? extends Writable>, Configuration) - Static method in class org.apache.hadoop.io.WritableFactories
Create a new instance of a class with a defined factory.
newInstance(Class<? extends Writable>) - Static method in class org.apache.hadoop.io.WritableFactories
Create a new instance of a class with a defined factory.
newInstance() - Method in interface org.apache.hadoop.io.WritableFactory
Return a new instance.
newInstance(Class<T>, Configuration) - Static method in class org.apache.hadoop.util.ReflectionUtils
Create an object for the given class and initialize it from conf
newInstanceLocal(Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
Get a unique local file system object
newKey() - Method in class org.apache.hadoop.io.WritableComparator
Construct a new WritableComparable instance.
newMBeanName(String) - Static method in enum org.apache.hadoop.metrics2.lib.DefaultMetricsSystem
 
newRate(String) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable rate metric
newRate(String, String) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable rate metric
newRate(String, String, boolean) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable rate metric (for throughput measurement)
newRate(String, String, boolean, boolean) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
 
newRecord(String) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Subclasses should override this if they subclass MetricsRecordImpl.
newRecord(String) - Method in class org.apache.hadoop.metrics.spi.CompositeContext
 
newStat(String, String, String, String, boolean) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable metric with stats
newStat(String, String, String, String) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable metric with stats
newToken(int) - Static method in class org.apache.hadoop.record.compiler.generated.Token
Deprecated.
Returns a new Token object, by default.
next(K, TupleWritable) - Method in class org.apache.hadoop.mapred.join.JoinRecordReader
Emit the next set of key, value pairs as defined by the child RecordReaders and operation associated with this composite RR.
next(K, V) - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader
Reads the next key/value pair from the input for processing.
next() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Read the next k,v pair into the head of this object; return true iff the RR and this are exhausted.
next(K, U) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Write key-value pair at the head of this stream to the objects provided; get next key-value pair from proxied RR.
next(Text, Text) - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
Read key/value pair in a line.
next(K, V) - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
next(K, V) - Method in interface org.apache.hadoop.mapred.RecordReader
Reads the next key/value pair from the input for processing.
next(Text, Text) - Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
Read key/value pair in a line.
next(K, V) - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
next(K) - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
next(LongWritable, T) - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
next(X) - Method in class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
 
next(T) - Method in interface org.apache.hadoop.mapreduce.lib.join.ResetableIterator
Assign next value to actual.
next(X) - Method in class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
 
next() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
 
next - Variable in class org.apache.hadoop.record.compiler.generated.Token
Deprecated.
A reference to the next regular (non-special) token from the input stream.
nextKey() - Method in interface org.apache.hadoop.mapreduce.ReduceContext
Start processing next unique key.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Read the next key, value pair.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
Read key/value pair in a line.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextRecordReader
Read key/value pair in a line.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
 
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.join.JoinRecordReader
Emit the next set of key, value pairs as defined by the child RecordReaders and operation associated with this composite RR.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.join.MultiFilterRecordReader
Read the next key, value pair.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Read the next k,v pair into the head of this object; return true iff the RR and this are exhausted.
nextKeyValue() - Method in class org.apache.hadoop.mapreduce.RecordReader
Read the next key, value pair.
nextKeyValue() - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
Advance to the next key, value pair, returning null if at end.
NLineInputFormat - Class in org.apache.hadoop.mapred.lib
NLineInputFormat which splits N lines of input as one split.
NLineInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.NLineInputFormat
 
NLineInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
NLineInputFormat which splits N lines of input as one split.
NLineInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
 
NO_SCRIPT - Static variable in class org.apache.hadoop.net.ScriptBasedMapping
Text used in the ScriptBasedMapping.toString() method if there is no string "no script"
NodeHealthStatus - Interface in org.apache.hadoop.yarn.api.records
NodeHealthStatus is a summary of the health status of the node.
NodeId - Class in org.apache.hadoop.yarn.api.records
NodeId is the unique identifier for a node.
NodeId() - Constructor for class org.apache.hadoop.yarn.api.records.NodeId
 
NodeReport - Interface in org.apache.hadoop.yarn.api.records
NodeReport is a summary of runtime information of a node in the cluster.
NoEmitMetricsContext - Class in org.apache.hadoop.metrics.spi
A MetricsContext that does not emit data, but, unlike NullContextWithUpdate, does save it for retrieval with getAllRecords().
NoEmitMetricsContext() - Constructor for class org.apache.hadoop.metrics.spi.NoEmitMetricsContext
Creates a new instance of NullContextWithUpdateThread
normalizeMemoryConfigValue(long) - Static method in class org.apache.hadoop.mapred.JobConf
Normalize the negative values in configuration
not() - Method in class org.apache.hadoop.util.bloom.BloomFilter
 
not() - Method in class org.apache.hadoop.util.bloom.CountingBloomFilter
 
not() - Method in class org.apache.hadoop.util.bloom.DynamicBloomFilter
 
NotInMountpointException - Exception in org.apache.hadoop.fs.viewfs
NotInMountpointException extends the UnsupportedOperationException.
NotInMountpointException(Path, String) - Constructor for exception org.apache.hadoop.fs.viewfs.NotInMountpointException
 
NotInMountpointException(String) - Constructor for exception org.apache.hadoop.fs.viewfs.NotInMountpointException
 
NULL - Static variable in interface org.apache.hadoop.mapred.Reporter
A constant of Reporter type that does nothing.
NullContext - Class in org.apache.hadoop.metrics.spi
Null metrics context: a metrics context which does nothing.
NullContext() - Constructor for class org.apache.hadoop.metrics.spi.NullContext
Creates a new instance of NullContext
NullContextWithUpdateThread - Class in org.apache.hadoop.metrics.spi
A null context which has a thread calling periodically when monitoring is started.
NullContextWithUpdateThread() - Constructor for class org.apache.hadoop.metrics.spi.NullContextWithUpdateThread
Creates a new instance of NullContextWithUpdateThread
NullOutputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
Consume all outputs and put them in /dev/null.
NullOutputFormat() - Constructor for class org.apache.hadoop.mapred.lib.NullOutputFormat
 
NullOutputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.output
Consume all outputs and put them in /dev/null.
NullOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.NullOutputFormat
 
NullWritable - Class in org.apache.hadoop.io
Singleton Writable with no data.
NUM_INPUT_FILES - Static variable in class org.apache.hadoop.mapred.FileInputFormat
 
NUM_INPUT_FILES - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
NUM_THREADS - Static variable in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
 

O

ObjectWritable - Class in org.apache.hadoop.io
A polymorphic Writable that writes an instance with it's class name.
ObjectWritable() - Constructor for class org.apache.hadoop.io.ObjectWritable
 
ObjectWritable(Object) - Constructor for class org.apache.hadoop.io.ObjectWritable
 
ObjectWritable(Class, Object) - Constructor for class org.apache.hadoop.io.ObjectWritable
 
obtainTokensForNamenodes(Credentials, Path[], Configuration) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
Convenience method to obtain delegation tokens from namenodes corresponding to the paths passed.
offset() - Method in interface org.apache.hadoop.io.file.tfile.RawComparable
Get the offset of the first byte in the byte array.
offset - Variable in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
ONE - Static variable in interface org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorDescriptor
 
ONE - Static variable in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorDescriptor
 
open(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.open(Path) except that Path f must be for this file system.
open(Path, int) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.open(Path, int) except that Path f must be for this file system.
open(Path, int) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
Opens an FSDataInputStream at the indicated Path.
open(Path) - Method in class org.apache.hadoop.fs.FileContext
Opens an FSDataInputStream at the indicated Path using default buffersize.
open(Path, int) - Method in class org.apache.hadoop.fs.FileContext
Opens an FSDataInputStream at the indicated Path.
open(Path, int) - Method in class org.apache.hadoop.fs.FileSystem
Opens an FSDataInputStream at the indicated Path.
open(Path) - Method in class org.apache.hadoop.fs.FileSystem
Opens an FSDataInputStream at the indicated Path.
open(Path, int) - Method in class org.apache.hadoop.fs.FilterFileSystem
Opens an FSDataInputStream at the indicated Path.
open(Path, int) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
open(Path, int) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
 
open(Path, int) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
open(Path, int) - Method in class org.apache.hadoop.fs.s3.S3FileSystem
 
open(Path, int) - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
open(Path, int) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
open(Path, int) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
Options - Class in org.apache.hadoop.fs
This class contains options related to file system operations.
Options() - Constructor for class org.apache.hadoop.fs.Options
 
or(Filter) - Method in class org.apache.hadoop.util.bloom.BloomFilter
 
or(Filter) - Method in class org.apache.hadoop.util.bloom.CountingBloomFilter
 
or(Filter) - Method in class org.apache.hadoop.util.bloom.DynamicBloomFilter
 
OracleDataDrivenDBInputFormat<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A InputFormat that reads input data from an SQL table in an Oracle db.
OracleDataDrivenDBInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.db.OracleDataDrivenDBInputFormat
 
OracleDataDrivenDBRecordReader<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A RecordReader that reads records from a Oracle table via DataDrivenDBRecordReader
OracleDataDrivenDBRecordReader(DBInputFormat.DBInputSplit, Class<T>, Configuration, Connection, DBConfiguration, String, String[], String) - Constructor for class org.apache.hadoop.mapreduce.lib.db.OracleDataDrivenDBRecordReader
 
OracleDateSplitter - Class in org.apache.hadoop.mapreduce.lib.db
Implement DBSplitter over date/time values returned by an Oracle db.
OracleDateSplitter() - Constructor for class org.apache.hadoop.mapreduce.lib.db.OracleDateSplitter
 
OracleDBRecordReader<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A RecordReader that reads records from an Oracle SQL table.
OracleDBRecordReader(DBInputFormat.DBInputSplit, Class<T>, Configuration, Connection, DBConfiguration, String, String[], String) - Constructor for class org.apache.hadoop.mapreduce.lib.db.OracleDBRecordReader
 
org.apache.hadoop - package org.apache.hadoop
 
org.apache.hadoop.classification - package org.apache.hadoop.classification
 
org.apache.hadoop.conf - package org.apache.hadoop.conf
Configuration of system parameters.
org.apache.hadoop.contrib.utils.join - package org.apache.hadoop.contrib.utils.join
 
org.apache.hadoop.examples - package org.apache.hadoop.examples
Hadoop example code.
org.apache.hadoop.examples.dancing - package org.apache.hadoop.examples.dancing
This package is a distributed implementation of Knuth's dancing links algorithm that can run under Hadoop.
org.apache.hadoop.examples.pi - package org.apache.hadoop.examples.pi
This package consists of a map/reduce application, distbbp, which computes exact binary digits of the mathematical constant π.
org.apache.hadoop.examples.pi.math - package org.apache.hadoop.examples.pi.math
This package provides useful mathematical library classes for the distbbp program.
org.apache.hadoop.examples.terasort - package org.apache.hadoop.examples.terasort
This package consists of 3 map/reduce applications for Hadoop to compete in the annual terabyte sort competition.
org.apache.hadoop.filecache - package org.apache.hadoop.filecache
 
org.apache.hadoop.fs - package org.apache.hadoop.fs
An abstract file system API.
org.apache.hadoop.fs.ftp - package org.apache.hadoop.fs.ftp
 
org.apache.hadoop.fs.http.client - package org.apache.hadoop.fs.http.client
 
org.apache.hadoop.fs.http.server - package org.apache.hadoop.fs.http.server
 
org.apache.hadoop.fs.kfs - package org.apache.hadoop.fs.kfs
A client for the Kosmos filesystem (KFS)
org.apache.hadoop.fs.permission - package org.apache.hadoop.fs.permission
 
org.apache.hadoop.fs.s3 - package org.apache.hadoop.fs.s3
A distributed, block-based implementation of FileSystem that uses Amazon S3 as a backing store.
org.apache.hadoop.fs.s3native - package org.apache.hadoop.fs.s3native
A distributed implementation of FileSystem for reading and writing files on Amazon S3.
org.apache.hadoop.fs.viewfs - package org.apache.hadoop.fs.viewfs
 
org.apache.hadoop.http.lib - package org.apache.hadoop.http.lib
This package provides user-selectable (via configuration) classes that add functionality to the web UI.
org.apache.hadoop.io - package org.apache.hadoop.io
Generic i/o code for use when reading and writing data to the network, to databases, and to files.
org.apache.hadoop.io.compress - package org.apache.hadoop.io.compress
 
org.apache.hadoop.io.file.tfile - package org.apache.hadoop.io.file.tfile
 
org.apache.hadoop.io.serializer - package org.apache.hadoop.io.serializer
This package provides a mechanism for using different serialization frameworks in Hadoop.
org.apache.hadoop.io.serializer.avro - package org.apache.hadoop.io.serializer.avro
This package provides Avro serialization in Hadoop.
org.apache.hadoop.jmx - package org.apache.hadoop.jmx
This package provides access to JMX primarily through the JMXJsonServlet class.
org.apache.hadoop.lib.lang - package org.apache.hadoop.lib.lang
 
org.apache.hadoop.lib.server - package org.apache.hadoop.lib.server
 
org.apache.hadoop.lib.service - package org.apache.hadoop.lib.service
 
org.apache.hadoop.lib.service.hadoop - package org.apache.hadoop.lib.service.hadoop
 
org.apache.hadoop.lib.service.instrumentation - package org.apache.hadoop.lib.service.instrumentation
 
org.apache.hadoop.lib.service.scheduler - package org.apache.hadoop.lib.service.scheduler
 
org.apache.hadoop.lib.service.security - package org.apache.hadoop.lib.service.security
 
org.apache.hadoop.lib.servlet - package org.apache.hadoop.lib.servlet
 
org.apache.hadoop.lib.util - package org.apache.hadoop.lib.util
 
org.apache.hadoop.lib.wsrs - package org.apache.hadoop.lib.wsrs
 
org.apache.hadoop.log - package org.apache.hadoop.log
 
org.apache.hadoop.log.metrics - package org.apache.hadoop.log.metrics
 
org.apache.hadoop.mapred - package org.apache.hadoop.mapred
 
org.apache.hadoop.mapred.gridmix - package org.apache.hadoop.mapred.gridmix
 
org.apache.hadoop.mapred.gridmix.emulators.resourceusage - package org.apache.hadoop.mapred.gridmix.emulators.resourceusage
 
org.apache.hadoop.mapred.jobcontrol - package org.apache.hadoop.mapred.jobcontrol
 
org.apache.hadoop.mapred.join - package org.apache.hadoop.mapred.join
 
org.apache.hadoop.mapred.lib - package org.apache.hadoop.mapred.lib
 
org.apache.hadoop.mapred.lib.aggregate - package org.apache.hadoop.mapred.lib.aggregate
 
org.apache.hadoop.mapred.lib.db - package org.apache.hadoop.mapred.lib.db
 
org.apache.hadoop.mapred.pipes - package org.apache.hadoop.mapred.pipes
 
org.apache.hadoop.mapred.tools - package org.apache.hadoop.mapred.tools
Command-line tools associated with the org.apache.hadoop.mapred package.
org.apache.hadoop.mapreduce - package org.apache.hadoop.mapreduce
 
org.apache.hadoop.mapreduce.lib.aggregate - package org.apache.hadoop.mapreduce.lib.aggregate
 
org.apache.hadoop.mapreduce.lib.chain - package org.apache.hadoop.mapreduce.lib.chain
 
org.apache.hadoop.mapreduce.lib.db - package org.apache.hadoop.mapreduce.lib.db
 
org.apache.hadoop.mapreduce.lib.fieldsel - package org.apache.hadoop.mapreduce.lib.fieldsel
 
org.apache.hadoop.mapreduce.lib.input - package org.apache.hadoop.mapreduce.lib.input
 
org.apache.hadoop.mapreduce.lib.jobcontrol - package org.apache.hadoop.mapreduce.lib.jobcontrol
 
org.apache.hadoop.mapreduce.lib.join - package org.apache.hadoop.mapreduce.lib.join
 
org.apache.hadoop.mapreduce.lib.map - package org.apache.hadoop.mapreduce.lib.map
 
org.apache.hadoop.mapreduce.lib.output - package org.apache.hadoop.mapreduce.lib.output
 
org.apache.hadoop.mapreduce.lib.partition - package org.apache.hadoop.mapreduce.lib.partition
 
org.apache.hadoop.mapreduce.lib.reduce - package org.apache.hadoop.mapreduce.lib.reduce
 
org.apache.hadoop.mapreduce.security - package org.apache.hadoop.mapreduce.security
 
org.apache.hadoop.mapreduce.server.jobtracker - package org.apache.hadoop.mapreduce.server.jobtracker
 
org.apache.hadoop.mapreduce.server.tasktracker - package org.apache.hadoop.mapreduce.server.tasktracker
 
org.apache.hadoop.mapreduce.tools - package org.apache.hadoop.mapreduce.tools
 
org.apache.hadoop.mapreduce.v2 - package org.apache.hadoop.mapreduce.v2
 
org.apache.hadoop.mapreduce.v2.app.webapp.dao - package org.apache.hadoop.mapreduce.v2.app.webapp.dao
 
org.apache.hadoop.mapreduce.v2.hs.webapp.dao - package org.apache.hadoop.mapreduce.v2.hs.webapp.dao
 
org.apache.hadoop.mapreduce.v2.security - package org.apache.hadoop.mapreduce.v2.security
 
org.apache.hadoop.metrics - package org.apache.hadoop.metrics
This package defines an API for reporting performance metric information.
org.apache.hadoop.metrics.file - package org.apache.hadoop.metrics.file
Implementation of the metrics package that writes the metrics to a file.
org.apache.hadoop.metrics.ganglia - package org.apache.hadoop.metrics.ganglia
Implementation of the metrics package that sends metric data to Ganglia.
org.apache.hadoop.metrics.spi - package org.apache.hadoop.metrics.spi
The Service Provider Interface for the Metrics API.
org.apache.hadoop.metrics2 - package org.apache.hadoop.metrics2
Metrics 2.0
org.apache.hadoop.metrics2.annotation - package org.apache.hadoop.metrics2.annotation
Annotation interfaces for metrics instrumentation
org.apache.hadoop.metrics2.filter - package org.apache.hadoop.metrics2.filter
Builtin metrics filters (to be used in metrics config files)
org.apache.hadoop.metrics2.lib - package org.apache.hadoop.metrics2.lib
A collection of library classes for implementing metrics sources
org.apache.hadoop.metrics2.sink - package org.apache.hadoop.metrics2.sink
Builtin metrics sinks
org.apache.hadoop.metrics2.sink.ganglia - package org.apache.hadoop.metrics2.sink.ganglia
 
org.apache.hadoop.metrics2.source - package org.apache.hadoop.metrics2.source
 
org.apache.hadoop.metrics2.util - package org.apache.hadoop.metrics2.util
General helpers for implementing source and sinks
org.apache.hadoop.net - package org.apache.hadoop.net
Network-related classes.
org.apache.hadoop.record - package org.apache.hadoop.record
(DEPRECATED) Hadoop record I/O contains classes and a record description language translator for simplifying serialization and deserialization of records in a language-neutral manner.
org.apache.hadoop.record.compiler - package org.apache.hadoop.record.compiler
(DEPRECATED) This package contains classes needed for code generation from the hadoop record compiler.
org.apache.hadoop.record.compiler.ant - package org.apache.hadoop.record.compiler.ant
 
org.apache.hadoop.record.compiler.generated - package org.apache.hadoop.record.compiler.generated
(DEPRECATED) This package contains code generated by JavaCC from the Hadoop record syntax file rcc.jj.
org.apache.hadoop.record.meta - package org.apache.hadoop.record.meta
 
org.apache.hadoop.security - package org.apache.hadoop.security
 
org.apache.hadoop.security.authentication.client - package org.apache.hadoop.security.authentication.client
 
org.apache.hadoop.security.authentication.examples - package org.apache.hadoop.security.authentication.examples
 
org.apache.hadoop.security.authentication.server - package org.apache.hadoop.security.authentication.server
 
org.apache.hadoop.security.authentication.util - package org.apache.hadoop.security.authentication.util
 
org.apache.hadoop.streaming - package org.apache.hadoop.streaming
Hadoop Streaming is a utility which allows users to create and run Map-Reduce jobs with any executables (e.g.
org.apache.hadoop.streaming.io - package org.apache.hadoop.streaming.io
 
org.apache.hadoop.tools.mapred - package org.apache.hadoop.tools.mapred
 
org.apache.hadoop.tools.mapred.lib - package org.apache.hadoop.tools.mapred.lib
 
org.apache.hadoop.tools.rumen - package org.apache.hadoop.tools.rumen
Rumen is a data extraction and analysis tool built for Apache Hadoop.
org.apache.hadoop.tools.rumen.anonymization - package org.apache.hadoop.tools.rumen.anonymization
 
org.apache.hadoop.tools.rumen.datatypes - package org.apache.hadoop.tools.rumen.datatypes
 
org.apache.hadoop.tools.rumen.datatypes.util - package org.apache.hadoop.tools.rumen.datatypes.util
 
org.apache.hadoop.tools.rumen.serializers - package org.apache.hadoop.tools.rumen.serializers
 
org.apache.hadoop.tools.rumen.state - package org.apache.hadoop.tools.rumen.state
 
org.apache.hadoop.tools.util - package org.apache.hadoop.tools.util
 
org.apache.hadoop.typedbytes - package org.apache.hadoop.typedbytes
Typed bytes are sequences of bytes in which the first byte is a type code.
org.apache.hadoop.util - package org.apache.hadoop.util
Common utilities.
org.apache.hadoop.util.bloom - package org.apache.hadoop.util.bloom
 
org.apache.hadoop.util.hash - package org.apache.hadoop.util.hash
 
org.apache.hadoop.yarn - package org.apache.hadoop.yarn
 
org.apache.hadoop.yarn.api - package org.apache.hadoop.yarn.api
 
org.apache.hadoop.yarn.api.protocolrecords - package org.apache.hadoop.yarn.api.protocolrecords
 
org.apache.hadoop.yarn.api.records - package org.apache.hadoop.yarn.api.records
 
org.apache.hadoop.yarn.applications.distributedshell - package org.apache.hadoop.yarn.applications.distributedshell
 
org.apache.hadoop.yarn.client - package org.apache.hadoop.yarn.client
 
org.apache.hadoop.yarn.client.cli - package org.apache.hadoop.yarn.client.cli
 
org.apache.hadoop.yarn.logaggregation - package org.apache.hadoop.yarn.logaggregation
 
org.hadoop.yarn.client - package org.hadoop.yarn.client
 
out - Variable in class org.apache.hadoop.io.compress.CompressionOutputStream
The output stream to be compressed.
OUTDIR - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
OuterJoinRecordReader<K extends WritableComparable> - Class in org.apache.hadoop.mapred.join
Full outer join.
OuterJoinRecordReader<K extends WritableComparable<?>> - Class in org.apache.hadoop.mapreduce.lib.join
Full outer join.
OUTPUT_FIELD_COUNT_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Number of fields in the Output table
OUTPUT_FIELD_COUNT_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Number of fields in the Output table
OUTPUT_FIELD_NAMES_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Field names in the Output table
OUTPUT_FIELD_NAMES_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Field names in the Output table
OUTPUT_FILTER - Static variable in class org.apache.hadoop.mapreduce.Job
 
OUTPUT_FORMAT - Static variable in class org.apache.hadoop.mapreduce.lib.output.LazyOutputFormat
 
OUTPUT_TABLE_NAME_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Output table name
OUTPUT_TABLE_NAME_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Output table name
OutputCollector<K,V> - Interface in org.apache.hadoop.mapred
Collects the <key, value> pairs output by Mappers and Reducers.
OutputCommitter - Class in org.apache.hadoop.mapred
OutputCommitter describes the commit of task output for a Map-Reduce job.
OutputCommitter() - Constructor for class org.apache.hadoop.mapred.OutputCommitter
 
OutputCommitter - Class in org.apache.hadoop.mapreduce
OutputCommitter describes the commit of task output for a Map-Reduce job.
OutputCommitter() - Constructor for class org.apache.hadoop.mapreduce.OutputCommitter
 
OutputFormat<K,V> - Interface in org.apache.hadoop.mapred
OutputFormat describes the output-specification for a Map-Reduce job.
OutputFormat<K,V> - Class in org.apache.hadoop.mapreduce
OutputFormat describes the output-specification for a Map-Reduce job.
OutputFormat() - Constructor for class org.apache.hadoop.mapreduce.OutputFormat
 
OutputLogFilter - Class in org.apache.hadoop.mapred
This class filters log files from directory given It doesnt accept paths having _logs.
OutputLogFilter() - Constructor for class org.apache.hadoop.mapred.OutputLogFilter
 
OutputRecord - Class in org.apache.hadoop.metrics.spi
Represents a record of metric data to be sent to a metrics system.
OverrideRecordReader<K extends WritableComparable,V extends Writable> - Class in org.apache.hadoop.mapred.join
Prefer the "rightmost" data source for this key.
OverrideRecordReader<K extends WritableComparable<?>,V extends Writable> - Class in org.apache.hadoop.mapreduce.lib.join
Prefer the "rightmost" data source for this key.

P

parent() - Method in class org.apache.hadoop.metrics2.MetricsRecordBuilder
 
ParentNotDirectoryException - Exception in org.apache.hadoop.fs
Indicates that the parent of specified Path is not a directory as expected.
ParentNotDirectoryException() - Constructor for exception org.apache.hadoop.fs.ParentNotDirectoryException
 
ParentNotDirectoryException(String) - Constructor for exception org.apache.hadoop.fs.ParentNotDirectoryException
 
parse(String, int) - Static method in class org.apache.hadoop.metrics.spi.Util
Parses a space and/or comma separated sequence of server specifications of the form hostname or hostname:port.
parse(String, int) - Static method in class org.apache.hadoop.metrics2.util.Servers
Parses a space and/or comma separated sequence of server specifications of the form hostname or hostname:port.
parseAndSetPeriod(String) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
If a period is set in the attribute passed in, override the default with it.
ParseException - Exception in org.apache.hadoop.record.compiler.generated
Deprecated.
Replaced by Avro.
ParseException(Token, int[][], String[]) - Constructor for exception org.apache.hadoop.record.compiler.generated.ParseException
Deprecated.
This constructor is used by the method "generateParseException" in the generated parser.
ParseException() - Constructor for exception org.apache.hadoop.record.compiler.generated.ParseException
Deprecated.
The following constructors are for use by you for whatever purpose you can think of.
ParseException(String) - Constructor for exception org.apache.hadoop.record.compiler.generated.ParseException
Deprecated.
 
parseOutputKeyValueSpec(String, List<Integer>, List<Integer>) - Static method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
Parser - Class in org.apache.hadoop.mapred.join
Very simple shift-reduce parser for join expressions.
Parser() - Constructor for class org.apache.hadoop.mapred.join.Parser
 
Parser - Class in org.apache.hadoop.mapreduce.lib.join
Very simple shift-reduce parser for join expressions.
Parser() - Constructor for class org.apache.hadoop.mapreduce.lib.join.Parser
 
Parser.Node - Class in org.apache.hadoop.mapred.join
 
Parser.Node(String) - Constructor for class org.apache.hadoop.mapred.join.Parser.Node
 
Parser.Node - Class in org.apache.hadoop.mapreduce.lib.join
 
Parser.Node(String) - Constructor for class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
Parser.NodeToken - Class in org.apache.hadoop.mapred.join
 
Parser.NodeToken - Class in org.apache.hadoop.mapreduce.lib.join
 
Parser.NumToken - Class in org.apache.hadoop.mapred.join
 
Parser.NumToken(double) - Constructor for class org.apache.hadoop.mapred.join.Parser.NumToken
 
Parser.NumToken - Class in org.apache.hadoop.mapreduce.lib.join
 
Parser.NumToken(double) - Constructor for class org.apache.hadoop.mapreduce.lib.join.Parser.NumToken
 
Parser.StrToken - Class in org.apache.hadoop.mapred.join
 
Parser.StrToken(Parser.TType, String) - Constructor for class org.apache.hadoop.mapred.join.Parser.StrToken
 
Parser.StrToken - Class in org.apache.hadoop.mapreduce.lib.join
 
Parser.StrToken(Parser.TType, String) - Constructor for class org.apache.hadoop.mapreduce.lib.join.Parser.StrToken
 
Parser.Token - Class in org.apache.hadoop.mapred.join
Tagged-union type for tokens from the join expression.
Parser.Token - Class in org.apache.hadoop.mapreduce.lib.join
Tagged-union type for tokens from the join expression.
Parser.TType - Enum in org.apache.hadoop.mapred.join
 
Parser.TType - Enum in org.apache.hadoop.mapreduce.lib.join
 
PART - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
Partitioner<K2,V2> - Interface in org.apache.hadoop.mapred
Partitions the key space.
PARTITIONER - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
Partitioner<KEY,VALUE> - Class in org.apache.hadoop.mapreduce
Partitions the key space.
Partitioner() - Constructor for class org.apache.hadoop.mapreduce.Partitioner
 
PARTITIONER_OPTIONS - Static variable in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
 
PARTITIONER_PATH - Static variable in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
 
PASSWORD_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
Password to access the database
PASSWORD_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
Password to access the database
Path - Class in org.apache.hadoop.fs
Names a file or directory in a FileSystem.
Path(String, String) - Constructor for class org.apache.hadoop.fs.Path
Resolve a child path against a parent path.
Path(Path, String) - Constructor for class org.apache.hadoop.fs.Path
Resolve a child path against a parent path.
Path(String, Path) - Constructor for class org.apache.hadoop.fs.Path
Resolve a child path against a parent path.
Path(Path, Path) - Constructor for class org.apache.hadoop.fs.Path
Resolve a child path against a parent path.
Path(String) - Constructor for class org.apache.hadoop.fs.Path
Construct a path from a String.
Path(URI) - Constructor for class org.apache.hadoop.fs.Path
Construct a path from a URI
Path(String, String, String) - Constructor for class org.apache.hadoop.fs.Path
Construct a Path from components.
PathFilter - Interface in org.apache.hadoop.fs
 
PATHFILTER_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
pathToFile(Path) - Method in class org.apache.hadoop.fs.LocalFileSystem
Convert a path to a File.
pathToFile(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
Convert a path to a File.
PATTERN - Static variable in class org.apache.hadoop.mapreduce.lib.map.RegexMapper
 
PENDING_DIR_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Name of directory where pending data is placed.
PERIOD_PROPERTY - Static variable in class org.apache.hadoop.metrics.file.FileContext
Deprecated.
 
PORT - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
PositionedReadable - Interface in org.apache.hadoop.fs
Stream that permits positional reading.
PREP - Static variable in class org.apache.hadoop.mapred.JobStatus
 
PRESERVE_COMMANDFILE - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
prevCharIsCR - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
prevCharIsLF - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
primitiveCreate(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable, Options.ChecksumOpt) - Method in class org.apache.hadoop.fs.FileSystem
Deprecated.
primitiveCreate(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable, Options.ChecksumOpt) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
primitiveMkdir(Path, FsPermission) - Method in class org.apache.hadoop.fs.FileSystem
Deprecated.
primitiveMkdir(Path, FsPermission, boolean) - Method in class org.apache.hadoop.fs.FileSystem
Deprecated.
primitiveMkdir(Path, FsPermission) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
primitiveMkdir(Path, FsPermission) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
printGenericCommandUsage(PrintStream) - Static method in class org.apache.hadoop.util.ToolRunner
Prints generic command-line argurments and usage information.
printStatistics() - Static method in class org.apache.hadoop.fs.AbstractFileSystem
Prints statistics for all file systems.
printStatistics() - Static method in class org.apache.hadoop.fs.FileContext
Prints the statistics to standard output.
printStatistics() - Static method in class org.apache.hadoop.fs.FileSystem
Print all statistics for all file systems
printThreadInfo(PrintWriter, String) - Static method in class org.apache.hadoop.util.ReflectionUtils
Print all of the thread's information and stack traces.
processDeleteOnExit() - Method in class org.apache.hadoop.fs.FileSystem
Delete all files that were marked as delete-on-exit.
progress - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
progress - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
progress() - Method in interface org.apache.hadoop.util.Progressable
Report progress to the Hadoop framework.
PROGRESS_MONITOR_POLL_INTERVAL_KEY - Static variable in class org.apache.hadoop.mapreduce.Job
Key in mapred-*.xml that sets progMonitorPollIntervalMillis
Progressable - Interface in org.apache.hadoop.util
A facility for reporting progress.
PureJavaCrc32 - Class in org.apache.hadoop.util
A pure-java implementation of the CRC32 checksum that uses the same polynomial as the built-in native CRC32.
PureJavaCrc32() - Constructor for class org.apache.hadoop.util.PureJavaCrc32
Create a new PureJavaCrc32 object.
PureJavaCrc32C - Class in org.apache.hadoop.util
A pure-java implementation of the CRC32 checksum that uses the CRC32-C polynomial, the same polynomial used by iSCSI and implemented on many Intel chipsets supporting SSE4.2.
PureJavaCrc32C() - Constructor for class org.apache.hadoop.util.PureJavaCrc32C
Create a new PureJavaCrc32 object.
put(Writable, Writable) - Method in class org.apache.hadoop.io.MapWritable
put(WritableComparable, Writable) - Method in class org.apache.hadoop.io.SortedMapWritable
putAll(Map<? extends Writable, ? extends Writable>) - Method in class org.apache.hadoop.io.MapWritable
putAll(Map<? extends WritableComparable, ? extends Writable>) - Method in class org.apache.hadoop.io.SortedMapWritable
putMetrics(MetricsRecord) - Method in interface org.apache.hadoop.metrics2.MetricsSink
Put a metrics record in the sink
putMetrics(MetricsRecord) - Method in class org.apache.hadoop.metrics2.sink.FileSink
 

Q

quarterDigest() - Method in class org.apache.hadoop.io.MD5Hash
Return a 32-bit digest of the MD5.
QueueACL - Enum in org.apache.hadoop.yarn.api.records
QueueACL enumerates the various ACLs for queues.
QueueAclsInfo - Class in org.apache.hadoop.mapreduce
Class to encapsulate Queue ACLs for a particular user.
QueueAclsInfo() - Constructor for class org.apache.hadoop.mapreduce.QueueAclsInfo
Default constructor for QueueAclsInfo.
QueueAclsInfo(String, String[]) - Constructor for class org.apache.hadoop.mapreduce.QueueAclsInfo
Construct a new QueueAclsInfo object using the queue name and the queue operations array
QueueInfo - Class in org.apache.hadoop.mapreduce
Class that contains the information regarding the Job Queues which are maintained by the Hadoop Map/Reduce framework.
QueueInfo() - Constructor for class org.apache.hadoop.mapreduce.QueueInfo
Default constructor for QueueInfo.
QueueInfo(String, String) - Constructor for class org.apache.hadoop.mapreduce.QueueInfo
Construct a new QueueInfo object using the queue name and the scheduling information passed.
QueueInfo(String, String, QueueState, JobStatus[]) - Constructor for class org.apache.hadoop.mapreduce.QueueInfo
 
QueueInfo - Interface in org.apache.hadoop.yarn.api.records
QueueInfo is a report of the runtime information of the queue.
QueueState - Enum in org.apache.hadoop.mapreduce
Enum representing queue state
QueueState - Enum in org.apache.hadoop.yarn.api.records
State of a Queue.
QueueUserACLInfo - Interface in org.apache.hadoop.yarn.api.records
QueueUserACLInfo provides information QueueACL for the given user.

R

RANDOM - Static variable in interface org.apache.hadoop.util.bloom.RemoveScheme
Random selection.
RATIO - Static variable in interface org.apache.hadoop.util.bloom.RemoveScheme
Ratio Selection.
RawComparable - Interface in org.apache.hadoop.io.file.tfile
Interface for objects that can be compared through RawComparator.
RawComparator<T> - Interface in org.apache.hadoop.io
A Comparator that operates directly on byte representations of objects.
RawLocalFileSystem - Class in org.apache.hadoop.fs
Implement the FileSystem API for the raw local filesystem.
RawLocalFileSystem() - Constructor for class org.apache.hadoop.fs.RawLocalFileSystem
 
rawMapping - Variable in class org.apache.hadoop.net.CachedDNSToSwitchMapping
The uncached mapping
RBRACE_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
Rcc - Class in org.apache.hadoop.record.compiler.generated
Deprecated.
Replaced by Avro.
Rcc(InputStream) - Constructor for class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
Rcc(InputStream, String) - Constructor for class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
Rcc(Reader) - Constructor for class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
Rcc(RccTokenManager) - Constructor for class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
RccConstants - Interface in org.apache.hadoop.record.compiler.generated
Deprecated.
Replaced by Avro.
RccTask - Class in org.apache.hadoop.record.compiler.ant
Deprecated.
Replaced by Avro.
RccTask() - Constructor for class org.apache.hadoop.record.compiler.ant.RccTask
Deprecated.
Creates a new instance of RccTask
RccTokenManager - Class in org.apache.hadoop.record.compiler.generated
Deprecated.
Replaced by Avro.
RccTokenManager(SimpleCharStream) - Constructor for class org.apache.hadoop.record.compiler.generated.RccTokenManager
Deprecated.
 
RccTokenManager(SimpleCharStream, int) - Constructor for class org.apache.hadoop.record.compiler.generated.RccTokenManager
Deprecated.
 
read(byte[], int, int) - Method in class org.apache.hadoop.fs.AvroFSInput
 
read(long, byte[], int, int) - Method in class org.apache.hadoop.fs.FSDataInputStream
Read bytes from the given position in the stream to the given buffer.
read(DataInput) - Static method in class org.apache.hadoop.fs.permission.FsPermission
Create and initialize a FsPermission from DataInput.
read(long, byte[], int, int) - Method in interface org.apache.hadoop.fs.PositionedReadable
Read upto the specified number of bytes, from a given position within a file, and return the number of bytes read.
read(byte[], int, int) - Method in class org.apache.hadoop.io.compress.CompressionInputStream
Read bytes from the stream.
read() - Method in class org.apache.hadoop.io.compress.DecompressorStream
 
read(byte[], int, int) - Method in class org.apache.hadoop.io.compress.DecompressorStream
 
read(DataInput) - Static method in class org.apache.hadoop.io.MD5Hash
Constructs, reads and returns an instance.
read(DataInput) - Static method in class org.apache.hadoop.mapred.JobID
Deprecated.
read(DataInput) - Static method in class org.apache.hadoop.mapred.TaskAttemptID
Deprecated.
read(DataInput) - Static method in class org.apache.hadoop.mapred.TaskID
Deprecated.
readBool(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
 
readBool(String) - Method in class org.apache.hadoop.record.CsvRecordInput
Deprecated.
 
readBool(String) - Method in interface org.apache.hadoop.record.RecordInput
Deprecated.
Read a boolean from serialized record.
readBool(String) - Method in class org.apache.hadoop.record.XmlRecordInput
Deprecated.
 
readBuffer(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
 
readBuffer(String) - Method in class org.apache.hadoop.record.CsvRecordInput
Deprecated.
 
readBuffer(String) - Method in interface org.apache.hadoop.record.RecordInput
Deprecated.
Read byte array from serialized record.
readBuffer(String) - Method in class org.apache.hadoop.record.XmlRecordInput
Deprecated.
 
readByte(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
 
readByte(String) - Method in class org.apache.hadoop.record.CsvRecordInput
Deprecated.
 
readByte(String) - Method in interface org.apache.hadoop.record.RecordInput
Deprecated.
Read a byte from serialized record.
readByte(String) - Method in class org.apache.hadoop.record.XmlRecordInput
Deprecated.
 
readChar() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
readCompressedByteArray(DataInput) - Static method in class org.apache.hadoop.io.WritableUtils
 
readCompressedString(DataInput) - Static method in class org.apache.hadoop.io.WritableUtils
 
readCompressedStringArray(DataInput) - Static method in class org.apache.hadoop.io.WritableUtils
 
readDouble(byte[], int) - Static method in class org.apache.hadoop.io.WritableComparator
Parse a double from a byte array.
readDouble(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
 
readDouble(String) - Method in class org.apache.hadoop.record.CsvRecordInput
Deprecated.
 
readDouble(String) - Method in interface org.apache.hadoop.record.RecordInput
Deprecated.
Read a double-precision number from serialized record.
readDouble(byte[], int) - Static method in class org.apache.hadoop.record.Utils
Deprecated.
Parse a double from a byte array.
readDouble(String) - Method in class org.apache.hadoop.record.XmlRecordInput
Deprecated.
 
readEnum(DataInput, Class<T>) - Static method in class org.apache.hadoop.io.WritableUtils
Read an Enum value from DataInput, Enums are read and written using String values.
readFields(DataInput) - Method in class org.apache.hadoop.conf.Configuration
 
readFields(DataInput) - Method in class org.apache.hadoop.fs.BlockLocation
Implement readFields of Writable
readFields(DataInput) - Method in class org.apache.hadoop.fs.ContentSummary
Deserialize the fields of this object from in.
readFields(DataInput) - Method in class org.apache.hadoop.fs.FileStatus
 
readFields(DataInput) - Method in class org.apache.hadoop.fs.FsServerDefaults
 
readFields(DataInput) - Method in class org.apache.hadoop.fs.FsStatus
 
readFields(DataInput) - Method in class org.apache.hadoop.fs.permission.FsPermission
Deserialize the fields of this object from in.
readFields(DataInput) - Method in class org.apache.hadoop.io.AbstractMapWritable
Deserialize the fields of this object from in.
readFields(DataInput) - Method in class org.apache.hadoop.io.ArrayPrimitiveWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.ArrayWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.BooleanWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.BytesWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.ByteWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.CompressedWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.DoubleWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.EnumSetWritable
Deserialize the fields of this object from in.
readFields(DataInput) - Method in class org.apache.hadoop.io.FloatWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.GenericWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.IntWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.LongWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.MapWritable
Deserialize the fields of this object from in.
readFields(DataInput) - Method in class org.apache.hadoop.io.MD5Hash
 
readFields(DataInput) - Method in class org.apache.hadoop.io.NullWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.ObjectWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.ShortWritable
read the short value
readFields(DataInput) - Method in class org.apache.hadoop.io.SortedMapWritable
Deserialize the fields of this object from in.
readFields(DataInput) - Method in class org.apache.hadoop.io.Text
deserialize
readFields(DataInput) - Method in class org.apache.hadoop.io.TwoDArrayWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.VersionedWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.VIntWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.io.VLongWritable
 
readFields(DataInput) - Method in interface org.apache.hadoop.io.Writable
Deserialize the fields of this object from in.
readFields(DataInput) - Method in class org.apache.hadoop.mapred.ClusterStatus
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.FileSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
Deserialize the fields of this object from in.
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.ID
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.JobID
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.JobStatus
 
readFields(ResultSet) - Method in interface org.apache.hadoop.mapreduce.lib.db.DBWritable
Reads the fields of the object from the ResultSet.
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.lib.input.FileSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
Deserialize the fields of this object from in.
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Deserialize the fields of this object from in.
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.QueueAclsInfo
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.QueueInfo
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.TaskID
 
readFields(DataInput) - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
 
readFields(DataInput) - Method in class org.apache.hadoop.record.Record
Deprecated.
 
readFields(DataInput) - Method in class org.apache.hadoop.util.bloom.BloomFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.util.bloom.CountingBloomFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.util.bloom.DynamicBloomFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.util.bloom.RetouchedBloomFilter
 
readFieldsCompressed(DataInput) - Method in class org.apache.hadoop.io.CompressedWritable
Subclasses implement this instead of CompressedWritable.readFields(DataInput).
readFloat(byte[], int) - Static method in class org.apache.hadoop.io.WritableComparator
Parse a float from a byte array.
readFloat(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
 
readFloat(String) - Method in class org.apache.hadoop.record.CsvRecordInput
Deprecated.
 
readFloat(String) - Method in interface org.apache.hadoop.record.RecordInput
Deprecated.
Read a single-precision float from serialized record.
readFloat(byte[], int) - Static method in class org.apache.hadoop.record.Utils
Deprecated.
Parse a float from a byte array.
readFloat(String) - Method in class org.apache.hadoop.record.XmlRecordInput
Deprecated.
 
readFully(long, byte[], int, int) - Method in class org.apache.hadoop.fs.FSDataInputStream
Read bytes from the given position in the stream to the given buffer.
readFully(long, byte[]) - Method in class org.apache.hadoop.fs.FSDataInputStream
readFully(long, byte[], int, int) - Method in interface org.apache.hadoop.fs.PositionedReadable
Read the specified number of bytes, from a given position within a file.
readFully(long, byte[]) - Method in interface org.apache.hadoop.fs.PositionedReadable
Read number of bytes equalt to the length of the buffer, from a given position within a file.
readFully(InputStream, byte[], int, int) - Static method in class org.apache.hadoop.io.IOUtils
Reads len bytes in a loop.
readInt(byte[], int) - Static method in class org.apache.hadoop.io.WritableComparator
Parse an integer from a byte array.
readInt(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
 
readInt(String) - Method in class org.apache.hadoop.record.CsvRecordInput
Deprecated.
 
readInt(String) - Method in interface org.apache.hadoop.record.RecordInput
Deprecated.
Read an integer from serialized record.
readInt(String) - Method in class org.apache.hadoop.record.XmlRecordInput
Deprecated.
 
readLong(byte[], int) - Static method in class org.apache.hadoop.io.WritableComparator
Parse a long from a byte array.
readLong(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
 
readLong(String) - Method in class org.apache.hadoop.record.CsvRecordInput
Deprecated.
 
readLong(String) - Method in interface org.apache.hadoop.record.RecordInput
Deprecated.
Read a long integer from serialized record.
readLong(String) - Method in class org.apache.hadoop.record.XmlRecordInput
Deprecated.
 
readObject(DataInput, Configuration) - Static method in class org.apache.hadoop.io.ObjectWritable
Read a Writable, String, primitive type, or an array of the preceding.
readObject(DataInput, ObjectWritable, Configuration) - Static method in class org.apache.hadoop.io.ObjectWritable
Read a Writable, String, primitive type, or an array of the preceding.
readString(DataInput) - Static method in class org.apache.hadoop.io.file.tfile.Utils
Read a String as a VInt n, followed by n Bytes in Text format.
readString(DataInput) - Static method in class org.apache.hadoop.io.Text
Read a UTF8 encoded string from in
readString(DataInput) - Static method in class org.apache.hadoop.io.WritableUtils
 
readString(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
Deprecated.
 
readString(String) - Method in class org.apache.hadoop.record.CsvRecordInput
Deprecated.
 
readString(String) - Method in interface org.apache.hadoop.record.RecordInput
Deprecated.
Read a UTF-8 encoded string from serialized record.
readString(String) - Method in class org.apache.hadoop.record.XmlRecordInput
Deprecated.
 
readStringArray(DataInput) - Static method in class org.apache.hadoop.io.WritableUtils
 
readStringSafely(DataInput, int) - Static method in class org.apache.hadoop.io.WritableUtils
Read a string, but check it for sanity.
readUnsignedShort(byte[], int) - Static method in class org.apache.hadoop.io.WritableComparator
Parse an unsigned short from a byte array.
readVInt(DataInput) - Static method in class org.apache.hadoop.io.file.tfile.Utils
Decoding the variable-length integer.
readVInt(byte[], int) - Static method in class org.apache.hadoop.io.WritableComparator
Reads a zero-compressed encoded integer from a byte array and returns it.
readVInt(DataInput) - Static method in class org.apache.hadoop.io.WritableUtils
Reads a zero-compressed encoded integer from input stream and returns it.
readVInt(byte[], int) - Static method in class org.apache.hadoop.record.Utils
Deprecated.
Reads a zero-compressed encoded integer from a byte array and returns it.
readVInt(DataInput) - Static method in class org.apache.hadoop.record.Utils
Deprecated.
Reads a zero-compressed encoded integer from a stream and returns it.
readVLong(DataInput) - Static method in class org.apache.hadoop.io.file.tfile.Utils
Decoding the variable-length integer.
readVLong(byte[], int) - Static method in class org.apache.hadoop.io.WritableComparator
Reads a zero-compressed encoded long from a byte array and returns it.
readVLong(DataInput) - Static method in class org.apache.hadoop.io.WritableUtils
Reads a zero-compressed encoded long from input stream and returns it.
readVLong(byte[], int) - Static method in class org.apache.hadoop.record.Utils
Deprecated.
Reads a zero-compressed encoded long from a byte array and returns it.
readVLong(DataInput) - Static method in class org.apache.hadoop.record.Utils
Deprecated.
Reads a zero-compressed encoded long from a stream and return it.
READY - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
 
Record() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
Record - Class in org.apache.hadoop.record
Deprecated.
Replaced by Avro.
Record() - Constructor for class org.apache.hadoop.record.Record
Deprecated.
 
RECORD_INPUT - Static variable in class org.apache.hadoop.record.compiler.Consts
Deprecated.
 
RECORD_OUTPUT - Static variable in class org.apache.hadoop.record.compiler.Consts
Deprecated.
 
RECORD_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
RecordComparator - Class in org.apache.hadoop.record
Deprecated.
Replaced by Avro.
RecordComparator(Class<? extends WritableComparable>) - Constructor for class org.apache.hadoop.record.RecordComparator
Deprecated.
Construct a raw Record comparison implementation.
RecordInput - Interface in org.apache.hadoop.record
Deprecated.
Replaced by Avro.
RecordList() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
RecordOutput - Interface in org.apache.hadoop.record
Deprecated.
Replaced by Avro.
RecordReader<K,V> - Interface in org.apache.hadoop.mapred
RecordReader reads <key, value> pairs from an InputSplit.
RecordReader<KEYIN,VALUEIN> - Class in org.apache.hadoop.mapreduce
The record reader breaks the data into key/value pairs for input to the Mapper.
RecordReader() - Constructor for class org.apache.hadoop.mapreduce.RecordReader
 
RecordTypeInfo - Class in org.apache.hadoop.record.meta
Deprecated.
Replaced by Avro.
RecordTypeInfo() - Constructor for class org.apache.hadoop.record.meta.RecordTypeInfo
Deprecated.
Create an empty RecordTypeInfo object.
RecordTypeInfo(String) - Constructor for class org.apache.hadoop.record.meta.RecordTypeInfo
Deprecated.
Create a RecordTypeInfo object representing a record with the given name
RecordWriter<K,V> - Interface in org.apache.hadoop.mapred
RecordWriter writes the output <key, value> pairs to an output file.
RecordWriter<K,V> - Class in org.apache.hadoop.mapreduce
RecordWriter writes the output <key, value> pairs to an output file.
RecordWriter() - Constructor for class org.apache.hadoop.mapreduce.RecordWriter
 
recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Recover the task output.
recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
This method implements the new interface by calling the old method.
recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
 
recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
Recover the task output.
reduce(Text, Iterator<Text>, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Combines values for a given key.
reduce(Text, Iterator<Text>, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorMapper
Do nothing.
reduce(Text, Iterator<Text>, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorReducer
 
reduce(Object, Iterator, OutputCollector, Reporter) - Method in class org.apache.hadoop.mapred.lib.ChainReducer
Chains the reduce(...) method of the Reducer with the map(...) methods of the Mappers in the chain.
reduce(Text, Iterator<Text>, OutputCollector<Text, Text>, Reporter) - Method in class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
 
reduce(K, Iterator<V>, OutputCollector<K, V>, Reporter) - Method in class org.apache.hadoop.mapred.lib.IdentityReducer
Writes all keys and values directly to output.
reduce(K, Iterator<LongWritable>, OutputCollector<K, LongWritable>, Reporter) - Method in class org.apache.hadoop.mapred.lib.LongSumReducer
 
reduce(K2, Iterator<V2>, OutputCollector<K3, V3>, Reporter) - Method in interface org.apache.hadoop.mapred.Reducer
Reduces values for a given key.
reduce(Text, Iterable<Text>, Reducer<Text, Text, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorCombiner
Combines values for a given key.
reduce(Text, Iterable<Text>, Reducer<Text, Text, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorReducer
 
reduce(Text, Iterable<Text>, Reducer<Text, Text, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionReducer
 
reduce(Key, Iterable<IntWritable>, Reducer<Key, IntWritable, Key, IntWritable>.Context) - Method in class org.apache.hadoop.mapreduce.lib.reduce.IntSumReducer
 
reduce(KEY, Iterable<LongWritable>, Reducer<KEY, LongWritable, KEY, LongWritable>.Context) - Method in class org.apache.hadoop.mapreduce.lib.reduce.LongSumReducer
 
reduce(KEYIN, Iterable<VALUEIN>, Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Reducer
This method is called once for each key.
REDUCE_OUTPUT_KEY_VALUE_SPEC - Static variable in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
ReduceContext<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Interface in org.apache.hadoop.mapreduce
The context passed to the Reducer.
reduceProgress() - Method in class org.apache.hadoop.mapred.JobStatus
 
reduceProgress() - Method in interface org.apache.hadoop.mapred.RunningJob
Get the progress of the job's reduce-tasks, as a float between 0.0 and 1.0.
reduceProgress() - Method in class org.apache.hadoop.mapreduce.Job
Get the progress of the job's reduce-tasks, as a float between 0.0 and 1.0.
Reducer<K2,V2,K3,V3> - Interface in org.apache.hadoop.mapred
Reduces a set of intermediate values which share a key to a smaller set of values.
Reducer<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce
Reduces a set of intermediate values which share a key to a smaller set of values.
Reducer() - Constructor for class org.apache.hadoop.mapreduce.Reducer
 
ReflectionUtils - Class in org.apache.hadoop.util
General reflection utils
ReflectionUtils() - Constructor for class org.apache.hadoop.util.ReflectionUtils
 
RegexFilter - Class in org.apache.hadoop.metrics2.filter
A regex pattern filter for metrics
RegexFilter() - Constructor for class org.apache.hadoop.metrics2.filter.RegexFilter
 
RegexMapper<K> - Class in org.apache.hadoop.mapred.lib
A Mapper that extracts text matching a regular expression.
RegexMapper() - Constructor for class org.apache.hadoop.mapred.lib.RegexMapper
 
RegexMapper<K> - Class in org.apache.hadoop.mapreduce.lib.map
A Mapper that extracts text matching a regular expression.
RegexMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.map.RegexMapper
 
register(String, String, T) - Method in class org.apache.hadoop.metrics2.MetricsSystem
Register a metrics source
register(T) - Method in class org.apache.hadoop.metrics2.MetricsSystem
Register a metrics source (deriving name and description from the object)
register(String, String, T) - Method in class org.apache.hadoop.metrics2.MetricsSystem
Register a metrics sink
register(MetricsSystem.Callback) - Method in class org.apache.hadoop.metrics2.MetricsSystem
Register a callback interface for JMX events
register(String, String, Object) - Static method in class org.apache.hadoop.metrics2.util.MBeans
Register the MBean using our standard MBeanName format "hadoop:service=,name=" Where the and are the supplied parameters
registerApplicationMaster(RegisterApplicationMasterRequest) - Method in interface org.apache.hadoop.yarn.api.AMRMProtocol
The interface used by a new ApplicationMaster to register with the ResourceManager.
RegisterApplicationMasterRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
The request sent by the ApplicationMaster to ResourceManager on registration.
RegisterApplicationMasterResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a new ApplicationMaster on registration.
registerUpdater(Updater) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Registers a callback to be called at time intervals determined by the configuration.
registerUpdater(Updater) - Method in class org.apache.hadoop.metrics.spi.CompositeContext
 
reinit(Configuration) - Method in interface org.apache.hadoop.io.compress.Compressor
Prepare the compressor to be used in a new stream with settings defined in the given Configuration
ReInit(InputStream) - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
ReInit(InputStream, String) - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
ReInit(Reader) - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
ReInit(RccTokenManager) - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
ReInit(SimpleCharStream) - Method in class org.apache.hadoop.record.compiler.generated.RccTokenManager
Deprecated.
 
ReInit(SimpleCharStream, int) - Method in class org.apache.hadoop.record.compiler.generated.RccTokenManager
Deprecated.
 
ReInit(Reader, int, int, int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
ReInit(Reader, int, int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
ReInit(Reader) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
ReInit(InputStream, String, int, int, int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
ReInit(InputStream, int, int, int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
ReInit(InputStream, String) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
ReInit(InputStream) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
ReInit(InputStream, String, int, int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
ReInit(InputStream, int, int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
release(Path) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
Deprecated.
reloadConfiguration() - Method in class org.apache.hadoop.conf.Configuration
Reload configuration from previously added resources.
remove(Object) - Method in class org.apache.hadoop.io.MapWritable
remove(Object) - Method in class org.apache.hadoop.io.SortedMapWritable
remove() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
 
remove(MetricsRecordImpl) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Called by MetricsRecordImpl.remove().
remove() - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
Removes the row, if it exists, in the buffered data table having tags that equal the tags that have been set on this record.
remove(MetricsRecordImpl) - Method in class org.apache.hadoop.metrics.spi.NullContext
Do-nothing version of remove
remove(MetricsRecordImpl) - Method in class org.apache.hadoop.metrics.spi.NullContextWithUpdateThread
Do-nothing version of remove
removeAsk(int) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
removeRelease(int) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
RemoveScheme - Interface in org.apache.hadoop.util.bloom
Defines the different remove scheme for retouched Bloom filters.
removeServiceResponse(String) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.StartContainerResponse
Remove a single auxiliary service from the StartContainerResponse object
removeSuffix(String, String) - Static method in class org.apache.hadoop.io.compress.CompressionCodecFactory
Removes a suffix from a filename, if it has it.
removeTag(String) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
Removes any tag of the specified name.
rename(Path, Path, Options.Rename...) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.rename(Path, Path, Options.Rename...) except that Path f must be for this file system.
rename(Path, Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
Rename files/dirs
rename(Path, Path, Options.Rename...) - Method in class org.apache.hadoop.fs.FileContext
Renames Path src to Path dst
  • rename(Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
    Renames Path src to Path dst.
    rename(Path, Path, Options.Rename...) - Method in class org.apache.hadoop.fs.FileSystem
    Deprecated.
    rename(Path, Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
    Renames Path src to Path dst.
    rename(Path, Path) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
     
    rename(Path, Path) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
     
    rename(Path, Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
     
    rename(Path, Path) - Method in class org.apache.hadoop.fs.s3.S3FileSystem
     
    rename(Path, Path) - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
     
    rename(Path, Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    rename(FileSystem, String, String) - Static method in class org.apache.hadoop.io.MapFile
    Renames an existing map directory.
    renameInternal(Path, Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
    The specification of this method matches that of FileContext.rename(Path, Path, Options.Rename...) except that Path f must be for this file system and NO OVERWRITE is performed.
    renameInternal(Path, Path, boolean) - Method in class org.apache.hadoop.fs.AbstractFileSystem
    The specification of this method matches that of FileContext.rename(Path, Path, Options.Rename...) except that Path f must be for this file system.
    renameInternal(Path, Path, boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    renameInternal(Path, Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    renewDelegationToken(Token<DelegationTokenIdentifier>) - Method in class org.apache.hadoop.mapred.JobClient
    Deprecated.
    Use Token.renew(org.apache.hadoop.conf.Configuration) instead
    renewDelegationToken(Token<DelegationTokenIdentifier>) - Method in class org.apache.hadoop.mapreduce.Cluster
    Deprecated.
    Use Token.renew(org.apache.hadoop.conf.Configuration) instead
    renewDelegationToken(RenewDelegationTokenRequest) - Method in interface org.apache.hadoop.yarn.api.ClientRMProtocol
    Renew an existing delegation token.
    RenewDelegationTokenRequest - Interface in org.apache.hadoop.mapreduce.v2.api.protocolrecords
    The request issued by the client to renew a delegation token from the ResourceManager.
    RenewDelegationTokenRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
    The request issued by the client to renew a delegation token from the ResourceManager.
    RenewDelegationTokenResponse - Interface in org.apache.hadoop.mapreduce.v2.api.protocolrecords
    The response to a renewDelegationToken call to the ResourceManager.
    RenewDelegationTokenResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
    The response to a renewDelegationToken call to the ResourceManager.
    replaceFile(File, File) - Static method in class org.apache.hadoop.fs.FileUtil
    Move the src file to the name specified by target.
    replay(X) - Method in class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
     
    replay(T) - Method in interface org.apache.hadoop.mapreduce.lib.join.ResetableIterator
    Assign last value returned to actual.
    replay(X) - Method in class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
     
    reportChecksumFailure(Path, FSDataInputStream, long, FSDataInputStream, long) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
    Report a checksum error to the file system.
    reportChecksumFailure(Path, FSDataInputStream, long, FSDataInputStream, long) - Method in class org.apache.hadoop.fs.LocalFileSystem
    Moves files to a bad file directory on the same device, so that their storage will not be reused.
    reporter - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
     
    Reporter - Interface in org.apache.hadoop.mapred
    A facility for Map-Reduce applications to report progress and update counters, status information etc.
    requiresLayout() - Method in class org.apache.hadoop.log.metrics.EventCounter
     
    reset() - Method in interface org.apache.hadoop.io.compress.Compressor
    Resets compressor so that a new set of input data can be processed.
    reset() - Method in interface org.apache.hadoop.io.compress.Decompressor
    Resets decompressor and input and output buffers so that a new set of input data can be processed.
    reset() - Method in class org.apache.hadoop.io.compress.DecompressorStream
     
    reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.DoubleValueSum
    reset the aggregator
    reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMax
    reset the aggregator
    reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueMin
    reset the aggregator
    reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.LongValueSum
    reset the aggregator
    reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMax
    reset the aggregator
    reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMin
    reset the aggregator
    reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
    reset the aggregator
    reset() - Method in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregator
    reset the aggregator
    reset() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueHistogram
    reset the aggregator
    reset() - Method in class org.apache.hadoop.mapreduce.lib.join.ArrayListBackedIterator
     
    reset() - Method in interface org.apache.hadoop.mapreduce.lib.join.ResetableIterator
    Set iterator to return to the start of its range.
    reset() - Method in class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
     
    reset() - Method in class org.apache.hadoop.mapreduce.MarkableIterator
     
    reset() - Method in class org.apache.hadoop.record.Buffer
    Deprecated.
    Reset the buffer to 0 size
    reset() - Method in class org.apache.hadoop.util.PureJavaCrc32
    reset() - Method in class org.apache.hadoop.util.PureJavaCrc32C
    ResetableIterator<T extends Writable> - Interface in org.apache.hadoop.mapred.join
    This defines an interface to a stateful Iterator that can replay elements added to it directly.
    ResetableIterator<T extends Writable> - Interface in org.apache.hadoop.mapreduce.lib.join
    This defines an interface to a stateful Iterator that can replay elements added to it directly.
    resetMinMax() - Method in class org.apache.hadoop.metrics2.lib.MutableStat
    Reset the all time min max of the metric
    resetState() - Method in class org.apache.hadoop.io.compress.BlockDecompressorStream
     
    resetState() - Method in class org.apache.hadoop.io.compress.CompressionInputStream
    Reset the decompressor to its initial state and discard any buffered data, as the underlying stream may have been repositioned.
    resetState() - Method in class org.apache.hadoop.io.compress.CompressionOutputStream
    Reset the compression to the initial state.
    resetState() - Method in class org.apache.hadoop.io.compress.CompressorStream
     
    resetState() - Method in class org.apache.hadoop.io.compress.DecompressorStream
     
    resolve(Path) - Method in class org.apache.hadoop.fs.FileContext
    Resolves all symbolic links in the specified path.
    resolve(List<String>) - Method in class org.apache.hadoop.net.CachedDNSToSwitchMapping
     
    resolve(List<String>) - Method in interface org.apache.hadoop.net.DNSToSwitchMapping
    Resolves a list of DNS-names/IP-addresses and returns back a list of switch information (network paths).
    resolveIntermediate(Path) - Method in class org.apache.hadoop.fs.FileContext
    Resolves all symbolic links in the specified path leading up to, but not including the final path component.
    resolvePath(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
    Return the fully-qualified path of path f resolving the path through any internal symlinks or mount point
    resolvePath(Path) - Method in class org.apache.hadoop.fs.FileContext
    Resolve the path following any symlinks or mount points
    resolvePath(Path) - Method in class org.apache.hadoop.fs.FileSystem
    Return the fully-qualified path of path f resolving the path through any symlinks or mount point
    resolvePath(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
     
    resolvePath(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    resolvePath(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    Resource - Class in org.apache.hadoop.yarn.api.records
    Resource models a set of computer resources in the cluster.
    Resource() - Constructor for class org.apache.hadoop.yarn.api.records.Resource
     
    ResourceRequest - Class in org.apache.hadoop.yarn.api.records
    ResourceRequest represents the request made by an application to the ResourceManager to obtain various Container allocations.
    ResourceRequest() - Constructor for class org.apache.hadoop.yarn.api.records.ResourceRequest
     
    resume() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
    resume the suspended thread
    RetouchedBloomFilter - Class in org.apache.hadoop.util.bloom
    Implements a retouched Bloom filter, as defined in the CoNEXT 2006 paper.
    RetouchedBloomFilter() - Constructor for class org.apache.hadoop.util.bloom.RetouchedBloomFilter
    Default constructor - use with readFields
    RetouchedBloomFilter(int, int, int) - Constructor for class org.apache.hadoop.util.bloom.RetouchedBloomFilter
    Constructor
    returnCompressor(Compressor) - Static method in class org.apache.hadoop.io.compress.CodecPool
    Return the Compressor to the pool.
    returnDecompressor(Decompressor) - Static method in class org.apache.hadoop.io.compress.CodecPool
    Return the Decompressor to the pool.
    RIGHT_OFFSET_PROPERTY_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
     
    RIO_PREFIX - Static variable in class org.apache.hadoop.record.compiler.Consts
    Deprecated.
     
    rmAddress - Variable in class org.apache.hadoop.yarn.client.YarnClientImpl
     
    rmAddress - Variable in class org.hadoop.yarn.client.YarnClientImpl
     
    rmClient - Variable in class org.apache.hadoop.yarn.client.YarnClientImpl
     
    rmClient - Variable in class org.hadoop.yarn.client.YarnClientImpl
     
    RMDelegationTokenIdentifier - Class in org.apache.hadoop.yarn.security.client
    Delegation Token Identifier that identifies the delegation tokens from the Resource Manager.
    RMDelegationTokenIdentifier() - Constructor for class org.apache.hadoop.yarn.security.client.RMDelegationTokenIdentifier
     
    RMDelegationTokenIdentifier(Text, Text, Text) - Constructor for class org.apache.hadoop.yarn.security.client.RMDelegationTokenIdentifier
    Create a new delegation token identifier
    rrClass - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
     
    rrClass - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
     
    rrConstructor - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
     
    rrConstructor - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
     
    rrCstrMap - Static variable in class org.apache.hadoop.mapred.join.Parser.Node
     
    rrCstrMap - Static variable in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
     
    RTI_FILTER - Static variable in class org.apache.hadoop.record.compiler.Consts
    Deprecated.
     
    RTI_FILTER_FIELDS - Static variable in class org.apache.hadoop.record.compiler.Consts
    Deprecated.
     
    RTI_VAR - Static variable in class org.apache.hadoop.record.compiler.Consts
    Deprecated.
     
    run(String[]) - Method in class org.apache.hadoop.fs.s3.MigrationTool
     
    run(RecordReader<K1, V1>, OutputCollector<K2, V2>, Reporter) - Method in class org.apache.hadoop.mapred.lib.MultithreadedMapRunner
     
    run(RecordReader<K1, V1>, OutputCollector<K2, V2>, Reporter) - Method in interface org.apache.hadoop.mapred.MapRunnable
    Start mapping input <key, value> pairs.
    run(RecordReader<K1, V1>, OutputCollector<K2, V2>, Reporter) - Method in class org.apache.hadoop.mapred.MapRunner
     
    run(String[]) - Method in class org.apache.hadoop.mapred.pipes.Submitter
     
    run(Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.lib.chain.ChainMapper
     
    run(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.lib.chain.ChainReducer
     
    run() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
    The main loop for the thread.
    run(Mapper<K1, V1, K2, V2>.Context) - Method in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
    Run the application's maps using a thread pool.
    run(String[]) - Method in class org.apache.hadoop.mapreduce.lib.partition.InputSampler
    Driver for InputSampler from the command line.
    run(Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Mapper
    Expert users can override this method for more complete control over the execution of the Mapper.
    run(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Reducer
    Advanced application writers can use the Reducer.run(org.apache.hadoop.mapreduce.Reducer.Context) method to control how the reduce task works.
    run(String[]) - Method in class org.apache.hadoop.mapreduce.tools.CLI
     
    run(String[]) - Method in interface org.apache.hadoop.util.Tool
    Execute the command with the given arguments.
    run(Configuration, Tool, String[]) - Static method in class org.apache.hadoop.util.ToolRunner
    Runs the given Tool by Tool.run(String[]), after parsing with the given generic arguments.
    run(Tool, String[]) - Static method in class org.apache.hadoop.util.ToolRunner
    Runs the Tool with its Configuration.
    run() - Method in class org.apache.hadoop.yarn.applications.distributedshell.ApplicationMaster
    Main run function for the application master
    run() - Method in class org.apache.hadoop.yarn.applications.distributedshell.Client
    Main run function for the client
    runJob(JobConf) - Static method in class org.apache.hadoop.mapred.JobClient
    Utility that submits a job, then polls for progress until the job is complete.
    runJob(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
    Submit a job to the map/reduce cluster.
    RUNNING - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
     
    RUNNING - Static variable in class org.apache.hadoop.mapred.JobStatus
     
    RunningJob - Interface in org.apache.hadoop.mapred
    RunningJob is the user-interface to query for details on a running Map-Reduce job.

    S

    S3Exception - Exception in org.apache.hadoop.fs.s3
    Thrown if there is a problem communicating with Amazon S3.
    S3Exception(Throwable) - Constructor for exception org.apache.hadoop.fs.s3.S3Exception
     
    S3FileSystem - Class in org.apache.hadoop.fs.s3
    A block-based FileSystem backed by Amazon S3.
    S3FileSystem() - Constructor for class org.apache.hadoop.fs.s3.S3FileSystem
     
    S3FileSystem(FileSystemStore) - Constructor for class org.apache.hadoop.fs.s3.S3FileSystem
     
    S3FileSystemException - Exception in org.apache.hadoop.fs.s3
    Thrown when there is a fatal exception while using S3FileSystem.
    S3FileSystemException(String) - Constructor for exception org.apache.hadoop.fs.s3.S3FileSystemException
     
    ScriptBasedMapping - Class in org.apache.hadoop.net
    This class implements the DNSToSwitchMapping interface using a script configured via the CommonConfigurationKeysPublic.NET_TOPOLOGY_SCRIPT_FILE_NAME_KEY option.
    ScriptBasedMapping() - Constructor for class org.apache.hadoop.net.ScriptBasedMapping
    Create an instance with the default configuration.
    ScriptBasedMapping(Configuration) - Constructor for class org.apache.hadoop.net.ScriptBasedMapping
    Create an instance from the given configuration
    seek(long) - Method in class org.apache.hadoop.fs.AvroFSInput
     
    seek(long) - Method in class org.apache.hadoop.fs.FSDataInputStream
    Seek to the given offset.
    seek(long) - Method in interface org.apache.hadoop.fs.Seekable
    Seek to the given offset from the start of the file.
    seek(long) - Method in class org.apache.hadoop.io.compress.CompressionInputStream
    This method is current not supported.
    seek(long) - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
     
    Seekable - Interface in org.apache.hadoop.fs
    Stream that permits seeking.
    seekToNewSource(long) - Method in class org.apache.hadoop.fs.FSDataInputStream
    Seek to the given position on an alternate copy of the data.
    seekToNewSource(long) - Method in interface org.apache.hadoop.fs.Seekable
    Seeks a different copy of the data.
    seekToNewSource(long) - Method in class org.apache.hadoop.io.compress.CompressionInputStream
    This method is current not supported.
    selectiveClearing(Key, short) - Method in class org.apache.hadoop.util.bloom.RetouchedBloomFilter
    Performs the selective clearing for a given key.
    SEMICOLON_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
    Deprecated.
     
    SEPARATOR - Static variable in class org.apache.hadoop.fs.Path
    The directory separator, a slash.
    SEPARATOR - Static variable in class org.apache.hadoop.mapreduce.ID
     
    SEPARATOR_CHAR - Static variable in class org.apache.hadoop.fs.Path
     
    SEPERATOR - Static variable in class org.apache.hadoop.mapreduce.lib.output.TextOutputFormat
     
    SequenceFile - Class in org.apache.hadoop.io
    SequenceFiles are flat files consisting of binary key/value pairs.
    SequenceFileAsBinaryInputFormat - Class in org.apache.hadoop.mapred
    InputFormat reading keys, values from SequenceFiles in binary (raw) format.
    SequenceFileAsBinaryInputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat
     
    SequenceFileAsBinaryInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
    InputFormat reading keys, values from SequenceFiles in binary (raw) format.
    SequenceFileAsBinaryInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat
     
    SequenceFileAsBinaryOutputFormat - Class in org.apache.hadoop.mapred
    An OutputFormat that writes keys, values to SequenceFiles in binary(raw) format
    SequenceFileAsBinaryOutputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
     
    SequenceFileAsBinaryOutputFormat - Class in org.apache.hadoop.mapreduce.lib.output
    An OutputFormat that writes keys, values to SequenceFiles in binary(raw) format
    SequenceFileAsBinaryOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
     
    SequenceFileAsTextInputFormat - Class in org.apache.hadoop.mapred
    This class is similar to SequenceFileInputFormat, except it generates SequenceFileAsTextRecordReader which converts the input keys and values to their String forms by calling toString() method.
    SequenceFileAsTextInputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileAsTextInputFormat
     
    SequenceFileAsTextInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
    This class is similar to SequenceFileInputFormat, except it generates SequenceFileAsTextRecordReader which converts the input keys and values to their String forms by calling toString() method.
    SequenceFileAsTextInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextInputFormat
     
    SequenceFileAsTextRecordReader - Class in org.apache.hadoop.mapred
    This class converts the input keys and values to their String forms by calling toString() method.
    SequenceFileAsTextRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
     
    SequenceFileAsTextRecordReader - Class in org.apache.hadoop.mapreduce.lib.input
    This class converts the input keys and values to their String forms by calling toString() method.
    SequenceFileAsTextRecordReader() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextRecordReader
     
    SequenceFileInputFilter<K,V> - Class in org.apache.hadoop.mapred
    A class that allows a map/red job to work on a sample of sequence files.
    SequenceFileInputFilter() - Constructor for class org.apache.hadoop.mapred.SequenceFileInputFilter
     
    SequenceFileInputFilter<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
    A class that allows a map/red job to work on a sample of sequence files.
    SequenceFileInputFilter() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
     
    SequenceFileInputFormat<K,V> - Class in org.apache.hadoop.mapred
    SequenceFileInputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileInputFormat
     
    SequenceFileInputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
    SequenceFileInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFormat
     
    SequenceFileOutputFormat<K,V> - Class in org.apache.hadoop.mapred
    An OutputFormat that writes SequenceFiles.
    SequenceFileOutputFormat() - Constructor for class org.apache.hadoop.mapred.SequenceFileOutputFormat
     
    SequenceFileOutputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.output
    An OutputFormat that writes SequenceFiles.
    SequenceFileOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.SequenceFileOutputFormat
     
    SequenceFileRecordReader<K,V> - Class in org.apache.hadoop.mapred
    SequenceFileRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.mapred.SequenceFileRecordReader
     
    SequenceFileRecordReader<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
    SequenceFileRecordReader() - Constructor for class org.apache.hadoop.mapreduce.lib.input.SequenceFileRecordReader
     
    serialize(RecordOutput, String) - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
    Deprecated.
    Serialize the type information for a record
    serialize(RecordOutput, String) - Method in class org.apache.hadoop.record.Record
    Deprecated.
    Serialize a record with tag (ususally field name)
    serialize(RecordOutput) - Method in class org.apache.hadoop.record.Record
    Deprecated.
    Serialize a record without a tag
    Servers - Class in org.apache.hadoop.metrics2.util
    Helpers to handle server addresses
    SESSION_TIMEZONE_KEY - Static variable in class org.apache.hadoop.mapreduce.lib.db.OracleDBRecordReader
    Configuration key to set to a timezone string.
    set(String, String) - Method in class org.apache.hadoop.conf.Configuration
    Set the value of the name property.
    set(String, String, String) - Method in class org.apache.hadoop.conf.Configuration
    Set the value of the name property.
    set(Object) - Method in class org.apache.hadoop.io.ArrayPrimitiveWritable
     
    set(Writable[]) - Method in class org.apache.hadoop.io.ArrayWritable
     
    set(boolean) - Method in class org.apache.hadoop.io.BooleanWritable
    Set the value of the BooleanWritable
    set(BytesWritable) - Method in class org.apache.hadoop.io.BytesWritable
    Set the BytesWritable to the contents of the given newData.
    set(byte[], int, int) - Method in class org.apache.hadoop.io.BytesWritable
    Set the value to a copy of the given byte range
    set(byte) - Method in class org.apache.hadoop.io.ByteWritable
    Set the value of this ByteWritable.
    set(double) - Method in class org.apache.hadoop.io.DoubleWritable
     
    set(EnumSet<E>, Class<E>) - Method in class org.apache.hadoop.io.EnumSetWritable
    reset the EnumSetWritable with specified value and elementType.
    set(float) - Method in class org.apache.hadoop.io.FloatWritable
    Set the value of this FloatWritable.
    set(Writable) - Method in class org.apache.hadoop.io.GenericWritable
    Set the instance that is wrapped.
    set(int) - Method in class org.apache.hadoop.io.IntWritable
    Set the value of this IntWritable.
    set(long) - Method in class org.apache.hadoop.io.LongWritable
    Set the value of this LongWritable.
    set(MD5Hash) - Method in class org.apache.hadoop.io.MD5Hash
    Copy the contents of another instance into this instance.
    set(Object) - Method in class org.apache.hadoop.io.ObjectWritable
    Reset the instance.
    set(short) - Method in class org.apache.hadoop.io.ShortWritable
    Set the value of this ShortWritable.
    set(String) - Method in class org.apache.hadoop.io.Text
    Set to contain the contents of a string.
    set(byte[]) - Method in class org.apache.hadoop.io.Text
    Set to a utf8 byte array
    set(Text) - Method in class org.apache.hadoop.io.Text
    copy a text.
    set(byte[], int, int) - Method in class org.apache.hadoop.io.Text
    Set the Text to range of bytes
    set(Writable[][]) - Method in class org.apache.hadoop.io.TwoDArrayWritable
     
    set(int) - Method in class org.apache.hadoop.io.VIntWritable
    Set the value of this VIntWritable.
    set(long) - Method in class org.apache.hadoop.io.VLongWritable
    Set the value of this LongWritable.
    set(int) - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeInt
    Set the value of the metric
    set(long) - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeLong
    Set the value of the metric
    set(byte[]) - Method in class org.apache.hadoop.record.Buffer
    Deprecated.
    Use the specified bytes array as underlying sequence.
    setAggregatorDescriptors(JobConf, Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
     
    setAggregatorDescriptors(Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
     
    setAllocatedContainers(List<Container>) - Method in interface org.apache.hadoop.yarn.api.records.AMResponse
    Set the list of newly allocated Container by the ResourceManager.
    setAMContainerSpec(ContainerLaunchContext) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the ContainerLaunchContext to describe the Container with which the ApplicationMaster is launched.
    setAMResponse(AMResponse) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
     
    setApplicationACLs(Map<ApplicationAccessType, String>) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
    Set the ApplicationACLs for the application.
    setApplicationACLs(Map<ApplicationAccessType, String>) - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Set the ApplicationACLs for the application.
    setApplicationAttemptId(ApplicationAttemptId) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
    Set the ApplicationAttemptId being managed by the ApplicationMaster.
    setApplicationAttemptId(ApplicationAttemptId) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
    Set the ApplicationAttemptId being managed by the ApplicationMaster.
    setApplicationAttemptId(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.api.records.ContainerId
     
    setApplicationId(ApplicationId) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportRequest
    Set the ApplicationId of the application
    setApplicationId(ApplicationId) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse
     
    setApplicationId(ApplicationId) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.KillApplicationRequest
     
    setApplicationId(ApplicationId) - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
     
    setApplicationId(ApplicationId) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setApplicationId(ApplicationId) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the ApplicationId of the submitted application.
    setApplicationList(List<ApplicationReport>) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetAllApplicationsResponse
     
    setApplicationName(String) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the application name.
    setApplicationReport(ApplicationReport) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportResponse
     
    setApplicationResourceUsageReport(ApplicationResourceUsageReport) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
    Store the structure containing the job resources for this application
    setApplications(List<ApplicationReport>) - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
     
    setApplicationSubmissionContext(ApplicationSubmissionContext) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.SubmitApplicationRequest
    Set the ApplicationSubmissionContext for the application.
    setAssignedJobID(JobID) - Method in class org.apache.hadoop.mapred.jobcontrol.Job
    Deprecated.
    setAssignedJobID should not be called. JOBID is set by the framework.
    setAttemptId(int) - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
     
    setAttemptsToStartSkipping(Configuration, int) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
    Set the number of Task attempts AFTER which skip mode will be kicked off.
    setAutoIncrMapperProcCount(Configuration, boolean) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
    Set the flag which if set to true, SkipBadRecords.COUNTER_MAP_PROCESSED_RECORDS is incremented by MapRunner after invoking the map function.
    setAutoIncrReducerProcCount(Configuration, boolean) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
    Set the flag which if set to true, SkipBadRecords.COUNTER_REDUCE_PROCESSED_GROUPS is incremented by framework after invoking the reduce function.
    setAvailableResources(Resource) - Method in interface org.apache.hadoop.yarn.api.records.AMResponse
     
    setBoolean(String, boolean) - Method in class org.apache.hadoop.conf.Configuration
    Set the value of the name property to a boolean.
    setBooleanIfUnset(String, boolean) - Method in class org.apache.hadoop.conf.Configuration
    Set the given property, if it is currently unset.
    setBoundingQuery(Configuration, String) - Static method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
    Set the user-defined bounding query to use with a user-defined query.
    setCacheArchives(URI[]) - Method in class org.apache.hadoop.mapreduce.Job
    Set the given set of archives
    setCacheFiles(URI[]) - Method in class org.apache.hadoop.mapreduce.Job
    Set the given set of files
    setCancelDelegationTokenUponJobCompletion(boolean) - Method in class org.apache.hadoop.mapreduce.Job
    Sets the flag that will allow the JobTracker to cancel the HDFS delegation tokens upon job completion.
    setCancelTokensWhenComplete(boolean) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set to false if tokens should not be canceled when the app finished else false.
    setCapability(Resource) - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
     
    setCapability(Resource) - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
    Set the Resource capability of the request
    setCapacity(int) - Method in class org.apache.hadoop.io.BytesWritable
    Change the capacity of the backing storage.
    setCapacity(int) - Method in class org.apache.hadoop.record.Buffer
    Deprecated.
    Change the capacity of the backing storage.
    setCapacity(float) - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
     
    setChanged() - Method in class org.apache.hadoop.metrics2.lib.MutableMetric
    Set the changed flag in mutable operations
    setChildQueues(List<QueueInfo>) - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
     
    setChildren(List<JobQueueInfo>) - Method in class org.apache.hadoop.mapred.JobQueueInfo
     
    setClass(String, Class<?>, Class<?>) - Method in class org.apache.hadoop.conf.Configuration
    Set the value of the name property to the name of a theClass implementing the given interface xface.
    setClassLoader(ClassLoader) - Method in class org.apache.hadoop.conf.Configuration
    Set the class loader that will be used to load the various objects.
    setCleanupProgress(float) - Method in class org.apache.hadoop.mapred.JobStatus
    Sets the cleanup progress of this job
    setCleanupProgress(float) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Sets the cleanup progress of this job
    setClientToken(String) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setClusterMetrics(YarnClusterMetrics) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetClusterMetricsResponse
     
    setClusterTimestamp(long) - Method in class org.apache.hadoop.yarn.api.records.ApplicationId
     
    setCodecClasses(Configuration, List<Class>) - Static method in class org.apache.hadoop.io.compress.CompressionCodecFactory
    Sets a list of codec classes in the configuration.
    setCombinerClass(Class<? extends Reducer>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the user-defined combiner class used to combine map-outputs before being sent to the reducers.
    setCombinerClass(Class<? extends Reducer>) - Method in class org.apache.hadoop.mapreduce.Job
    Set the combiner class for the job.
    setCommands(List<String>) - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Add the list of commands for launching the container.
    setCompletedContainersStatuses(List<ContainerStatus>) - Method in interface org.apache.hadoop.yarn.api.records.AMResponse
     
    setCompressMapOutput(boolean) - Method in class org.apache.hadoop.mapred.JobConf
    Should the map outputs be compressed before transfer?
    setCompressOutput(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
    Set whether the output of the job is compressed.
    setCompressOutput(Job, boolean) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
    Set whether the output of the job is compressed.
    setConf(Configuration) - Method in interface org.apache.hadoop.conf.Configurable
    Set the configuration to be used by this object.
    setConf(Configuration) - Method in class org.apache.hadoop.conf.Configured
     
    setConf(Configuration) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
     
    setConf(Configuration) - Method in class org.apache.hadoop.io.AbstractMapWritable
     
    setConf(Configuration) - Method in class org.apache.hadoop.io.compress.BZip2Codec
    Set the configuration to be used by this object.
    setConf(Configuration) - Method in class org.apache.hadoop.io.compress.DefaultCodec
     
    setConf(Configuration) - Method in class org.apache.hadoop.io.EnumSetWritable
    Set the configuration to be used by this object.
    setConf(Configuration) - Method in class org.apache.hadoop.io.GenericWritable
     
    setConf(Configuration) - Method in class org.apache.hadoop.io.ObjectWritable
     
    setConf(Configuration) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
    Set the configuration to be used by this object.
    setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
    Set the configuration to be used by this object.
    setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
    Set the configuration to be used by this object.
    setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
     
    setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
     
    setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
     
    setConf(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
    Read in the partition file and build indexing data structures.
    setConf(Configuration) - Method in class org.apache.hadoop.net.AbstractDNSToSwitchMapping
     
    setConf(Configuration) - Method in class org.apache.hadoop.net.ScriptBasedMapping
    Set the configuration to be used by this object.
    setConf(Configuration) - Method in class org.apache.hadoop.net.SocksSocketFactory
     
    setConf(Object, Configuration) - Static method in class org.apache.hadoop.util.ReflectionUtils
    Check and set 'configuration' if necessary.
    setContainerId(ContainerId) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusRequest
    Set the ContainerId of container for which to obtain the ContainerStatus
    setContainerId(ContainerId) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.StopContainerRequest
    Set the ContainerId of the container to be stopped.
    setContainerId(ContainerId) - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Set ContainerId of container to be launched.
    setContainerId(ContainerId) - Method in interface org.apache.hadoop.yarn.api.records.ContainerStatus
     
    setContainerLaunchContext(ContainerLaunchContext) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.StartContainerRequest
    Set the ContainerLaunchContext for the container to be started by the NodeManager
    setContainerStatus(ContainerStatus) - Method in interface org.apache.hadoop.yarn.api.records.Container
     
    setContainerToken(ContainerToken) - Method in interface org.apache.hadoop.yarn.api.records.Container
     
    setContainerTokens(ByteBuffer) - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Set security tokens (if security is enabled).
    setContentionTracing(boolean) - Static method in class org.apache.hadoop.util.ReflectionUtils
     
    setContext(String) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
    Set the metrics context tag
    setContext(String) - Method in class org.apache.hadoop.metrics2.MetricsRecordBuilder
    Set the context tag
    setCorrupt(boolean) - Method in class org.apache.hadoop.fs.BlockLocation
    Set the corrupt flag.
    setCountersEnabled(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.lib.MultipleOutputs
    Enables or disables counters for the named outputs.
    setCountersEnabled(Job, boolean) - Static method in class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
    Enables or disables counters for the named outputs.
    setCurrentCapacity(float) - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
     
    setDebugStream(PrintStream) - Method in class org.apache.hadoop.record.compiler.generated.RccTokenManager
    Deprecated.
     
    setDefaultCompressionType(Configuration, SequenceFile.CompressionType) - Static method in class org.apache.hadoop.io.SequenceFile
    Set the default compression type for sequence files.
    setDefaultUri(Configuration, URI) - Static method in class org.apache.hadoop.fs.FileSystem
    Set the default filesystem URI in a configuration.
    setDefaultUri(Configuration, String) - Static method in class org.apache.hadoop.fs.FileSystem
    Set the default filesystem URI in a configuration.
    setDelegationToken(DelegationToken) - Method in interface org.apache.hadoop.mapreduce.v2.api.protocolrecords.CancelDelegationTokenRequest
     
    setDelegationToken(DelegationToken) - Method in interface org.apache.hadoop.mapreduce.v2.api.protocolrecords.RenewDelegationTokenRequest
     
    setDelegationToken(DelegationToken) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.CancelDelegationTokenRequest
     
    setDelegationToken(DelegationToken) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RenewDelegationTokenRequest
     
    setDestdir(File) - Method in class org.apache.hadoop.record.compiler.ant.RccTask
    Deprecated.
    Sets directory where output files will be generated
    setDiagnostics(String) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setDiagnostics(String) - Method in interface org.apache.hadoop.yarn.api.records.ContainerStatus
     
    setDictionary(byte[], int, int) - Method in interface org.apache.hadoop.io.compress.Compressor
    Sets preset dictionary for compression.
    setDictionary(byte[], int, int) - Method in interface org.apache.hadoop.io.compress.Decompressor
    Sets preset dictionary for compression.
    setDigest(String) - Method in class org.apache.hadoop.io.MD5Hash
    Sets the digest value from a hex string.
    setDisplayName(String) - Method in interface org.apache.hadoop.mapreduce.Counter
    Deprecated.
    (and no-op by default)
    setDisplayName(String) - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
    Set the display name of the group
    setEnd(long) - Method in class org.apache.hadoop.io.compress.SplitCompressionInputStream
     
    setEnum(String, T) - Method in class org.apache.hadoop.conf.Configuration
    Set the value of the name property to the given type.
    setEnvironment(Map<String, String>) - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Add environment variables for the container.
    setEventId(int) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
    set event Id.
    setEventId(int) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
    set event Id.
    setExecutable(JobConf, String) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
    Set the URI for the application's executable.
    setExitStatus(int) - Method in interface org.apache.hadoop.yarn.api.records.ContainerStatus
     
    setFactory(Class, WritableFactory) - Static method in class org.apache.hadoop.io.WritableFactories
    Define a factory for a class.
    setFailonerror(boolean) - Method in class org.apache.hadoop.record.compiler.ant.RccTask
    Deprecated.
    Given multiple files (via fileset), set the error handling behavior
    setFailureInfo(String) - Method in class org.apache.hadoop.mapred.JobStatus
     
    setFailureInfo(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Set diagnostic information.
    SetFile - Class in org.apache.hadoop.io
    A file-based set of keys.
    SetFile() - Constructor for class org.apache.hadoop.io.SetFile
     
    setFile(File) - Method in class org.apache.hadoop.record.compiler.ant.RccTask
    Deprecated.
    Sets the record definition file attribute
    setFile(String) - Method in interface org.apache.hadoop.yarn.api.records.URL
    Set the file of the URL.
    setFilterClass(Configuration, Class) - Static method in class org.apache.hadoop.mapred.SequenceFileInputFilter
    set the filter class
    setFilterClass(Job, Class<?>) - Static method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
    set the filter class
    setFinalApplicationStatus(FinalApplicationStatus) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setFinishTime(long) - Method in class org.apache.hadoop.mapred.JobStatus
    Set the finish time of the job
    setFinishTime(long) - Method in class org.apache.hadoop.mapred.TaskReport
    set finish time of task.
    setFinishTime(long) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Set the finish time of the job
    setFinishTime(long) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setFloat(String, float) - Method in class org.apache.hadoop.conf.Configuration
    Set the value of the name property to a float.
    setFormat(JobConf) - Method in class org.apache.hadoop.mapred.join.CompositeInputFormat
    Interpret a given string as a composite expression.
    setFormat(Configuration) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
    Interpret a given string as a composite expression.
    setGroup(String) - Method in class org.apache.hadoop.fs.FileStatus
    Sets group.
    setGroupingComparatorClass(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapreduce.Job
    Define the comparator that controls which keys are grouped together for a single call to Reducer.reduce(Object, Iterable, org.apache.hadoop.mapreduce.Reducer.Context)
    setHealthReport(String) - Method in interface org.apache.hadoop.yarn.api.records.NodeHealthStatus
     
    setHistoryFile(String) - Method in class org.apache.hadoop.mapred.JobStatus
    Set the job history file url for a completed job
    setHistoryFile(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Set the job history file url for a completed job
    setHistoryFileManager(HistoryFileManager) - Method in interface org.apache.hadoop.mapreduce.v2.hs.HistoryStorage
    Give the Storage a reference to a class that can be used to interact with history files.
    setHost(String) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
    Set the host on which the ApplicationMaster is running.
    setHost(String) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setHost(String) - Method in class org.apache.hadoop.yarn.api.records.NodeId
     
    setHost(String) - Method in interface org.apache.hadoop.yarn.api.records.URL
    Set the host of the URL.
    setHostName(String) - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
    Set host/rack on which the allocation is desired.
    setHosts(String[]) - Method in class org.apache.hadoop.fs.BlockLocation
    Set the hosts hosting this block
    setHttpAddress(String) - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
     
    setID(int) - Method in class org.apache.hadoop.mapred.join.Parser.Node
     
    setID(int) - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
     
    setId(int) - Method in class org.apache.hadoop.yarn.api.records.ApplicationId
     
    setId(ContainerId) - Method in interface org.apache.hadoop.yarn.api.records.Container
     
    setId(int) - Method in class org.apache.hadoop.yarn.api.records.ContainerId
     
    setIdentifier(ByteBuffer) - Method in interface org.apache.hadoop.yarn.api.records.ContainerToken
     
    setIdentifier(ByteBuffer) - Method in interface org.apache.hadoop.yarn.api.records.DelegationToken
     
    setIfUnset(String, String) - Method in class org.apache.hadoop.conf.Configuration
    Sets a property if it is currently unset.
    setIncludeApplications(boolean) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
    Should we get fetch information about active applications?
    setIncludeChildQueues(boolean) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
    Should we fetch information about child queues?
    setInput(byte[], int, int) - Method in interface org.apache.hadoop.io.compress.Compressor
    Sets input data for compression.
    setInput(byte[], int, int) - Method in interface org.apache.hadoop.io.compress.Decompressor
    Sets input data for decompression.
    setInput(JobConf, Class<? extends DBWritable>, String, String, String, String...) - Static method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
    Initializes the map-part of the job with the appropriate input settings.
    setInput(JobConf, Class<? extends DBWritable>, String, String) - Static method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
    Initializes the map-part of the job with the appropriate input settings.
    setInput(Job, Class<? extends DBWritable>, String, String, String, String...) - Static method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
    Note that the "orderBy" column is called the "splitBy" in this version.
    setInput(Job, Class<? extends DBWritable>, String, String) - Static method in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
    setInput() takes a custom query and a separate "bounding query" to use instead of the custom "count query" used by DBInputFormat.
    setInput(Job, Class<? extends DBWritable>, String, String, String, String...) - Static method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
    Initializes the map-part of the job with the appropriate input settings.
    setInput(Job, Class<? extends DBWritable>, String, String) - Static method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
    Initializes the map-part of the job with the appropriate input settings.
    setInputBoundingQuery(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
     
    setInputClass(Class<? extends DBWritable>) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
     
    setInputConditions(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
     
    setInputCountQuery(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
     
    setInputDirRecursive(Job, boolean) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
     
    setInputFieldNames(String...) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
     
    setInputFormat(Class<? extends InputFormat>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the InputFormat implementation for the map-reduce job.
    setInputFormatClass(Class<? extends InputFormat>) - Method in class org.apache.hadoop.mapreduce.Job
    Set the InputFormat for the job.
    setInputOrderBy(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
     
    setInputPathFilter(JobConf, Class<? extends PathFilter>) - Static method in class org.apache.hadoop.mapred.FileInputFormat
    Set a PathFilter to be applied to the input paths for the map-reduce job.
    setInputPathFilter(Job, Class<? extends PathFilter>) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
    Set a PathFilter to be applied to the input paths for the map-reduce job.
    setInputPaths(JobConf, String) - Static method in class org.apache.hadoop.mapred.FileInputFormat
    Sets the given comma separated paths as the list of inputs for the map-reduce job.
    setInputPaths(JobConf, Path...) - Static method in class org.apache.hadoop.mapred.FileInputFormat
    Set the array of Paths as the list of inputs for the map-reduce job.
    setInputPaths(Job, String) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
    Sets the given comma separated paths as the list of inputs for the map-reduce job.
    setInputPaths(Job, Path...) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
    Set the array of Paths as the list of inputs for the map-reduce job.
    setInputQuery(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
     
    setInputTableName(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
     
    setInstance(MetricsSystem) - Static method in enum org.apache.hadoop.metrics2.lib.DefaultMetricsSystem
     
    setInt(String, int) - Method in class org.apache.hadoop.conf.Configuration
    Set the value of the name property to an int.
    setIsJavaMapper(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
    Set whether the Mapper is written in Java.
    setIsJavaRecordReader(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
    Set whether the job is using a Java RecordReader.
    setIsJavaRecordWriter(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
    Set whether the job will use a Java RecordWriter.
    setIsJavaReducer(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
    Set whether the Reducer is written in Java.
    setIsNodeHealthy(boolean) - Method in interface org.apache.hadoop.yarn.api.records.NodeHealthStatus
     
    setJar(String) - Method in class org.apache.hadoop.mapred.JobConf
    Set the user jar for the map-reduce job.
    setJar(String) - Method in class org.apache.hadoop.mapreduce.Job
    Set the job jar
    setJarByClass(Class) - Method in class org.apache.hadoop.mapred.JobConf
    Set the job's jar file by finding an example class location.
    setJarByClass(Class<?>) - Method in class org.apache.hadoop.mapreduce.Job
    Set the Jar by finding where a given class came from.
    setJob(Job) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
    Set the mapreduce job
    setJobACLs(Map<JobACL, AccessControlList>) - Method in class org.apache.hadoop.mapred.JobStatus
     
    setJobACLs(Map<JobACL, AccessControlList>) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Set the job acls.
    setJobConf(JobConf) - Method in class org.apache.hadoop.mapred.jobcontrol.Job
    Set the mapred job conf for this job.
    setJobEndNotificationURI(String) - Method in class org.apache.hadoop.mapred.JobConf
    Set the uri to be invoked in-order to send a notification after the job has completed (success/failure).
    setJobID(String) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
    Set the job ID for this job.
    setJobName(String) - Method in class org.apache.hadoop.mapred.JobConf
    Set the user-specified job name.
    setJobName(String) - Method in class org.apache.hadoop.mapreduce.Job
    Set the user-specified job name.
    setJobName(String) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
    Set the job name for this job.
    setJobPriority(JobPriority) - Method in class org.apache.hadoop.mapred.JobConf
    Set JobPriority for this job.
    setJobPriority(JobPriority) - Method in class org.apache.hadoop.mapred.JobStatus
    Set the priority of the job, defaulting to NORMAL.
    setJobPriority(String) - Method in interface org.apache.hadoop.mapred.RunningJob
    Set the priority of a running job.
    setJobSetupCleanupNeeded(boolean) - Method in class org.apache.hadoop.mapreduce.Job
    Specify whether job-setup and job-cleanup is needed for the job
    setJobState(ControlledJob.State) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
    Set the state for this job.
    setJobStatuses(JobStatus[]) - Method in class org.apache.hadoop.mapred.JobQueueInfo
     
    setJobStatuses(JobStatus[]) - Method in class org.apache.hadoop.mapreduce.QueueInfo
     
    setJobToken(Token<? extends TokenIdentifier>, Credentials) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
    store job token
    setKeepCommandFile(JobConf, boolean) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
    Set whether to keep the command file for debugging
    setKeepFailedTaskFiles(boolean) - Method in class org.apache.hadoop.mapred.JobConf
    Set whether the framework should keep the intermediate files for failed tasks.
    setKeepTaskFilesPattern(String) - Method in class org.apache.hadoop.mapred.JobConf
    Set a regular expression for task names that should be kept.
    setKeyComparator(Class<? extends WritableComparator>) - Method in class org.apache.hadoop.mapred.join.Parser.Node
     
    setKeyComparator(Class<? extends WritableComparator>) - Method in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
     
    setKeyFieldComparatorOptions(String) - Method in class org.apache.hadoop.mapred.JobConf
    Set the KeyFieldBasedComparator options used to compare keys.
    setKeyFieldComparatorOptions(Job, String) - Static method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedComparator
    Set the KeyFieldBasedComparator options used to compare keys.
    setKeyFieldPartitionerOptions(String) - Method in class org.apache.hadoop.mapred.JobConf
    Set the KeyFieldBasedPartitioner options used for Partitioner
    setKeyFieldPartitionerOptions(Job, String) - Method in class org.apache.hadoop.mapreduce.lib.partition.KeyFieldBasedPartitioner
    Set the KeyFieldBasedPartitioner options used for Partitioner
    setKeyValue(Text, Text, byte[], int, int) - Static method in class org.apache.hadoop.mapreduce.lib.input.KeyValueLineRecordReader
     
    setKind(String) - Method in interface org.apache.hadoop.yarn.api.records.ContainerToken
     
    setKind(String) - Method in interface org.apache.hadoop.yarn.api.records.DelegationToken
     
    setLanguage(String) - Method in class org.apache.hadoop.record.compiler.ant.RccTask
    Deprecated.
    Sets the output language option
    setLastHealthReportTime(long) - Method in interface org.apache.hadoop.yarn.api.records.NodeHealthStatus
     
    setLeftOffset(Configuration, int) - Static method in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
    Set the subarray to be used for partitioning to bytes[offset:] in Python syntax.
    setLength(long) - Method in class org.apache.hadoop.fs.BlockLocation
    Set the length of block
    setLocalResources(Map<String, LocalResource>) - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Set LocalResource required by the container.
    setLong(String, long) - Method in class org.apache.hadoop.conf.Configuration
    Set the value of the name property to a long.
    setMapDebugScript(String) - Method in class org.apache.hadoop.mapred.JobConf
    Set the debug script to run when the map tasks fail.
    setMapOutputCompressorClass(Class<? extends CompressionCodec>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the given class as the CompressionCodec for the map outputs.
    setMapOutputKeyClass(Class<?>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the key class for the map output data.
    setMapOutputKeyClass(Class<?>) - Method in class org.apache.hadoop.mapreduce.Job
    Set the key class for the map output data.
    setMapOutputValueClass(Class<?>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the value class for the map output data.
    setMapOutputValueClass(Class<?>) - Method in class org.apache.hadoop.mapreduce.Job
    Set the value class for the map output data.
    setMapperClass(Class<? extends Mapper>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the Mapper class for the job.
    setMapperClass(Class<? extends Mapper>) - Method in class org.apache.hadoop.mapreduce.Job
    Set the Mapper for the job.
    setMapperClass(Job, Class<? extends Mapper<K1, V1, K2, V2>>) - Static method in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
    Set the application's mapper class.
    setMapperMaxSkipRecords(Configuration, long) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
    Set the number of acceptable skip records surrounding the bad record PER bad record in mapper.
    setMapProgress(float) - Method in class org.apache.hadoop.mapred.JobStatus
    Sets the map progress of this job
    setMapProgress(float) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Sets the map progress of this job
    setMapRunnerClass(Class<? extends MapRunnable>) - Method in class org.apache.hadoop.mapred.JobConf
    Expert: Set the MapRunnable class for the job.
    setMapSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapred.JobConf
    Turn speculative execution on or off for this job for map tasks.
    setMapSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapreduce.Job
    Turn speculative execution on or off for this job for map tasks.
    setMaxHistoryAge(long) - Method in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
     
    setMaximumCapacity(float) - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
     
    setMaximumResourceCapability(Resource) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse
     
    setMaximumResourceCapability(Resource) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
     
    setMaxInputSplitSize(Job, long) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
    Set the maximum split size
    setMaxItems(long) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
    Set the limit on the number of unique values
    setMaxMapAttempts(int) - Method in class org.apache.hadoop.mapred.JobConf
    Expert: Set the number of maximum attempts that will be made to run a map task.
    setMaxMapAttempts(int) - Method in class org.apache.hadoop.mapreduce.Job
    Expert: Set the number of maximum attempts that will be made to run a map task.
    setMaxMapTaskFailuresPercent(int) - Method in class org.apache.hadoop.mapred.JobConf
    Expert: Set the maximum percentage of map tasks that can fail without the job being aborted.
    setMaxPhysicalMemoryForTask(long) - Method in class org.apache.hadoop.mapred.JobConf
    Deprecated.
    setMaxReduceAttempts(int) - Method in class org.apache.hadoop.mapred.JobConf
    Expert: Set the number of maximum attempts that will be made to run a reduce task.
    setMaxReduceAttempts(int) - Method in class org.apache.hadoop.mapreduce.Job
    Expert: Set the number of maximum attempts that will be made to run a reduce task.
    setMaxReduceTaskFailuresPercent(int) - Method in class org.apache.hadoop.mapred.JobConf
    Set the maximum percentage of reduce tasks that can fail without the job being aborted.
    setMaxSplitSize(long) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
    Specify the maximum size (in bytes) of each split.
    setMaxTaskFailuresPerTracker(int) - Method in class org.apache.hadoop.mapred.JobConf
    Set the maximum no.
    setMaxVirtualMemoryForTask(long) - Method in class org.apache.hadoop.mapred.JobConf
    setMemory(int) - Method in class org.apache.hadoop.yarn.api.records.Resource
    Set memory of the resource.
    setMemoryForMapTask(long) - Method in class org.apache.hadoop.mapred.JobConf
     
    setMemoryForReduceTask(long) - Method in class org.apache.hadoop.mapred.JobConf
     
    setMessage(String) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
    Set the message for this job.
    setMetric(String, int) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
    Sets the named metric to the specified value.
    setMetric(String, long) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
    Sets the named metric to the specified value.
    setMetric(String, short) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
    Sets the named metric to the specified value.
    setMetric(String, byte) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
    Sets the named metric to the specified value.
    setMetric(String, float) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
    Sets the named metric to the specified value.
    setMiniClusterMode(boolean) - Static method in enum org.apache.hadoop.metrics2.lib.DefaultMetricsSystem
     
    setMinimumResourceCapability(Resource) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse
     
    setMinimumResourceCapability(Resource) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
     
    setMinInputSplitSize(Job, long) - Static method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
    Set the minimum input split size
    setMinSplitSize(long) - Method in class org.apache.hadoop.mapred.FileInputFormat
     
    setMinSplitSizeNode(long) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
    Specify the minimum size (in bytes) of each split per node.
    setMinSplitSizeRack(long) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
    Specify the minimum size (in bytes) of each split per rack.
    setName(String) - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
    Deprecated.
    set the name of the record
    setName(String) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setNames(String[]) - Method in class org.apache.hadoop.fs.BlockLocation
    Set the names (host:port) hosting this block
    setNeededMem(int) - Method in class org.apache.hadoop.mapreduce.JobStatus
     
    setNeededResources(Resource) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
     
    setNextExpirationTime(long) - Method in interface org.apache.hadoop.mapreduce.v2.api.protocolrecords.RenewDelegationTokenResponse
     
    setNextExpirationTime(long) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RenewDelegationTokenResponse
     
    setNodeHealthStatus(NodeHealthStatus) - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
     
    setNodeHttpAddress(String) - Method in interface org.apache.hadoop.yarn.api.records.Container
     
    setNodeId(NodeId) - Method in interface org.apache.hadoop.yarn.api.records.Container
     
    setNodeId(NodeId) - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
     
    setNodeReports(List<NodeReport>) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesResponse
     
    setNumberOfThreads(Job, int) - Static method in class org.apache.hadoop.mapreduce.lib.map.MultithreadedMapper
    Set the number of threads in the pool for running maps.
    setNumClusterNodes(int) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
     
    setNumContainers(int) - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
     
    setNumContainers(int) - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
    Set the number of containers required with the given specifications
    setNumLinesPerSplit(Job, int) - Static method in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
    Set the number of lines per split
    setNumMapTasks(int) - Method in class org.apache.hadoop.mapred.JobConf
    Set the number of map tasks for this job.
    setNumNodeManagers(int) - Method in interface org.apache.hadoop.yarn.api.records.YarnClusterMetrics
     
    setNumReduceTasks(int) - Method in class org.apache.hadoop.mapred.JobConf
    Set the requisite number of reduce tasks for this job.
    setNumReduceTasks(int) - Method in class org.apache.hadoop.mapreduce.Job
    Set the number of reduce tasks for the job.
    setNumReservedContainers(int) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
    Set the number of reserved containers
    setNumReservedSlots(int) - Method in class org.apache.hadoop.mapreduce.JobStatus
     
    setNumTasksToExecutePerJvm(int) - Method in class org.apache.hadoop.mapred.JobConf
    Sets the number of tasks that a spawned task JVM should run before it exits
    setNumUsedContainers(int) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
    Set the number of used containers
    setNumUsedSlots(int) - Method in class org.apache.hadoop.mapreduce.JobStatus
     
    setOffset(long) - Method in class org.apache.hadoop.fs.BlockLocation
    Set the start offset of file associated with this block
    setOffsets(Configuration, int, int) - Static method in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
    Set the subarray to be used for partitioning to bytes[left:(right+1)] in Python syntax.
    setOriginalTrackingUrl(String) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setOutput(JobConf, String, String...) - Static method in class org.apache.hadoop.mapred.lib.db.DBOutputFormat
    Initializes the reduce-part of the job with the appropriate output settings
    setOutput(JobConf, String, int) - Static method in class org.apache.hadoop.mapred.lib.db.DBOutputFormat
    Initializes the reduce-part of the job with the appropriate output settings
    setOutput(Job, String, String...) - Static method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat
    Initializes the reduce-part of the job with the appropriate output settings
    setOutput(Job, String, int) - Static method in class org.apache.hadoop.mapreduce.lib.db.DBOutputFormat
    Initializes the reduce-part of the job with the appropriate output settings
    setOutputCommitter(Class<? extends OutputCommitter>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the OutputCommitter implementation for the map-reduce job.
    setOutputCompressionType(JobConf, SequenceFile.CompressionType) - Static method in class org.apache.hadoop.mapred.SequenceFileOutputFormat
    Set the SequenceFile.CompressionType for the output SequenceFile.
    setOutputCompressionType(Job, SequenceFile.CompressionType) - Static method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileOutputFormat
    Set the SequenceFile.CompressionType for the output SequenceFile.
    setOutputCompressorClass(JobConf, Class<? extends CompressionCodec>) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
    Set the CompressionCodec to be used to compress job outputs.
    setOutputCompressorClass(Job, Class<? extends CompressionCodec>) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
    Set the CompressionCodec to be used to compress job outputs.
    setOutputFieldCount(int) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
     
    setOutputFieldNames(String...) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
     
    setOutputFormat(Class<? extends OutputFormat>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the OutputFormat implementation for the map-reduce job.
    setOutputFormatClass(JobConf, Class<? extends OutputFormat>) - Static method in class org.apache.hadoop.mapred.lib.LazyOutputFormat
    Set the underlying output format for LazyOutputFormat.
    setOutputFormatClass(Class<? extends OutputFormat>) - Method in class org.apache.hadoop.mapreduce.Job
    Set the OutputFormat for the job.
    setOutputFormatClass(Job, Class<? extends OutputFormat>) - Static method in class org.apache.hadoop.mapreduce.lib.output.LazyOutputFormat
    Set the underlying output format for LazyOutputFormat.
    setOutputKeyClass(Class<?>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the key class for the job output data.
    setOutputKeyClass(Class<?>) - Method in class org.apache.hadoop.mapreduce.Job
    Set the key class for the job output data.
    setOutputKeyComparatorClass(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the RawComparator comparator used to compare keys.
    setOutputName(JobContext, String) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
    Set the base output name for output file to be created.
    setOutputPath(JobConf, Path) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
    Set the Path of the output directory for the map-reduce job.
    setOutputPath(Job, Path) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
    Set the Path of the output directory for the map-reduce job.
    setOutputTableName(String) - Method in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
     
    setOutputValueClass(Class<?>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the value class for job outputs.
    setOutputValueClass(Class<?>) - Method in class org.apache.hadoop.mapreduce.Job
    Set the value class for job outputs.
    setOutputValueGroupingComparator(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the user defined RawComparator comparator for grouping keys in the input to the reduce.
    setOwner(Path, String, String) - Method in class org.apache.hadoop.fs.AbstractFileSystem
    The specification of this method matches that of FileContext.setOwner(Path, String, String) except that Path f must be for this file system.
    setOwner(Path, String, String) - Method in class org.apache.hadoop.fs.FileContext
    Set owner of a path (i.e.
    setOwner(String) - Method in class org.apache.hadoop.fs.FileStatus
    Sets owner.
    setOwner(Path, String, String) - Method in class org.apache.hadoop.fs.FileSystem
    Set owner of a path (i.e.
    setOwner(Path, String, String) - Method in class org.apache.hadoop.fs.FilterFileSystem
    Set owner of a path (i.e.
    setOwner(Path, String, String) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
    Use the command chown to set owner.
    setOwner(Path, String, String) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    setOwner(Path, String, String) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    setPartitionerClass(Class<? extends Partitioner>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the Partitioner class used to partition Mapper-outputs to be sent to the Reducers.
    setPartitionerClass(Class<? extends Partitioner>) - Method in class org.apache.hadoop.mapreduce.Job
    Set the Partitioner for the job.
    setPartitionFile(Configuration, Path) - Static method in class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
    Set the path to the SequenceFile storing the sorted partition keyset.
    setPassword(ByteBuffer) - Method in interface org.apache.hadoop.yarn.api.records.ContainerToken
     
    setPassword(ByteBuffer) - Method in interface org.apache.hadoop.yarn.api.records.DelegationToken
     
    setPath(Path) - Method in class org.apache.hadoop.fs.FileStatus
     
    setPattern(String, Pattern) - Method in class org.apache.hadoop.conf.Configuration
    Set the given property to Pattern.
    setPattern(String) - Method in interface org.apache.hadoop.yarn.api.records.LocalResource
    Set the pattern that should be used to extract entries from the archive (only used when type is PATTERN).
    setPeriod(int) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
    Sets the timer period
    setPermission(Path, FsPermission) - Method in class org.apache.hadoop.fs.AbstractFileSystem
    The specification of this method matches that of FileContext.setPermission(Path, FsPermission) except that Path f must be for this file system.
    setPermission(Path, FsPermission) - Method in class org.apache.hadoop.fs.FileContext
    Set permission of a path.
    setPermission(FsPermission) - Method in class org.apache.hadoop.fs.FileStatus
    Sets permission.
    setPermission(Path, FsPermission) - Method in class org.apache.hadoop.fs.FileSystem
    Set permission of a path.
    setPermission(Path, FsPermission) - Method in class org.apache.hadoop.fs.FilterFileSystem
    Set permission of a path.
    setPermission(Path, FsPermission) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
    Use the command chmod to set permission.
    setPermission(Path, FsPermission) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    setPermission(Path, FsPermission) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    setPort(int) - Method in class org.apache.hadoop.yarn.api.records.NodeId
     
    setPort(int) - Method in interface org.apache.hadoop.yarn.api.records.URL
    Set the port of the URL
    setPriority(JobPriority) - Method in class org.apache.hadoop.mapreduce.Job
    Set the priority of a running job.
    setPriority(JobPriority) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Set the priority of the job, defaulting to NORMAL.
    setPriority(Priority) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the Priority of the application.
    setPriority(Priority) - Method in interface org.apache.hadoop.yarn.api.records.Container
     
    setPriority(Priority) - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
    Set the Priority of the request
    setProfileEnabled(boolean) - Method in class org.apache.hadoop.mapred.JobConf
    Set whether the system should collect profiler information for some of the tasks in this job? The information is stored in the user log directory.
    setProfileEnabled(boolean) - Method in class org.apache.hadoop.mapreduce.Job
    Set whether the system should collect profiler information for some of the tasks in this job? The information is stored in the user log directory.
    setProfileParams(String) - Method in class org.apache.hadoop.mapred.JobConf
    Set the profiler configuration arguments.
    setProfileParams(String) - Method in class org.apache.hadoop.mapreduce.Job
    Set the profiler configuration arguments.
    setProfileTaskRange(boolean, String) - Method in class org.apache.hadoop.mapred.JobConf
    Set the ranges of maps or reduces to profile.
    setProfileTaskRange(boolean, String) - Method in class org.apache.hadoop.mapreduce.Job
    Set the ranges of maps or reduces to profile.
    setProgress(float) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
    Set the current progress of application
    setProperties(Properties) - Method in class org.apache.hadoop.mapred.JobQueueInfo
     
    setProperties(Properties) - Method in class org.apache.hadoop.mapreduce.QueueInfo
     
    setQueue(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Set queue name
    setQueue(String) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setQueue(String) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the queue to which the application is being submitted
    setQueueChildren(List<QueueInfo>) - Method in class org.apache.hadoop.mapreduce.QueueInfo
     
    setQueueInfo(QueueInfo) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoResponse
     
    setQueueName(String) - Method in class org.apache.hadoop.mapred.JobConf
    Set the name of the queue to which this job should be submitted.
    setQueueName(String) - Method in class org.apache.hadoop.mapred.JobQueueInfo
    Set the queue name of the JobQueueInfo
    setQueueName(String) - Method in class org.apache.hadoop.mapreduce.QueueAclsInfo
     
    setQueueName(String) - Method in class org.apache.hadoop.mapreduce.QueueInfo
    Set the queue name of the JobQueueInfo
    setQueueName(String) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
    Set the queue name for which to get queue information
    setQueueName(String) - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
     
    setQueueName(String) - Method in interface org.apache.hadoop.yarn.api.records.QueueUserACLInfo
     
    setQueueState(String) - Method in class org.apache.hadoop.mapred.JobQueueInfo
    Set the state of the queue
    setQueueState(QueueState) - Method in interface org.apache.hadoop.yarn.api.records.QueueInfo
     
    setQuietMode(boolean) - Method in class org.apache.hadoop.conf.Configuration
    Set the quietness-mode.
    setRackName(String) - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
     
    setReboot(boolean) - Method in interface org.apache.hadoop.yarn.api.records.AMResponse
     
    setRecursive(boolean) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
    Should we fetch information on the entire child queue hierarchy?
    setReduceDebugScript(String) - Method in class org.apache.hadoop.mapred.JobConf
    Set the debug script to run when the reduce tasks fail.
    setReduceProgress(float) - Method in class org.apache.hadoop.mapred.JobStatus
    Sets the reduce progress of this Job
    setReduceProgress(float) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Sets the reduce progress of this Job
    setReducer(JobConf, Class<? extends Reducer<K1, V1, K2, V2>>, Class<? extends K1>, Class<? extends V1>, Class<? extends K2>, Class<? extends V2>, boolean, JobConf) - Static method in class org.apache.hadoop.mapred.lib.ChainReducer
    Sets the Reducer class to the chain job's JobConf.
    setReducer(Job, Class<? extends Reducer>, Class<?>, Class<?>, Class<?>, Class<?>, Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.chain.ChainReducer
    Sets the Reducer class to the chain job.
    setReducerClass(Class<? extends Reducer>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the Reducer class for the job.
    setReducerClass(Class<? extends Reducer>) - Method in class org.apache.hadoop.mapreduce.Job
    Set the Reducer for the job.
    setReducerMaxSkipGroups(Configuration, long) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
    Set the number of acceptable skip groups surrounding the bad group PER bad group in reducer.
    setReduceSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapred.JobConf
    Turn speculative execution on or off for this job for reduce tasks.
    setReduceSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapreduce.Job
    Turn speculative execution on or off for this job for reduce tasks.
    setRenewer(String) - Method in interface org.apache.hadoop.mapreduce.v2.api.protocolrecords.GetDelegationTokenRequest
     
    setRenewer(String) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenRequest
     
    setReplication(Path, short) - Method in class org.apache.hadoop.fs.AbstractFileSystem
    The specification of this method matches that of FileContext.setReplication(Path, short) except that Path f must be for this file system.
    setReplication(Path, short) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
    Set replication for an existing file.
    setReplication(Path, short) - Method in class org.apache.hadoop.fs.FileContext
    Set replication for an existing file.
    setReplication(Path, short) - Method in class org.apache.hadoop.fs.FileSystem
    Set replication for an existing file.
    setReplication(Path, short) - Method in class org.apache.hadoop.fs.FilterFileSystem
    Set replication for an existing file.
    setReplication(Path, short) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
     
    setReplication(Path, short) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    setReplication(Path, short) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    setReservedMem(int) - Method in class org.apache.hadoop.mapreduce.JobStatus
     
    setReservedResources(Resource) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
     
    setResource(Resource) - Method in interface org.apache.hadoop.yarn.api.records.Container
     
    setResource(Resource) - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Set the Resource allocated to the container by the ResourceManager.
    setResource(URL) - Method in interface org.apache.hadoop.yarn.api.records.LocalResource
    Set location of the resource to be localized.
    setResponseId(int) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
    Set the response id used to track duplicate responses.
    setResponseId(int) - Method in interface org.apache.hadoop.yarn.api.records.AMResponse
     
    setRetired() - Method in class org.apache.hadoop.mapred.JobStatus
    Set the job retire flag to true.
    setRetired() - Method in class org.apache.hadoop.mapreduce.JobStatus
    Set the job retire flag to true.
    setRightOffset(Configuration, int) - Static method in class org.apache.hadoop.mapreduce.lib.partition.BinaryPartitioner
    Set the subarray to be used for partitioning to bytes[:(offset+1)] in Python syntax.
    setRMDelegationToken(DelegationToken) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenResponse
     
    setRpcPort(int) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
    Set the RPC port on which the ApplicationMaster is responding.
    setRpcPort(int) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setRunningTaskAttempts(Collection<TaskAttemptID>) - Method in class org.apache.hadoop.mapred.TaskReport
    set running attempt(s) of the task.
    setRunState(int) - Method in class org.apache.hadoop.mapred.JobStatus
    Change the current run state of the job.
    setSchedulingInfo(String) - Method in class org.apache.hadoop.mapred.JobQueueInfo
    Set the scheduling information associated to particular job queue
    setSchedulingInfo(String) - Method in class org.apache.hadoop.mapred.JobStatus
    Used to set the scheduling information associated to a particular Job.
    setSchedulingInfo(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Used to set the scheduling information associated to a particular Job.
    setSchedulingInfo(String) - Method in class org.apache.hadoop.mapreduce.QueueInfo
    Set the scheduling information associated to particular job queue
    setScheme(String) - Method in interface org.apache.hadoop.yarn.api.records.URL
    Set the scheme of the URL
    setSequenceFileOutputKeyClass(JobConf, Class<?>) - Static method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
    Set the key class for the SequenceFile
    setSequenceFileOutputKeyClass(Job, Class<?>) - Static method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
    Set the key class for the SequenceFile
    setSequenceFileOutputValueClass(JobConf, Class<?>) - Static method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
    Set the value class for the SequenceFile
    setSequenceFileOutputValueClass(Job, Class<?>) - Static method in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
    Set the value class for the SequenceFile
    setService(String) - Method in interface org.apache.hadoop.yarn.api.records.ContainerToken
     
    setService(String) - Method in interface org.apache.hadoop.yarn.api.records.DelegationToken
     
    setServiceData(Map<String, ByteBuffer>) - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Set application-specific binary service data.
    setServiceResponse(String, ByteBuffer) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.StartContainerResponse
    Add to the list of auxiliary services which have been started on the NodeManager.
    setSessionId(String) - Method in class org.apache.hadoop.mapred.JobConf
    Deprecated.
    setSessionTimeZone(Configuration, Connection) - Static method in class org.apache.hadoop.mapreduce.lib.db.OracleDBRecordReader
    Set session time zone
    setSetupProgress(float) - Method in class org.apache.hadoop.mapred.JobStatus
    Sets the setup progress of this job
    setSetupProgress(float) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Sets the setup progress of this job
    setShuffleSecretKey(byte[], Credentials) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
     
    setSize(int) - Method in class org.apache.hadoop.io.BytesWritable
    Change the size of the buffer.
    setSize(long) - Method in interface org.apache.hadoop.yarn.api.records.LocalResource
    Set the size of the resource to be localized.
    setSkipOutputPath(JobConf, Path) - Static method in class org.apache.hadoop.mapred.SkipBadRecords
    Set the directory to which skipped records are written.
    setSocketAddr(String, InetSocketAddress) - Method in class org.apache.hadoop.conf.Configuration
    Set the socket address for the name property as a host:port.
    setSortComparatorClass(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapreduce.Job
    Define the comparator that controls how the keys are sorted before they are passed to the Reducer.
    setSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapred.JobConf
    Turn speculative execution on or off for this job.
    setSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapreduce.Job
    Turn speculative execution on or off for this job.
    setStart(long) - Method in class org.apache.hadoop.io.compress.SplitCompressionInputStream
     
    setStartTime(long) - Method in class org.apache.hadoop.mapred.JobStatus
    Set the start time of the job
    setStartTime(long) - Method in class org.apache.hadoop.mapred.TaskReport
    set start time of the task.
    setStartTime(long) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Set the start time of the job
    setStartTime(long) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setState(JobStatus.State) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Change the current run state of the job.
    setState(QueueState) - Method in class org.apache.hadoop.mapreduce.QueueInfo
    Set the state of the queue
    setState(ContainerState) - Method in interface org.apache.hadoop.yarn.api.records.Container
     
    setState(ContainerState) - Method in interface org.apache.hadoop.yarn.api.records.ContainerStatus
     
    setStatement(PreparedStatement) - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
     
    setStatus(String) - Method in interface org.apache.hadoop.mapred.Reporter
    Set the status description for the task.
    setStatus(String) - Method in interface org.apache.hadoop.mapreduce.TaskAttemptContext
    Set the current status of the task to the given string.
    setStatus(ContainerStatus) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusResponse
     
    setStrings(String, String...) - Method in class org.apache.hadoop.conf.Configuration
    Set the array of string values for the name property as as comma delimited values.
    setSuccessfulAttempt(TaskAttemptID) - Method in class org.apache.hadoop.mapred.TaskReport
    set successful attempt ID of the task.
    setSymlink(Path) - Method in class org.apache.hadoop.fs.FileStatus
     
    setTabSize(int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    setTag(String, String) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
    Sets the named tag to the specified value.
    setTag(String, int) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
    Sets the named tag to the specified value.
    setTag(String, long) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
    Sets the named tag to the specified value.
    setTag(String, short) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
    Sets the named tag to the specified value.
    setTag(String, byte) - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
    Sets the named tag to the specified value.
    setTaskAttemptId(TaskAttemptID) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
    Sets task id.
    setTaskAttemptId(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
    Sets task id.
    setTaskId(String) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
    setTaskOutputFilter(JobClient.TaskStatusFilter) - Method in class org.apache.hadoop.mapred.JobClient
    Deprecated.
    setTaskOutputFilter(JobConf, JobClient.TaskStatusFilter) - Static method in class org.apache.hadoop.mapred.JobClient
    Modify the JobConf to set the task output filter.
    setTaskOutputFilter(Configuration, Job.TaskStatusFilter) - Static method in class org.apache.hadoop.mapreduce.Job
    Modify the Configuration to set the task output filter.
    setTaskRunTime(int) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
    Set the task completion time
    setTaskRunTime(int) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
    Set the task completion time
    setTaskStatus(TaskCompletionEvent.Status) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
    Set task status.
    setTaskStatus(TaskCompletionEvent.Status) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
    Set task status.
    setTaskTrackerHttp(String) - Method in class org.apache.hadoop.mapred.TaskCompletionEvent
    Set task tracker http location.
    setTaskTrackerHttp(String) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
    Set task tracker http location.
    setTimes(Path, long, long) - Method in class org.apache.hadoop.fs.AbstractFileSystem
    The specification of this method matches that of FileContext.setTimes(Path, long, long) except that Path f must be for this file system.
    setTimes(Path, long, long) - Method in class org.apache.hadoop.fs.FileContext
    Set access time of a file.
    setTimes(Path, long, long) - Method in class org.apache.hadoop.fs.FileSystem
    Set access time of a file
    setTimes(Path, long, long) - Method in class org.apache.hadoop.fs.FilterFileSystem
    Set access time of a file
    setTimes(Path, long, long) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    setTimes(Path, long, long) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    setTimestamp(long) - Method in interface org.apache.hadoop.yarn.api.records.LocalResource
    Set the timestamp of the resource to be localized, used for verification.
    setTopologyPaths(String[]) - Method in class org.apache.hadoop.fs.BlockLocation
    Set the network topology paths of the hosts
    setTrackingUrl(String) - Method in class org.apache.hadoop.mapred.JobStatus
    Set the link to the web-ui for details of the job.
    setTrackingUrl(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Set the link to the web-ui for details of the job.
    setTrackingUrl(String) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
    Set the tracking URL for the ApplicationMaster.
    setTrackingUrl(String) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setType(LocalResourceType) - Method in interface org.apache.hadoop.yarn.api.records.LocalResource
    Set the LocalResourceType of the resource to be localized.
    setUber(boolean) - Method in class org.apache.hadoop.mapreduce.JobStatus
    Set uber-mode flag
    setUMask(FsPermission) - Method in class org.apache.hadoop.fs.FileContext
    Set umask to the supplied parameter.
    setUMask(Configuration, FsPermission) - Static method in class org.apache.hadoop.fs.permission.FsPermission
    Set the user file creation mask (umask)
    setup(Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
     
    setup(Mapper<K1, V1, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorMapper
     
    setup(Reducer<Text, Text, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorReducer
     
    setup(Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.lib.chain.ChainMapper
     
    setup(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.lib.chain.ChainReducer
     
    setup(Mapper<K, V, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionMapper
     
    setup(Reducer<Text, Text, Text, Text>.Context) - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionReducer
     
    setup(Mapper<K, Text, Text, LongWritable>.Context) - Method in class org.apache.hadoop.mapreduce.lib.map.RegexMapper
     
    setup(Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Mapper
    Called once at the beginning of the task.
    setup(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class org.apache.hadoop.mapreduce.Reducer
    Called once at the start of the task.
    setupJob(JobContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
     
    setupJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
    For the framework to setup the job output during initialization.
    setupJob(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
    This method implements the new interface by calling the old method.
    setupJob(JobContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
    Create the temporary directory that is the root of all of the task work directories.
    setupJob(JobContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
    For the framework to setup the job output during initialization.
    setupProgress() - Method in class org.apache.hadoop.mapred.JobStatus
     
    setupProgress() - Method in interface org.apache.hadoop.mapred.RunningJob
    Get the progress of the job's setup-tasks, as a float between 0.0 and 1.0.
    setupProgress() - Method in class org.apache.hadoop.mapreduce.Job
    Get the progress of the job's setup-tasks, as a float between 0.0 and 1.0.
    setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
     
    setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
    Sets up output for the task.
    setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
    This method implements the new interface by calling the old method.
    setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
    No task setup required.
    setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.OutputCommitter
    Sets up output for the task.
    setUsed(Resource) - Method in interface org.apache.hadoop.yarn.api.records.NodeReport
     
    setUsedMem(int) - Method in class org.apache.hadoop.mapreduce.JobStatus
     
    setUsedResources(Resource) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
     
    setUseNewMapper(boolean) - Method in class org.apache.hadoop.mapred.JobConf
    Set whether the framework should use the new api for the mapper.
    setUseNewReducer(boolean) - Method in class org.apache.hadoop.mapred.JobConf
    Set whether the framework should use the new api for the reducer.
    setUser(String) - Method in class org.apache.hadoop.mapred.JobConf
    Set the reported username for this job.
    setUser(String) - Method in class org.apache.hadoop.mapreduce.Job
    Set the reported username for this job.
    setUser(String) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setUser(String) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the user submitting the application.
    setUser(String) - Method in interface org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Set the user to whom the container has been allocated
    setUserAcls(List<QueueACL>) - Method in interface org.apache.hadoop.yarn.api.records.QueueUserACLInfo
     
    setUserAclsInfoList(List<QueueUserACLInfo>) - Method in interface org.apache.hadoop.yarn.api.protocolrecords.GetQueueUserAclsInfoResponse
     
    setUsername(String) - Method in class org.apache.hadoop.mapred.JobStatus
     
    setUsername(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
     
    setValue(long) - Method in interface org.apache.hadoop.mapreduce.Counter
    Set this counter by the given value
    setVerifyChecksum(boolean) - Method in class org.apache.hadoop.fs.AbstractFileSystem
    The specification of this method matches that of FileContext.setVerifyChecksum(boolean, Path) except that Path f must be for this file system.
    setVerifyChecksum(boolean) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
    Set whether to verify checksum.
    setVerifyChecksum(boolean, Path) - Method in class org.apache.hadoop.fs.FileContext
    Set the verify checksum flag for the file system denoted by the path.
    setVerifyChecksum(boolean) - Method in class org.apache.hadoop.fs.FileSystem
    Set the verify checksum flag.
    setVerifyChecksum(boolean) - Method in class org.apache.hadoop.fs.FilterFileSystem
    Set the verify checksum flag.
    setVerifyChecksum(boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    setVerifyChecksum(boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    setVisibility(LocalResourceVisibility) - Method in interface org.apache.hadoop.yarn.api.records.LocalResource
    Set the LocalResourceVisibility of the resource to be localized.
    setWorkingDirectory(Path) - Method in class org.apache.hadoop.fs.FileContext
    Set the working directory for wd-relative names (such a "foo/bar").
    setWorkingDirectory(Path) - Method in class org.apache.hadoop.fs.FileSystem
    Set the current working directory for the given file system.
    setWorkingDirectory(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
    Set the current working directory for the given file system.
    setWorkingDirectory(Path) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
     
    setWorkingDirectory(Path) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
     
    setWorkingDirectory(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
    Set the working directory to the given directory.
    setWorkingDirectory(Path) - Method in class org.apache.hadoop.fs.s3.S3FileSystem
     
    setWorkingDirectory(Path) - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
    Set the working directory to the given directory.
    setWorkingDirectory(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    setWorkingDirectory(Path) - Method in class org.apache.hadoop.mapred.JobConf
    Set the current working directory for the default file system.
    setWorkingDirectory(Path) - Method in class org.apache.hadoop.mapreduce.Job
    Set the current working directory for the default file system.
    setWriteAllCounters(boolean) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
    Set the "writeAllCounters" option to true or false
    setWriteChecksum(boolean) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
     
    setWriteChecksum(boolean) - Method in class org.apache.hadoop.fs.FileSystem
    Set the write checksum flag.
    setWriteChecksum(boolean) - Method in class org.apache.hadoop.fs.FilterFileSystem
     
    setWriteChecksum(boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    setYarnApplicationState(YarnApplicationState) - Method in interface org.apache.hadoop.yarn.api.records.ApplicationReport
     
    ShortWritable - Class in org.apache.hadoop.io
    A WritableComparable for shorts.
    ShortWritable() - Constructor for class org.apache.hadoop.io.ShortWritable
     
    ShortWritable(short) - Constructor for class org.apache.hadoop.io.ShortWritable
     
    shutdown() - Static method in enum org.apache.hadoop.metrics2.lib.DefaultMetricsSystem
    Shutdown the metrics system
    shutdown() - Method in class org.apache.hadoop.metrics2.MetricsSystem
    Shutdown the metrics system completely (usually during server shutdown.) The MetricsSystemMXBean will be unregistered.
    SHUTDOWN_HOOK_PRIORITY - Static variable in class org.apache.hadoop.fs.FileContext
    Priority of the FileContext shutdown hook.
    SHUTDOWN_HOOK_PRIORITY - Static variable in class org.apache.hadoop.fs.FileSystem
    Priority of the FileSystem shutdown hook.
    SimpleCharStream - Class in org.apache.hadoop.record.compiler.generated
    Deprecated.
    Replaced by Avro.
    SimpleCharStream(Reader, int, int, int) - Constructor for class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    SimpleCharStream(Reader, int, int) - Constructor for class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    SimpleCharStream(Reader) - Constructor for class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    SimpleCharStream(InputStream, String, int, int, int) - Constructor for class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    SimpleCharStream(InputStream, int, int, int) - Constructor for class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    SimpleCharStream(InputStream, String, int, int) - Constructor for class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    SimpleCharStream(InputStream, int, int) - Constructor for class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    SimpleCharStream(InputStream, String) - Constructor for class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    SimpleCharStream(InputStream) - Constructor for class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    size() - Method in class org.apache.hadoop.conf.Configuration
    Return the number of keys in the configuration.
    size() - Method in class org.apache.hadoop.io.EnumSetWritable
     
    size() - Method in interface org.apache.hadoop.io.file.tfile.RawComparable
    Get the size of the byte range in the byte array.
    size() - Method in class org.apache.hadoop.io.MapWritable
    size() - Method in class org.apache.hadoop.io.SortedMapWritable
    size() - Method in class org.apache.hadoop.mapred.Counters
    Deprecated.
    size() - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
     
    size() - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
    The number of children in this Tuple.
    skip(long) - Method in class org.apache.hadoop.io.compress.DecompressorStream
     
    skip(DataInput) - Static method in class org.apache.hadoop.io.Text
    Skips over one Text in the input.
    skip(K) - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
    Skip key-value pairs with keys less than or equal to the key provided.
    skip(K) - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
    Pass skip key to child RRs.
    skip(K) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
    Skip key-value pairs with keys less than or equal to the key provided.
    skip(K) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
    Pass skip key to child RRs.
    skip(K) - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
    Skip key-value pairs with keys less than or equal to the key provided.
    skip(RecordInput, String, TypeID) - Static method in class org.apache.hadoop.record.meta.Utils
    Deprecated.
    read/skip bytes from stream based on a type
    SkipBadRecords - Class in org.apache.hadoop.mapred
    Utility class for skip bad records functionality.
    SkipBadRecords() - Constructor for class org.apache.hadoop.mapred.SkipBadRecords
     
    skipCompressedByteArray(DataInput) - Static method in class org.apache.hadoop.io.WritableUtils
     
    skipFully(InputStream, long) - Static method in class org.apache.hadoop.io.IOUtils
    Similar to readFully().
    skipFully(DataInput, int) - Static method in class org.apache.hadoop.io.WritableUtils
    Skip len number of bytes in input streamin
    snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
    Sample all the mutable metrics and put the snapshot in the builder
    snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableCounterInt
     
    snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableCounterLong
     
    snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeInt
     
    snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeLong
     
    snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableMetric
    Get a snapshot of the metric
    snapshot(MetricsRecordBuilder) - Method in class org.apache.hadoop.metrics2.lib.MutableMetric
    Get a snapshot of metric if changed
    snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableRates
     
    snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableStat
     
    SocksSocketFactory - Class in org.apache.hadoop.net
    Specialized SocketFactory to create sockets with a SOCKS proxy
    SocksSocketFactory() - Constructor for class org.apache.hadoop.net.SocksSocketFactory
    Default empty constructor (for use with the reflection API).
    SocksSocketFactory(Proxy) - Constructor for class org.apache.hadoop.net.SocksSocketFactory
    Constructor with a supplied Proxy
    SortedMapWritable - Class in org.apache.hadoop.io
    A Writable SortedMap.
    SortedMapWritable() - Constructor for class org.apache.hadoop.io.SortedMapWritable
    default constructor.
    SortedMapWritable(SortedMapWritable) - Constructor for class org.apache.hadoop.io.SortedMapWritable
    Copy constructor.
    sourceName(String, boolean) - Static method in enum org.apache.hadoop.metrics2.lib.DefaultMetricsSystem
     
    specialConstructor - Variable in exception org.apache.hadoop.record.compiler.generated.ParseException
    Deprecated.
    This variable determines which constructor was used to create this object and thereby affects the semantics of the "getMessage" method (see below).
    specialToken - Variable in class org.apache.hadoop.record.compiler.generated.Token
    Deprecated.
    This field is used to access special tokens that occur prior to this token, but after the immediately preceding regular (non-special) token.
    specToString(String, String, int, List<Integer>, List<Integer>) - Static method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
     
    split - Variable in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
     
    split(Configuration, ResultSet, String) - Method in class org.apache.hadoop.mapreduce.lib.db.BigDecimalSplitter
     
    split(Configuration, ResultSet, String) - Method in class org.apache.hadoop.mapreduce.lib.db.BooleanSplitter
     
    split(Configuration, ResultSet, String) - Method in class org.apache.hadoop.mapreduce.lib.db.DateSplitter
     
    split(Configuration, ResultSet, String) - Method in interface org.apache.hadoop.mapreduce.lib.db.DBSplitter
    Given a ResultSet containing one record (and already advanced to that record) with two columns (a low value, and a high value, both of the same type), determine a set of splits that span the given values.
    split(Configuration, ResultSet, String) - Method in class org.apache.hadoop.mapreduce.lib.db.FloatSplitter
     
    split(Configuration, ResultSet, String) - Method in class org.apache.hadoop.mapreduce.lib.db.IntegerSplitter
     
    split(Configuration, ResultSet, String) - Method in class org.apache.hadoop.mapreduce.lib.db.TextSplitter
    This method needs to determine the splits between two user-provided strings.
    split - Variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
     
    SPLIT_MAXSIZE - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
     
    SPLIT_MINSIZE - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
     
    SPLIT_MINSIZE_PERNODE - Static variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
     
    SPLIT_MINSIZE_PERRACK - Static variable in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
     
    SplitCompressionInputStream - Class in org.apache.hadoop.io.compress
    An InputStream covering a range of compressed data.
    SplitCompressionInputStream(InputStream, long, long) - Constructor for class org.apache.hadoop.io.compress.SplitCompressionInputStream
     
    SplittableCompressionCodec - Interface in org.apache.hadoop.io.compress
    This interface is meant to be implemented by those compression codecs which are capable to compress / de-compress a stream starting at any arbitrary position.
    StandardSocketFactory - Class in org.apache.hadoop.net
    Specialized SocketFactory to create sockets with a SOCKS proxy
    StandardSocketFactory() - Constructor for class org.apache.hadoop.net.StandardSocketFactory
    Default empty constructor (for use with the reflection API).
    start() - Method in interface org.apache.hadoop.metrics2.MetricsSystemMXBean
    Start the metrics system
    start() - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
     
    start() - Method in class org.hadoop.yarn.client.YarnClientImpl
     
    startContainer(StartContainerRequest) - Method in interface org.apache.hadoop.yarn.api.ContainerManager
    The ApplicationMaster requests a NodeManager to start a Container allocated to it using this interface.
    StartContainerRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
    The request sent by the ApplicationMaster to the NodeManager to start a container.
    StartContainerResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
    The response sent by the NodeManager to the ApplicationMaster when asked to start an allocated container.
    startLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
     
    startLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.FileSystem
    Returns a local File that the user can write output to.
    startLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
    Returns a local File that the user can write output to.
    startLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
     
    startLocalOutput(Path, Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
     
    startMap(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
    Deprecated.
     
    startMap(TreeMap, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
    Deprecated.
     
    startMap(String) - Method in class org.apache.hadoop.record.CsvRecordInput
    Deprecated.
     
    startMap(TreeMap, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
    Deprecated.
     
    startMap(String) - Method in interface org.apache.hadoop.record.RecordInput
    Deprecated.
    Check the mark for start of the serialized map.
    startMap(TreeMap, String) - Method in interface org.apache.hadoop.record.RecordOutput
    Deprecated.
    Mark the start of a map to be serialized.
    startMap(String) - Method in class org.apache.hadoop.record.XmlRecordInput
    Deprecated.
     
    startMap(TreeMap, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
    Deprecated.
     
    startMetricsMBeans() - Method in interface org.apache.hadoop.metrics2.MetricsSystemMXBean
    Start metrics MBeans
    startMonitoring() - Method in class org.apache.hadoop.metrics.file.FileContext
    Deprecated.
    Starts or restarts monitoring, by opening in append-mode, the file specified by the fileName attribute, if specified.
    startMonitoring() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
    Starts or restarts monitoring, the emitting of metrics records.
    startMonitoring() - Method in class org.apache.hadoop.metrics.spi.CompositeContext
     
    startMonitoring() - Method in class org.apache.hadoop.metrics.spi.NullContext
    Do-nothing version of startMonitoring
    startRecord(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
    Deprecated.
     
    startRecord(Record, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
    Deprecated.
     
    startRecord(String) - Method in class org.apache.hadoop.record.CsvRecordInput
    Deprecated.
     
    startRecord(Record, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
    Deprecated.
     
    startRecord(String) - Method in interface org.apache.hadoop.record.RecordInput
    Deprecated.
    Check the mark for start of the serialized record.
    startRecord(Record, String) - Method in interface org.apache.hadoop.record.RecordOutput
    Deprecated.
    Mark the start of a record to be serialized.
    startRecord(String) - Method in class org.apache.hadoop.record.XmlRecordInput
    Deprecated.
     
    startRecord(Record, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
    Deprecated.
     
    startVector(String) - Method in class org.apache.hadoop.record.BinaryRecordInput
    Deprecated.
     
    startVector(ArrayList, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
    Deprecated.
     
    startVector(String) - Method in class org.apache.hadoop.record.CsvRecordInput
    Deprecated.
     
    startVector(ArrayList, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
    Deprecated.
     
    startVector(String) - Method in interface org.apache.hadoop.record.RecordInput
    Deprecated.
    Check the mark for start of the serialized vector.
    startVector(ArrayList, String) - Method in interface org.apache.hadoop.record.RecordOutput
    Deprecated.
    Mark the start of a vector to be serialized.
    startVector(String) - Method in class org.apache.hadoop.record.XmlRecordInput
    Deprecated.
     
    startVector(ArrayList, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
    Deprecated.
     
    stat2Paths(FileStatus[]) - Static method in class org.apache.hadoop.fs.FileUtil
    convert an array of FileStatus to an array of Path
    stat2Paths(FileStatus[], Path) - Static method in class org.apache.hadoop.fs.FileUtil
    convert an array of FileStatus to an array of Path.
    statement - Variable in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
     
    staticFlag - Static variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    statistics - Variable in class org.apache.hadoop.fs.AbstractFileSystem
    The statistics for this file system.
    statistics - Variable in class org.apache.hadoop.fs.FileSystem
    The statistics for this file system.
    stop() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
    set the thread state to STOPPING so that the thread will stop when it wakes up.
    stop() - Method in interface org.apache.hadoop.metrics2.MetricsSystemMXBean
    Stop the metrics system
    stop() - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
     
    stop() - Method in class org.hadoop.yarn.client.YarnClientImpl
     
    stopContainer(StopContainerRequest) - Method in interface org.apache.hadoop.yarn.api.ContainerManager
    The ApplicationMaster requests a NodeManager to stop a Container allocated to it using this interface.
    StopContainerRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
    The request sent by the ApplicationMaster to the NodeManager to stop a container.
    StopContainerResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
    The response sent by the NodeManager to the ApplicationMaster when asked to stop an allocated container.
    stopMetricsMBeans() - Method in interface org.apache.hadoop.metrics2.MetricsSystemMXBean
    Stop metrics MBeans.
    stopMonitoring() - Method in class org.apache.hadoop.metrics.file.FileContext
    Deprecated.
    Stops monitoring, closing the file.
    stopMonitoring() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
    Stops monitoring.
    stopMonitoring() - Method in class org.apache.hadoop.metrics.spi.CompositeContext
     
    store(Configuration, K, String) - Static method in class org.apache.hadoop.io.DefaultStringifier
    Stores the item in the configuration with the given keyName.
    storeArray(Configuration, K[], String) - Static method in class org.apache.hadoop.io.DefaultStringifier
    Stores the array of items in the configuration with the given keyName.
    StreamBackedIterator<X extends Writable> - Class in org.apache.hadoop.mapred.join
    This class provides an implementation of ResetableIterator.
    StreamBackedIterator() - Constructor for class org.apache.hadoop.mapred.join.StreamBackedIterator
     
    StreamBackedIterator<X extends Writable> - Class in org.apache.hadoop.mapreduce.lib.join
    This class provides an implementation of ResetableIterator.
    StreamBackedIterator() - Constructor for class org.apache.hadoop.mapreduce.lib.join.StreamBackedIterator
     
    STRING_VALUE_MAX - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
     
    STRING_VALUE_MAX - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
     
    STRING_VALUE_MIN - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
     
    STRING_VALUE_MIN - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
     
    Stringifier<T> - Interface in org.apache.hadoop.io
    Stringifier interface offers two methods to convert an object to a string representation and restore the object given its string representation.
    StringInterner - Class in org.apache.hadoop.util
    Provides equivalent behavior to String.intern() to optimize performance, whereby does not consume memory in the permanent generation.
    StringInterner() - Constructor for class org.apache.hadoop.util.StringInterner
     
    StringTypeID - Static variable in class org.apache.hadoop.record.meta.TypeID
    Deprecated.
     
    StringValueMax - Class in org.apache.hadoop.mapred.lib.aggregate
    This class implements a value aggregator that maintain the biggest of a sequence of strings.
    StringValueMax() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.StringValueMax
     
    StringValueMax - Class in org.apache.hadoop.mapreduce.lib.aggregate
    This class implements a value aggregator that maintain the biggest of a sequence of strings.
    StringValueMax() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMax
    the default constructor
    StringValueMin - Class in org.apache.hadoop.mapred.lib.aggregate
    This class implements a value aggregator that maintain the smallest of a sequence of strings.
    StringValueMin() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.StringValueMin
     
    StringValueMin - Class in org.apache.hadoop.mapreduce.lib.aggregate
    This class implements a value aggregator that maintain the smallest of a sequence of strings.
    StringValueMin() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.StringValueMin
    the default constructor
    strongIntern(String) - Static method in class org.apache.hadoop.util.StringInterner
    Interns and returns a reference to the representative instance for any of a collection of string instances that are equal to each other.
    StructTypeID - Class in org.apache.hadoop.record.meta
    Deprecated.
    Replaced by Avro.
    StructTypeID(RecordTypeInfo) - Constructor for class org.apache.hadoop.record.meta.StructTypeID
    Deprecated.
    Create a StructTypeID based on the RecordTypeInfo of some record
    subMap(WritableComparable, WritableComparable) - Method in class org.apache.hadoop.io.SortedMapWritable
    submit() - Method in class org.apache.hadoop.mapreduce.Job
    Submit the job to the cluster and return immediately.
    submit() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
    Submit this job to mapred.
    SUBMIT_REPLICATION - Static variable in class org.apache.hadoop.mapreduce.Job
     
    submitApplication(SubmitApplicationRequest) - Method in interface org.apache.hadoop.yarn.api.ClientRMProtocol
    The interface used by clients to submit a new application to the ResourceManager.
    submitApplication(ApplicationSubmissionContext) - Method in interface org.apache.hadoop.yarn.client.YarnClient
    Submit a new application to YARN.
    submitApplication(ApplicationSubmissionContext) - Method in class org.apache.hadoop.yarn.client.YarnClientImpl
     
    submitApplication(ApplicationSubmissionContext) - Method in interface org.hadoop.yarn.client.YarnClient
    Submit a new application to YARN.
    submitApplication(ApplicationSubmissionContext) - Method in class org.hadoop.yarn.client.YarnClientImpl
     
    SubmitApplicationRequest - Interface in org.apache.hadoop.yarn.api.protocolrecords
    The request sent by a client to submit an application to the ResourceManager.
    SubmitApplicationResponse - Interface in org.apache.hadoop.yarn.api.protocolrecords
    The response sent by the ResourceManager to a client on application submission.
    submitJob(String) - Method in class org.apache.hadoop.mapred.JobClient
    Submit a job to the MR system.
    submitJob(JobConf) - Method in class org.apache.hadoop.mapred.JobClient
    Submit a job to the MR system.
    submitJob(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
    Deprecated.
    Submitter - Class in org.apache.hadoop.mapred.pipes
    The main entry point and job submitter.
    Submitter() - Constructor for class org.apache.hadoop.mapred.pipes.Submitter
     
    Submitter(Configuration) - Constructor for class org.apache.hadoop.mapred.pipes.Submitter
     
    SUBSTITUTE_TOKEN - Static variable in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
    If users are providing their own query, the following string is expected to appear in the WHERE clause, which will be substituted with a pair of conditions on the input to allow input splits to parallelise the import.
    SUCCEEDED - Static variable in class org.apache.hadoop.mapred.JobStatus
     
    SUCCEEDED_FILE_NAME - Static variable in class org.apache.hadoop.mapred.FileOutputCommitter
     
    SUCCEEDED_FILE_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
     
    SUCCESS - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
     
    SUCCESSFUL_JOB_OUTPUT_DIR_MARKER - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
     
    suffix(String) - Method in class org.apache.hadoop.fs.Path
    Adds a suffix to the final name in the path.
    sum(Counters, Counters) - Static method in class org.apache.hadoop.mapred.Counters
    Convenience method for computing the sum of two sets of counters.
    supportsSymlinks() - Method in class org.apache.hadoop.fs.AbstractFileSystem
    Returns true if the file system supports symlinks, false otherwise.
    supportsSymlinks() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    suspend() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
    suspend the running thread
    swapScheme - Variable in class org.apache.hadoop.fs.FilterFileSystem
     
    SwitchTo(int) - Method in class org.apache.hadoop.record.compiler.generated.RccTokenManager
    Deprecated.
     
    symLink(String, String) - Static method in class org.apache.hadoop.fs.FileUtil
    Create a soft link between a src and destination only on a local disk.
    sync() - Method in class org.apache.hadoop.fs.FSDataOutputStream
    Deprecated.
    sync() - Method in interface org.apache.hadoop.fs.Syncable
    Deprecated.
    As of HADOOP 0.21.0, replaced by hflush
    SYNC_INTERVAL - Static variable in class org.apache.hadoop.io.SequenceFile
    The number of bytes between sync points.
    Syncable - Interface in org.apache.hadoop.fs
    This interface for flush/sync operation.

    T

    tabSize - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    tag(MetricsInfo, String) - Static method in class org.apache.hadoop.metrics2.lib.Interns
    Get a metrics tag
    tag(String, String, String) - Static method in class org.apache.hadoop.metrics2.lib.Interns
    Get a metrics tag
    tag(String, String, String) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
    Add a tag to the metrics
    tag(String, String, String, boolean) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
    Add a tag to the metrics
    tag(MetricsInfo, String, boolean) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
    Add a tag to the metrics
    tag(MetricsInfo, String) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
     
    tag(MetricsInfo, String) - Method in class org.apache.hadoop.metrics2.MetricsRecordBuilder
    Add a metrics tag
    TAG - Static variable in class org.apache.hadoop.record.compiler.Consts
    Deprecated.
     
    tags() - Method in interface org.apache.hadoop.metrics2.MetricsRecord
    Get the tags of the record Note: returning a collection instead of iterable as we need to use tags as keys (hence Collection#hashCode etc.) in maps
    tailMap(WritableComparable) - Method in class org.apache.hadoop.io.SortedMapWritable
    TASK - Static variable in class org.apache.hadoop.mapreduce.TaskID
     
    TaskAttemptContext - Interface in org.apache.hadoop.mapred
     
    TaskAttemptContext - Interface in org.apache.hadoop.mapreduce
    The context for task attempts.
    TaskAttemptID - Class in org.apache.hadoop.mapred
    TaskAttemptID represents the immutable and unique identifier for a task attempt.
    TaskAttemptID(TaskID, int) - Constructor for class org.apache.hadoop.mapred.TaskAttemptID
    Constructs a TaskAttemptID object from given TaskID.
    TaskAttemptID(String, int, boolean, int, int) - Constructor for class org.apache.hadoop.mapred.TaskAttemptID
    TaskAttemptID(String, int, TaskType, int, int) - Constructor for class org.apache.hadoop.mapred.TaskAttemptID
    Constructs a TaskId object from given parts.
    TaskAttemptID() - Constructor for class org.apache.hadoop.mapred.TaskAttemptID
     
    TaskAttemptID - Class in org.apache.hadoop.mapreduce
    TaskAttemptID represents the immutable and unique identifier for a task attempt.
    TaskAttemptID(TaskID, int) - Constructor for class org.apache.hadoop.mapreduce.TaskAttemptID
    Constructs a TaskAttemptID object from given TaskID.
    TaskAttemptID(String, int, TaskType, int, int) - Constructor for class org.apache.hadoop.mapreduce.TaskAttemptID
    Constructs a TaskId object from given parts.
    TaskAttemptID() - Constructor for class org.apache.hadoop.mapreduce.TaskAttemptID
     
    TaskCompletionEvent - Class in org.apache.hadoop.mapred
    This is used to track task completion events on job tracker.
    TaskCompletionEvent() - Constructor for class org.apache.hadoop.mapred.TaskCompletionEvent
    Default constructor for Writable.
    TaskCompletionEvent(int, TaskAttemptID, int, boolean, TaskCompletionEvent.Status, String) - Constructor for class org.apache.hadoop.mapred.TaskCompletionEvent
    Constructor.
    TaskCompletionEvent - Class in org.apache.hadoop.mapreduce
    This is used to track task completion events on job tracker.
    TaskCompletionEvent() - Constructor for class org.apache.hadoop.mapreduce.TaskCompletionEvent
    Default constructor for Writable.
    TaskCompletionEvent(int, TaskAttemptID, int, boolean, TaskCompletionEvent.Status, String) - Constructor for class org.apache.hadoop.mapreduce.TaskCompletionEvent
    Constructor.
    TaskCompletionEvent.Status - Enum in org.apache.hadoop.mapred
     
    TaskCompletionEvent.Status - Enum in org.apache.hadoop.mapreduce
     
    TaskCounter - Enum in org.apache.hadoop.mapreduce
     
    TaskID - Class in org.apache.hadoop.mapred
    TaskID represents the immutable and unique identifier for a Map or Reduce Task.
    TaskID(JobID, boolean, int) - Constructor for class org.apache.hadoop.mapred.TaskID
    TaskID(String, int, boolean, int) - Constructor for class org.apache.hadoop.mapred.TaskID
    TaskID(JobID, TaskType, int) - Constructor for class org.apache.hadoop.mapred.TaskID
    Constructs a TaskID object from given JobID.
    TaskID(String, int, TaskType, int) - Constructor for class org.apache.hadoop.mapred.TaskID
    Constructs a TaskInProgressId object from given parts.
    TaskID() - Constructor for class org.apache.hadoop.mapred.TaskID
     
    TaskID - Class in org.apache.hadoop.mapreduce
    TaskID represents the immutable and unique identifier for a Map or Reduce Task.
    TaskID(JobID, TaskType, int) - Constructor for class org.apache.hadoop.mapreduce.TaskID
    Constructs a TaskID object from given JobID.
    TaskID(String, int, TaskType, int) - Constructor for class org.apache.hadoop.mapreduce.TaskID
    Constructs a TaskInProgressId object from given parts.
    TaskID() - Constructor for class org.apache.hadoop.mapreduce.TaskID
     
    TaskInputOutputContext<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Interface in org.apache.hadoop.mapreduce
    A context object that allows input and output from the task.
    TaskReport - Class in org.apache.hadoop.mapred
    A report on the state of a task.
    TaskReport() - Constructor for class org.apache.hadoop.mapred.TaskReport
     
    TaskTrackerInfo - Class in org.apache.hadoop.mapreduce
    Information about TaskTracker.
    TaskTrackerInfo() - Constructor for class org.apache.hadoop.mapreduce.TaskTrackerInfo
     
    TaskTrackerInfo(String) - Constructor for class org.apache.hadoop.mapreduce.TaskTrackerInfo
     
    TaskTrackerInfo(String, String, String) - Constructor for class org.apache.hadoop.mapreduce.TaskTrackerInfo
     
    TaskType - Enum in org.apache.hadoop.mapreduce
    Enum for map, reduce, job-setup, job-cleanup, task-cleanup task types.
    tell() - Method in class org.apache.hadoop.fs.AvroFSInput
     
    TEMP_DIR_NAME - Static variable in class org.apache.hadoop.mapred.FileOutputCommitter
    Temporary directory name
    Text - Class in org.apache.hadoop.io
    This class stores text using standard UTF8 encoding.
    Text() - Constructor for class org.apache.hadoop.io.Text
     
    Text(String) - Constructor for class org.apache.hadoop.io.Text
    Construct from a string.
    Text(Text) - Constructor for class org.apache.hadoop.io.Text
    Construct from another text.
    Text(byte[]) - Constructor for class org.apache.hadoop.io.Text
    Construct from a byte array.
    TextInputFormat - Class in org.apache.hadoop.mapred
    An InputFormat for plain text files.
    TextInputFormat() - Constructor for class org.apache.hadoop.mapred.TextInputFormat
     
    TextInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
    An InputFormat for plain text files.
    TextInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.TextInputFormat
     
    TextOutputFormat<K,V> - Class in org.apache.hadoop.mapred
    An OutputFormat that writes plain text files.
    TextOutputFormat() - Constructor for class org.apache.hadoop.mapred.TextOutputFormat
     
    TextOutputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.output
    An OutputFormat that writes plain text files.
    TextOutputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.output.TextOutputFormat
     
    TextSplitter - Class in org.apache.hadoop.mapreduce.lib.db
    Implement DBSplitter over text strings.
    TextSplitter() - Constructor for class org.apache.hadoop.mapreduce.lib.db.TextSplitter
     
    TFile - Class in org.apache.hadoop.io.file.tfile
    A TFile is a container of key-value pairs.
    TFILE_FS_INPUT_BUFFER_SIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
    Default value for TFILE_FS_INPUT_BUFFER_SIZE_KEY
    TFILE_FS_INPUT_BUFFER_SIZE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
    TFILE_FS_OUTPUT_BUFFER_SIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
    Default value for TFILE_FS_OUTPUT_BUFFER_SIZE_KEY
    TFILE_FS_OUTPUT_BUFFER_SIZE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
    TFILE_IO_CHUNK_SIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
    Default value for TFILE_IO_CHUNK_SIZE_DEFAULT
    TFILE_IO_CHUNK_SIZE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
    theAggregatorDescriptor - Variable in class org.apache.hadoop.mapreduce.lib.aggregate.UserDefinedValueAggregatorDescriptor
     
    timestamp() - Method in interface org.apache.hadoop.metrics2.MetricsRecord
    Get the timestamp of the metrics
    toArray() - Method in class org.apache.hadoop.io.ArrayWritable
     
    toArray() - Method in class org.apache.hadoop.io.TwoDArrayWritable
     
    toByteArray(Writable...) - Static method in class org.apache.hadoop.io.WritableUtils
    Convert writables to a byte array
    token - Variable in class org.apache.hadoop.record.compiler.generated.Rcc
    Deprecated.
     
    Token - Class in org.apache.hadoop.record.compiler.generated
    Deprecated.
    Replaced by Avro.
    Token() - Constructor for class org.apache.hadoop.record.compiler.generated.Token
    Deprecated.
     
    token_source - Variable in class org.apache.hadoop.record.compiler.generated.Rcc
    Deprecated.
     
    TokenCache - Class in org.apache.hadoop.mapreduce.security
    This class provides user facing APIs for transferring secrets from the job client to the tasks.
    TokenCache() - Constructor for class org.apache.hadoop.mapreduce.security.TokenCache
     
    TokenCounterMapper - Class in org.apache.hadoop.mapreduce.lib.map
    Tokenize the input values and emit each word with a count of 1.
    TokenCounterMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.map.TokenCounterMapper
     
    TokenCountMapper<K> - Class in org.apache.hadoop.mapred.lib
    A Mapper that maps text values into pairs.
    TokenCountMapper() - Constructor for class org.apache.hadoop.mapred.lib.TokenCountMapper
     
    tokenImage - Variable in exception org.apache.hadoop.record.compiler.generated.ParseException
    Deprecated.
    This is a reference to the "tokenImage" array of the generated parser within which the parse error occurred.
    tokenImage - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
    Deprecated.
     
    TokenMgrError - Error in org.apache.hadoop.record.compiler.generated
    Deprecated.
    Replaced by Avro.
    TokenMgrError() - Constructor for error org.apache.hadoop.record.compiler.generated.TokenMgrError
    Deprecated.
     
    TokenMgrError(String, int) - Constructor for error org.apache.hadoop.record.compiler.generated.TokenMgrError
    Deprecated.
     
    TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.hadoop.record.compiler.generated.TokenMgrError
    Deprecated.
     
    Tool - Interface in org.apache.hadoop.util
    A tool interface that supports handling of generic command-line options.
    ToolRunner - Class in org.apache.hadoop.util
    A utility to help run Tools.
    ToolRunner() - Constructor for class org.apache.hadoop.util.ToolRunner
     
    toShort() - Method in class org.apache.hadoop.fs.permission.FsPermission
    Encode the object to a short.
    toString() - Method in class org.apache.hadoop.conf.Configuration
     
    toString() - Method in class org.apache.hadoop.fs.BlockLocation
     
    toString() - Method in class org.apache.hadoop.fs.ContentSummary
    toString(boolean) - Method in class org.apache.hadoop.fs.ContentSummary
    Return the string representation of the object in the output format.
    toString() - Method in class org.apache.hadoop.fs.FileStatus
     
    toString() - Method in class org.apache.hadoop.fs.Path
     
    toString() - Method in class org.apache.hadoop.fs.permission.FsPermission
    toString() - Method in class org.apache.hadoop.fs.RawLocalFileSystem
     
    toString() - Method in class org.apache.hadoop.io.BooleanWritable
     
    toString() - Method in class org.apache.hadoop.io.BytesWritable
    Generate the stream of bytes as hex pairs separated by ' '.
    toString() - Method in class org.apache.hadoop.io.ByteWritable
     
    toString() - Method in class org.apache.hadoop.io.compress.CompressionCodecFactory
    Print the extension map out as a string.
    toString(T) - Method in class org.apache.hadoop.io.DefaultStringifier
     
    toString() - Method in class org.apache.hadoop.io.DoubleWritable
     
    toString() - Method in class org.apache.hadoop.io.EnumSetWritable
    toString() - Method in class org.apache.hadoop.io.FloatWritable
     
    toString() - Method in class org.apache.hadoop.io.GenericWritable
     
    toString() - Method in class org.apache.hadoop.io.IntWritable
     
    toString() - Method in class org.apache.hadoop.io.LongWritable
     
    toString() - Method in class org.apache.hadoop.io.MD5Hash
    Returns a string representation of this object.
    toString() - Method in class org.apache.hadoop.io.NullWritable
     
    toString() - Method in class org.apache.hadoop.io.ObjectWritable
     
    toString() - Method in class org.apache.hadoop.io.ShortWritable
    Short values in string format
    toString(T) - Method in interface org.apache.hadoop.io.Stringifier
    Converts the object to a string representation
    toString() - Method in class org.apache.hadoop.io.Text
    Convert text back to string
    toString() - Method in exception org.apache.hadoop.io.VersionMismatchException
    Returns a string representation of this object.
    toString() - Method in class org.apache.hadoop.io.VIntWritable
     
    toString() - Method in class org.apache.hadoop.io.VLongWritable
     
    toString() - Method in class org.apache.hadoop.mapred.FileSplit
     
    toString() - Method in class org.apache.hadoop.mapred.MultiFileSplit
     
    toString() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
    Return textual representation of the counter values.
    toString() - Method in class org.apache.hadoop.mapreduce.ID
     
    toString() - Method in class org.apache.hadoop.mapreduce.Job
    Dump stats to screen.
    toString() - Method in class org.apache.hadoop.mapreduce.JobID
     
    toString() - Method in class org.apache.hadoop.mapreduce.JobStatus
     
    toString() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UserDefinedValueAggregatorDescriptor
     
    toString() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
     
    toString() - Method in class org.apache.hadoop.mapreduce.lib.input.FileSplit
     
    toString() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
     
    toString() - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
    Convert Tuple to String as in the following.
    toString() - Method in enum org.apache.hadoop.mapreduce.QueueState
     
    toString() - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
     
    toString() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
     
    toString() - Method in class org.apache.hadoop.mapreduce.TaskID
     
    toString() - Method in class org.apache.hadoop.metrics2.AbstractMetric
     
    toString() - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
     
    toString() - Method in class org.apache.hadoop.metrics2.MetricsTag
     
    toString() - Method in class org.apache.hadoop.net.CachedDNSToSwitchMapping
     
    toString() - Method in class org.apache.hadoop.net.ScriptBasedMapping
     
    toString() - Method in class org.apache.hadoop.record.Buffer
    Deprecated.
     
    toString(String) - Method in class org.apache.hadoop.record.Buffer
    Deprecated.
    Convert the byte buffer to a string an specific character encoding
    toString() - Method in class org.apache.hadoop.record.compiler.CodeBuffer
    Deprecated.
     
    toString() - Method in class org.apache.hadoop.record.compiler.generated.Token
    Deprecated.
    Returns the image.
    toString() - Method in class org.apache.hadoop.record.Record
    Deprecated.
     
    toString() - Method in class org.apache.hadoop.util.bloom.BloomFilter
     
    toString() - Method in class org.apache.hadoop.util.bloom.CountingBloomFilter
     
    toString() - Method in class org.apache.hadoop.util.bloom.DynamicBloomFilter
     
    toString() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
     
    toString() - Method in class org.apache.hadoop.yarn.api.records.ApplicationId
     
    toString() - Method in class org.apache.hadoop.yarn.api.records.ContainerId
     
    toString() - Method in class org.apache.hadoop.yarn.api.records.NodeId
     
    toString() - Method in class org.apache.hadoop.yarn.api.records.Resource
     
    toStrings() - Method in class org.apache.hadoop.io.ArrayWritable
     
    TotalOrderPartitioner<K extends WritableComparable<?>,V> - Class in org.apache.hadoop.mapred.lib
    Partitioner effecting a total order by reading split points from an externally generated source.
    TotalOrderPartitioner() - Constructor for class org.apache.hadoop.mapred.lib.TotalOrderPartitioner
     
    TotalOrderPartitioner<K extends WritableComparable<?>,V> - Class in org.apache.hadoop.mapreduce.lib.partition
    Partitioner effecting a total order by reading split points from an externally generated source.
    TotalOrderPartitioner() - Constructor for class org.apache.hadoop.mapreduce.lib.partition.TotalOrderPartitioner
     
    toUri() - Method in class org.apache.hadoop.fs.Path
    Convert this to a URI.
    Trash - Class in org.apache.hadoop.fs
    Provides a trash facility which supports pluggable Trash policies.
    Trash(Configuration) - Constructor for class org.apache.hadoop.fs.Trash
    Construct a trash can accessor.
    Trash(FileSystem, Configuration) - Constructor for class org.apache.hadoop.fs.Trash
    Construct a trash can accessor for the FileSystem provided.
    trash - Variable in class org.apache.hadoop.fs.TrashPolicy
     
    TrashPolicy - Class in org.apache.hadoop.fs
    This interface is used for implementing different Trash policies.
    TrashPolicy() - Constructor for class org.apache.hadoop.fs.TrashPolicy
     
    truncate() - Method in class org.apache.hadoop.record.Buffer
    Deprecated.
    Change the capacity of the backing store to be the same as the current count of buffer.
    tryDivide(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.mapreduce.lib.db.BigDecimalSplitter
    Divide numerator by denominator.
    TupleWritable - Class in org.apache.hadoop.mapred.join
    Writable type storing multiple Writables.
    TupleWritable() - Constructor for class org.apache.hadoop.mapred.join.TupleWritable
    Create an empty tuple with no allocated storage for writables.
    TupleWritable(Writable[]) - Constructor for class org.apache.hadoop.mapred.join.TupleWritable
    Initialize tuple with storage; unknown whether any of them contain "written" values.
    TupleWritable - Class in org.apache.hadoop.mapreduce.lib.join
    Writable type storing multiple Writables.
    TupleWritable() - Constructor for class org.apache.hadoop.mapreduce.lib.join.TupleWritable
    Create an empty tuple with no allocated storage for writables.
    TupleWritable(Writable[]) - Constructor for class org.apache.hadoop.mapreduce.lib.join.TupleWritable
    Initialize tuple with storage; unknown whether any of them contain "written" values.
    TwoDArrayWritable - Class in org.apache.hadoop.io
    A Writable for 2D arrays containing a matrix of instances of a class.
    TwoDArrayWritable(Class) - Constructor for class org.apache.hadoop.io.TwoDArrayWritable
     
    TwoDArrayWritable(Class, Writable[][]) - Constructor for class org.apache.hadoop.io.TwoDArrayWritable
     
    type() - Method in class org.apache.hadoop.metrics2.AbstractMetric
    Get the type of the metric
    Type() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
    Deprecated.
     
    TYPE_SEPARATOR - Static variable in interface org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorDescriptor
     
    TYPE_SEPARATOR - Static variable in interface org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorDescriptor
     
    TypeID - Class in org.apache.hadoop.record.meta
    Deprecated.
    Replaced by Avro.
    typeVal - Variable in class org.apache.hadoop.record.meta.TypeID
    Deprecated.
     

    U

    UMASK_LABEL - Static variable in class org.apache.hadoop.fs.permission.FsPermission
     
    UNINITIALIZED_MEMORY_VALUE - Static variable in class org.apache.hadoop.mapred.ClusterStatus
     
    UNIQ_VALUE_COUNT - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
     
    UNIQ_VALUE_COUNT - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
     
    UniqValueCount - Class in org.apache.hadoop.mapred.lib.aggregate
    This class implements a value aggregator that dedupes a sequence of objects.
    UniqValueCount() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.UniqValueCount
    the default constructor
    UniqValueCount(long) - Constructor for class org.apache.hadoop.mapred.lib.aggregate.UniqValueCount
    constructor
    UniqValueCount - Class in org.apache.hadoop.mapreduce.lib.aggregate
    This class implements a value aggregator that dedupes a sequence of objects.
    UniqValueCount() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
    the default constructor
    UniqValueCount(long) - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
    constructor
    UNPACK_JAR_PATTERN_DEFAULT - Static variable in class org.apache.hadoop.mapred.JobConf
    Pattern for the default unpacking behavior for job jars
    unregister(ObjectName) - Static method in class org.apache.hadoop.metrics2.util.MBeans
     
    unregisterUpdater(Updater) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
    Removes a callback, if it exists.
    unregisterUpdater(Updater) - Method in class org.apache.hadoop.metrics.spi.CompositeContext
     
    unset(String) - Method in class org.apache.hadoop.conf.Configuration
    Unset a previously set property.
    UnsupportedFileSystemException - Exception in org.apache.hadoop.fs
    File system for a given file system name/scheme is not supported
    UnsupportedFileSystemException(String) - Constructor for exception org.apache.hadoop.fs.UnsupportedFileSystemException
    Constructs exception with the specified detail message.
    unTar(File, File) - Static method in class org.apache.hadoop.fs.FileUtil
    Given a Tar File as input it will untar the file in a the untar directory passed as the second parameter This utility will untar ".tar" files and ".tar.gz","tgz" files.
    unZip(File, File) - Static method in class org.apache.hadoop.fs.FileUtil
    Given a File input it will unzip the file in a the unzip directory passed as the second parameter
    update(MetricsRecordImpl) - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
    Called by MetricsRecordImpl.update().
    update() - Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
    Updates the table of buffered data which is to be sent periodically.
    update(MetricsRecordImpl) - Method in class org.apache.hadoop.metrics.spi.NullContext
    Do-nothing version of update
    update(MetricsRecordImpl) - Method in class org.apache.hadoop.metrics.spi.NullContextWithUpdateThread
    Do-nothing version of update
    update(MetricsRecord, boolean) - Method in class org.apache.hadoop.metrics2.util.MetricsCache
    Update the cache and return the current cached record
    update(MetricsRecord) - Method in class org.apache.hadoop.metrics2.util.MetricsCache
    Update the cache and return the current cache record
    update(byte[], int, int) - Method in class org.apache.hadoop.util.PureJavaCrc32
    update(int) - Method in class org.apache.hadoop.util.PureJavaCrc32
    update(byte[], int, int) - Method in class org.apache.hadoop.util.PureJavaCrc32C
    update(int) - Method in class org.apache.hadoop.util.PureJavaCrc32C
    updateConnectAddr(String, InetSocketAddress) - Method in class org.apache.hadoop.conf.Configuration
    Set the socket address a client can use to connect for the name property as a host:port.
    UpdateLineColumn(char) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    UPPER_LIMIT_ON_TASK_VMEM_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
    Deprecated. 
    upperBound(List<? extends T>, T, Comparator<? super T>) - Static method in class org.apache.hadoop.io.file.tfile.Utils
    Upper bound binary search.
    upperBound(List<? extends Comparable<? super T>>, T) - Static method in class org.apache.hadoop.io.file.tfile.Utils
    Upper bound binary search.
    URL - Interface in org.apache.hadoop.yarn.api.records
    URL represents a serializable URL.
    URL_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
    JDBC Database access URL
    URL_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
    JDBC Database access URL
    usage() - Static method in class org.apache.hadoop.record.compiler.generated.Rcc
    Deprecated.
     
    USED_GENERIC_PARSER - Static variable in class org.apache.hadoop.mapreduce.Job
     
    USER_JAR - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
     
    UserDefinedValueAggregatorDescriptor - Class in org.apache.hadoop.mapred.lib.aggregate
    This class implements a wrapper for a user defined value aggregator descriptor.
    UserDefinedValueAggregatorDescriptor(String, JobConf) - Constructor for class org.apache.hadoop.mapred.lib.aggregate.UserDefinedValueAggregatorDescriptor
     
    UserDefinedValueAggregatorDescriptor - Class in org.apache.hadoop.mapreduce.lib.aggregate
    This class implements a wrapper for a user defined value aggregator descriptor.
    UserDefinedValueAggregatorDescriptor(String, Configuration) - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.UserDefinedValueAggregatorDescriptor
     
    USERNAME_PROPERTY - Static variable in class org.apache.hadoop.mapred.lib.db.DBConfiguration
    User name to access the database
    USERNAME_PROPERTY - Static variable in class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
    User name to access the database
    USTRING_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
    Deprecated.
     
    utf8Length(String) - Static method in class org.apache.hadoop.io.Text
    For the given string, returns the number of UTF-8 bytes required to encode the string.
    util() - Method in class org.apache.hadoop.fs.FileContext
     
    Util - Class in org.apache.hadoop.metrics.spi
    Static utility methods
    Utils - Class in org.apache.hadoop.io.file.tfile
    Supporting Utility classes used by TFile, and shared by users of TFile.
    Utils - Class in org.apache.hadoop.mapred
    A utility class.
    Utils() - Constructor for class org.apache.hadoop.mapred.Utils
     
    Utils - Class in org.apache.hadoop.record.meta
    Deprecated.
    Replaced by Avro.
    Utils - Class in org.apache.hadoop.record
    Deprecated.
    Replaced by Avro.

    V

    validate(EnumSet<CreateFlag>) - Static method in enum org.apache.hadoop.fs.CreateFlag
    Validate the CreateFlag and throw exception if it is invalid
    validate(Object, boolean, EnumSet<CreateFlag>) - Static method in enum org.apache.hadoop.fs.CreateFlag
    Validate the CreateFlag for create operation
    validateUTF8(byte[]) - Static method in class org.apache.hadoop.io.Text
    Check if a byte array contains valid utf-8
    validateUTF8(byte[], int, int) - Static method in class org.apache.hadoop.io.Text
    Check to see if a byte array is valid utf-8
    value - Variable in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
     
    value() - Method in class org.apache.hadoop.metrics2.AbstractMetric
    Get the value of the metric
    value() - Method in class org.apache.hadoop.metrics2.lib.MutableCounterInt
     
    value() - Method in class org.apache.hadoop.metrics2.lib.MutableCounterLong
     
    value() - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeInt
     
    value() - Method in class org.apache.hadoop.metrics2.lib.MutableGaugeLong
     
    value() - Method in class org.apache.hadoop.metrics2.MetricsTag
    Get the value of the tag
    VALUE_CLASS - Static variable in class org.apache.hadoop.mapreduce.lib.output.SequenceFileAsBinaryOutputFormat
     
    VALUE_HISTOGRAM - Static variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
     
    VALUE_HISTOGRAM - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
     
    ValueAggregator<E> - Interface in org.apache.hadoop.mapred.lib.aggregate
    This interface defines the minimal protocol for value aggregators.
    ValueAggregator<E> - Interface in org.apache.hadoop.mapreduce.lib.aggregate
    This interface defines the minimal protocol for value aggregators.
    ValueAggregatorBaseDescriptor - Class in org.apache.hadoop.mapred.lib.aggregate
    This class implements the common functionalities of the subclasses of ValueAggregatorDescriptor class.
    ValueAggregatorBaseDescriptor() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
     
    ValueAggregatorBaseDescriptor - Class in org.apache.hadoop.mapreduce.lib.aggregate
    This class implements the common functionalities of the subclasses of ValueAggregatorDescriptor class.
    ValueAggregatorBaseDescriptor() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorBaseDescriptor
     
    ValueAggregatorCombiner<K1 extends WritableComparable,V1 extends Writable> - Class in org.apache.hadoop.mapred.lib.aggregate
    This class implements the generic combiner of Aggregate.
    ValueAggregatorCombiner() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
     
    ValueAggregatorCombiner<K1 extends WritableComparable<?>,V1 extends Writable> - Class in org.apache.hadoop.mapreduce.lib.aggregate
    This class implements the generic combiner of Aggregate.
    ValueAggregatorCombiner() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorCombiner
     
    ValueAggregatorDescriptor - Interface in org.apache.hadoop.mapred.lib.aggregate
    This interface defines the contract a value aggregator descriptor must support.
    ValueAggregatorDescriptor - Interface in org.apache.hadoop.mapreduce.lib.aggregate
    This interface defines the contract a value aggregator descriptor must support.
    ValueAggregatorJob - Class in org.apache.hadoop.mapred.lib.aggregate
    This is the main class for creating a map/reduce job using Aggregate framework.
    ValueAggregatorJob() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
     
    ValueAggregatorJob - Class in org.apache.hadoop.mapreduce.lib.aggregate
    This is the main class for creating a map/reduce job using Aggregate framework.
    ValueAggregatorJob() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
     
    ValueAggregatorJobBase<K1 extends WritableComparable,V1 extends Writable> - Class in org.apache.hadoop.mapred.lib.aggregate
    This abstract class implements some common functionalities of the the generic mapper, reducer and combiner classes of Aggregate.
    ValueAggregatorJobBase() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
     
    ValueAggregatorJobBase<K1 extends WritableComparable<?>,V1 extends Writable> - Class in org.apache.hadoop.mapreduce.lib.aggregate
    This abstract class implements some common functionalities of the the generic mapper, reducer and combiner classes of Aggregate.
    ValueAggregatorJobBase() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
     
    ValueAggregatorMapper<K1 extends WritableComparable,V1 extends Writable> - Class in org.apache.hadoop.mapred.lib.aggregate
    This class implements the generic mapper of Aggregate.
    ValueAggregatorMapper() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorMapper
     
    ValueAggregatorMapper<K1 extends WritableComparable<?>,V1 extends Writable> - Class in org.apache.hadoop.mapreduce.lib.aggregate
    This class implements the generic mapper of Aggregate.
    ValueAggregatorMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorMapper
     
    ValueAggregatorReducer<K1 extends WritableComparable,V1 extends Writable> - Class in org.apache.hadoop.mapred.lib.aggregate
    This class implements the generic reducer of Aggregate.
    ValueAggregatorReducer() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorReducer
     
    ValueAggregatorReducer<K1 extends WritableComparable<?>,V1 extends Writable> - Class in org.apache.hadoop.mapreduce.lib.aggregate
    This class implements the generic reducer of Aggregate.
    ValueAggregatorReducer() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorReducer
     
    ValueHistogram - Class in org.apache.hadoop.mapred.lib.aggregate
    This class implements a value aggregator that computes the histogram of a sequence of strings.
    ValueHistogram() - Constructor for class org.apache.hadoop.mapred.lib.aggregate.ValueHistogram
     
    ValueHistogram - Class in org.apache.hadoop.mapreduce.lib.aggregate
    This class implements a value aggregator that computes the histogram of a sequence of strings.
    ValueHistogram() - Constructor for class org.apache.hadoop.mapreduce.lib.aggregate.ValueHistogram
     
    valueOf(String) - Static method in enum org.apache.hadoop.fs.CreateFlag
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in class org.apache.hadoop.fs.permission.FsPermission
    Create a FsPermission from a Unix symbolic permission string
    valueOf(String) - Static method in enum org.apache.hadoop.mapred.JobPriority
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapred.join.Parser.TType
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapred.TaskCompletionEvent.Status
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.JobCounter
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.JobPriority
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.lib.input.FileInputFormatCounter
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.lib.join.Parser.TType
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.lib.output.FileOutputFormatCounter
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.QueueState
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.TaskCompletionEvent.Status
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.TaskCounter
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapreduce.TaskType
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.metrics2.lib.DefaultMetricsSystem
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.yarn.api.records.ApplicationAccessType
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.yarn.api.records.FinalApplicationStatus
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.yarn.api.records.LocalResourceType
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.yarn.api.records.LocalResourceVisibility
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.yarn.api.records.QueueACL
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.yarn.api.records.QueueState
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.yarn.api.records.YarnApplicationState
    Returns the enum constant of this type with the specified name.
    values() - Static method in enum org.apache.hadoop.fs.CreateFlag
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Method in class org.apache.hadoop.io.MapWritable
    values() - Method in class org.apache.hadoop.io.SortedMapWritable
    values() - Static method in enum org.apache.hadoop.mapred.JobPriority
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.mapred.join.Parser.TType
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.mapred.TaskCompletionEvent.Status
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.mapreduce.JobCounter
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.mapreduce.JobPriority
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.mapreduce.lib.input.FileInputFormatCounter
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.mapreduce.lib.join.Parser.TType
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.mapreduce.lib.output.FileOutputFormatCounter
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.mapreduce.QueueState
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.mapreduce.TaskCompletionEvent.Status
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.mapreduce.TaskCounter
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.mapreduce.TaskType
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.metrics2.lib.DefaultMetricsSystem
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.yarn.api.records.ApplicationAccessType
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.yarn.api.records.FinalApplicationStatus
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.yarn.api.records.LocalResourceType
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.yarn.api.records.LocalResourceVisibility
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.yarn.api.records.QueueACL
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.yarn.api.records.QueueState
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.yarn.api.records.YarnApplicationState
    Returns an array containing the constants of this enum type, in the order they are declared.
    Vector() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
    Deprecated.
     
    VECTOR_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
    Deprecated.
     
    VectorTypeID - Class in org.apache.hadoop.record.meta
    Deprecated.
    Replaced by Avro.
    VectorTypeID(TypeID) - Constructor for class org.apache.hadoop.record.meta.VectorTypeID
    Deprecated.
     
    VersionedWritable - Class in org.apache.hadoop.io
    A base class for Writables that provides version checking.
    VersionedWritable() - Constructor for class org.apache.hadoop.io.VersionedWritable
     
    VersionMismatchException - Exception in org.apache.hadoop.fs.s3
    Thrown when Hadoop cannot read the version of the data stored in S3FileSystem.
    VersionMismatchException(String, String) - Constructor for exception org.apache.hadoop.fs.s3.VersionMismatchException
     
    VersionMismatchException - Exception in org.apache.hadoop.io
    Thrown by VersionedWritable.readFields(DataInput) when the version of an object being read does not match the current implementation version as returned by VersionedWritable.getVersion().
    VersionMismatchException(byte, byte) - Constructor for exception org.apache.hadoop.io.VersionMismatchException
     
    ViewFileSystem - Class in org.apache.hadoop.fs.viewfs
    ViewFileSystem (extends the FileSystem interface) implements a client-side mount table.
    ViewFileSystem() - Constructor for class org.apache.hadoop.fs.viewfs.ViewFileSystem
    This is the constructor with the signature needed by FileSystem.createFileSystem(URI, Configuration) After this constructor is called initialize() is called.
    ViewFileSystem(Configuration) - Constructor for class org.apache.hadoop.fs.viewfs.ViewFileSystem
    Convenience Constructor for apps to call directly
    ViewFs - Class in org.apache.hadoop.fs.viewfs
    ViewFs (extends the AbstractFileSystem interface) implements a client-side mount table.
    ViewFs(Configuration) - Constructor for class org.apache.hadoop.fs.viewfs.ViewFs
     
    VIEWFS_SCHEME - Static variable in interface org.apache.hadoop.fs.FsConstants
     
    VIEWFS_URI - Static variable in interface org.apache.hadoop.fs.FsConstants
    ViewFs: viewFs file system (ie the mount file system on client side)
    VIntWritable - Class in org.apache.hadoop.io
    A WritableComparable for integer values stored in variable-length format.
    VIntWritable() - Constructor for class org.apache.hadoop.io.VIntWritable
     
    VIntWritable(int) - Constructor for class org.apache.hadoop.io.VIntWritable
     
    visit(MetricsVisitor) - Method in class org.apache.hadoop.metrics2.AbstractMetric
    Accept a visitor interface
    VLongWritable - Class in org.apache.hadoop.io
    A WritableComparable for longs in a variable-length format.
    VLongWritable() - Constructor for class org.apache.hadoop.io.VLongWritable
     
    VLongWritable(long) - Constructor for class org.apache.hadoop.io.VLongWritable
     

    W

    waitForCompletion() - Method in interface org.apache.hadoop.mapred.RunningJob
    Blocks until the job is complete.
    waitForCompletion(boolean) - Method in class org.apache.hadoop.mapreduce.Job
    Submit the job to the cluster and wait for it to finish.
    WAITING - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
     
    weakIntern(String) - Static method in class org.apache.hadoop.util.StringInterner
    Interns and returns a reference to the representative instance for any of a collection of string instances that are equal to each other.
    WithinMultiLineComment - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
    Deprecated.
     
    WithinOneLineComment - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
    Deprecated.
     
    WrappedMapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce.lib.map
    A Mapper which wraps a given one to allow custom Mapper.Context implementations.
    WrappedMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.map.WrappedMapper
     
    WrappedRecordReader<K extends WritableComparable,U extends Writable> - Class in org.apache.hadoop.mapred.join
    Proxy class for a RecordReader participating in the join framework.
    WrappedRecordReader<K extends WritableComparable<?>,U extends Writable> - Class in org.apache.hadoop.mapreduce.lib.join
    Proxy class for a RecordReader participating in the join framework.
    WrappedRecordReader(int) - Constructor for class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
     
    WrappedReducer<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapreduce.lib.reduce
    A Reducer which wraps a given one to allow for custom Reducer.Context implementations.
    WrappedReducer() - Constructor for class org.apache.hadoop.mapreduce.lib.reduce.WrappedReducer
     
    Writable - Interface in org.apache.hadoop.io
    A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
    WritableComparable<T> - Interface in org.apache.hadoop.io
    A Writable which is also Comparable.
    WritableComparator - Class in org.apache.hadoop.io
    A Comparator for WritableComparables.
    WritableComparator() - Constructor for class org.apache.hadoop.io.WritableComparator
     
    WritableComparator(Class<? extends WritableComparable>) - Constructor for class org.apache.hadoop.io.WritableComparator
    Construct for a WritableComparable implementation.
    WritableComparator(Class<? extends WritableComparable>, boolean) - Constructor for class org.apache.hadoop.io.WritableComparator
     
    WritableFactories - Class in org.apache.hadoop.io
    Factories for non-public writables.
    WritableFactory - Interface in org.apache.hadoop.io
    A factory for a class of Writable.
    WritableSerialization - Class in org.apache.hadoop.io.serializer
    WritableSerialization() - Constructor for class org.apache.hadoop.io.serializer.WritableSerialization
     
    WritableUtils - Class in org.apache.hadoop.io
     
    WritableUtils() - Constructor for class org.apache.hadoop.io.WritableUtils
     
    write(DataOutput) - Method in class org.apache.hadoop.conf.Configuration
     
    write(DataOutput) - Method in class org.apache.hadoop.fs.BlockLocation
    Implement write of Writable
    write(DataOutput) - Method in class org.apache.hadoop.fs.ContentSummary
    Serialize the fields of this object to out.
    write(DataOutput) - Method in class org.apache.hadoop.fs.FileStatus
     
    write(DataOutput) - Method in class org.apache.hadoop.fs.FsServerDefaults
     
    write(DataOutput) - Method in class org.apache.hadoop.fs.FsStatus
     
    write(DataOutput) - Method in class org.apache.hadoop.fs.permission.FsPermission
    Serialize the fields of this object to out.
    write(DataOutput) - Method in class org.apache.hadoop.io.AbstractMapWritable
    Serialize the fields of this object to out.
    write(DataOutput) - Method in class org.apache.hadoop.io.ArrayPrimitiveWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.ArrayWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.BooleanWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.BytesWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.ByteWritable
     
    write(byte[], int, int) - Method in class org.apache.hadoop.io.compress.BlockCompressorStream
    Write the data provided to the compression codec, compressing no more than the buffer size less the compression overhead as specified during construction for each block.
    write(byte[], int, int) - Method in class org.apache.hadoop.io.compress.CompressionOutputStream
    Write compressed bytes to the stream.
    write(byte[], int, int) - Method in class org.apache.hadoop.io.compress.CompressorStream
     
    write(int) - Method in class org.apache.hadoop.io.compress.CompressorStream
     
    write(DataOutput) - Method in class org.apache.hadoop.io.CompressedWritable
     
    write(int) - Method in class org.apache.hadoop.io.DataOutputOutputStream
     
    write(byte[], int, int) - Method in class org.apache.hadoop.io.DataOutputOutputStream
     
    write(byte[]) - Method in class org.apache.hadoop.io.DataOutputOutputStream
     
    write(DataOutput) - Method in class org.apache.hadoop.io.DoubleWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.EnumSetWritable
    Serialize the fields of this object to out.
    write(DataOutput) - Method in class org.apache.hadoop.io.FloatWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.GenericWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.IntWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.LongWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.MapWritable
    Serialize the fields of this object to out.
    write(DataOutput) - Method in class org.apache.hadoop.io.MD5Hash
     
    write(DataOutput) - Method in class org.apache.hadoop.io.NullWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.ObjectWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.ShortWritable
    write short value
    write(DataOutput) - Method in class org.apache.hadoop.io.SortedMapWritable
    Serialize the fields of this object to out.
    write(DataOutput) - Method in class org.apache.hadoop.io.Text
    serialize write this object to out length uses zero-compressed encoding
    write(DataOutput) - Method in class org.apache.hadoop.io.TwoDArrayWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.VersionedWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.VIntWritable
     
    write(DataOutput) - Method in class org.apache.hadoop.io.VLongWritable
     
    write(DataOutput) - Method in interface org.apache.hadoop.io.Writable
    Serialize the fields of this object to out.
    write(DataOutput) - Method in class org.apache.hadoop.mapred.ClusterStatus
     
    write(DataOutput) - Method in class org.apache.hadoop.mapred.FileSplit
     
    write(DataOutput) - Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
    Write splits in the following format.
    write(K, V) - Method in interface org.apache.hadoop.mapred.RecordWriter
    Writes a key/value pair.
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
     
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
    Write the set of groups.
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.ID
     
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.JobID
     
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.JobStatus
     
    write(PreparedStatement) - Method in interface org.apache.hadoop.mapreduce.lib.db.DBWritable
    Sets the fields of the object in the PreparedStatement.
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
     
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.lib.input.FileSplit
     
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
    Write splits in the following format.
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
    Writes each Writable to out.
    write(String, K, V) - Method in class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
    Write key and value to the namedOutput.
    write(String, K, V, String) - Method in class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
    Write key and value to baseOutputPath using the namedOutput.
    write(KEYOUT, VALUEOUT, String) - Method in class org.apache.hadoop.mapreduce.lib.output.MultipleOutputs
    Write key value to an output file name.
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.QueueAclsInfo
     
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.QueueInfo
     
    write(K, V) - Method in class org.apache.hadoop.mapreduce.RecordWriter
    Writes a key/value pair.
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.TaskAttemptID
     
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
     
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.TaskID
     
    write(KEYOUT, VALUEOUT) - Method in interface org.apache.hadoop.mapreduce.TaskInputOutputContext
    Generate an output key/value pair.
    write(DataOutput) - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
     
    write(DataOutput) - Method in class org.apache.hadoop.record.Record
    Deprecated.
     
    write(DataOutput) - Method in class org.apache.hadoop.util.bloom.BloomFilter
     
    write(DataOutput) - Method in class org.apache.hadoop.util.bloom.CountingBloomFilter
     
    write(DataOutput) - Method in class org.apache.hadoop.util.bloom.DynamicBloomFilter
     
    write(DataOutput) - Method in class org.apache.hadoop.util.bloom.RetouchedBloomFilter
     
    writeBool(boolean, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
    Deprecated.
     
    writeBool(boolean, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
    Deprecated.
     
    writeBool(boolean, String) - Method in interface org.apache.hadoop.record.RecordOutput
    Deprecated.
    Write a boolean to serialized record.
    writeBool(boolean, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
    Deprecated.
     
    writeBuffer(Buffer, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
    Deprecated.
     
    writeBuffer(Buffer, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
    Deprecated.
     
    writeBuffer(Buffer, String) - Method in interface org.apache.hadoop.record.RecordOutput
    Deprecated.
    Write a buffer to serialized record.
    writeBuffer(Buffer, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
    Deprecated.
     
    writeByte(byte, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
    Deprecated.
     
    writeByte(byte, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
    Deprecated.
     
    writeByte(byte, String) - Method in interface org.apache.hadoop.record.RecordOutput
    Deprecated.
    Write a byte to serialized record.
    writeByte(byte, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
    Deprecated.
     
    writeCompressed(DataOutput) - Method in class org.apache.hadoop.io.CompressedWritable
    Subclasses implement this instead of CompressedWritable.write(DataOutput).
    writeCompressedByteArray(DataOutput, byte[]) - Static method in class org.apache.hadoop.io.WritableUtils
     
    writeCompressedString(DataOutput, String) - Static method in class org.apache.hadoop.io.WritableUtils
     
    writeCompressedStringArray(DataOutput, String[]) - Static method in class org.apache.hadoop.io.WritableUtils
     
    writeDouble(double, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
    Deprecated.
     
    writeDouble(double, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
    Deprecated.
     
    writeDouble(double, String) - Method in interface org.apache.hadoop.record.RecordOutput
    Deprecated.
    Write a double precision floating point number to serialized record.
    writeDouble(double, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
    Deprecated.
     
    writeEnum(DataOutput, Enum<?>) - Static method in class org.apache.hadoop.io.WritableUtils
    writes String value of enum to DataOutput.
    writeFloat(float, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
    Deprecated.
     
    writeFloat(float, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
    Deprecated.
     
    writeFloat(float, String) - Method in interface org.apache.hadoop.record.RecordOutput
    Deprecated.
    Write a single-precision float to serialized record.
    writeFloat(float, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
    Deprecated.
     
    writeInt(int, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
    Deprecated.
     
    writeInt(int, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
    Deprecated.
     
    writeInt(int, String) - Method in interface org.apache.hadoop.record.RecordOutput
    Deprecated.
    Write an integer to serialized record.
    writeInt(int, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
    Deprecated.
     
    writeLong(long, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
    Deprecated.
     
    writeLong(long, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
    Deprecated.
     
    writeLong(long, String) - Method in interface org.apache.hadoop.record.RecordOutput
    Deprecated.
    Write a long integer to serialized record.
    writeLong(long, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
    Deprecated.
     
    writeObject(DataOutput, Object, Class, Configuration) - Static method in class org.apache.hadoop.io.ObjectWritable
    Write a Writable, String, primitive type, or an array of the preceding.
    writeObject(DataOutput, Object, Class, Configuration, boolean) - Static method in class org.apache.hadoop.io.ObjectWritable
    Write a Writable, String, primitive type, or an array of the preceding.
    writePartitionFile(JobConf, InputSampler.Sampler<K, V>) - Static method in class org.apache.hadoop.mapred.lib.InputSampler
     
    writePartitionFile(Job, InputSampler.Sampler<K, V>) - Static method in class org.apache.hadoop.mapreduce.lib.partition.InputSampler
    Write a partition file for the given job, using the Sampler provided.
    writeString(DataOutput, String) - Static method in class org.apache.hadoop.io.file.tfile.Utils
    Write a String as a VInt n, followed by n Bytes as in Text format.
    writeString(DataOutput, String) - Static method in class org.apache.hadoop.io.Text
    Write a UTF8 encoded string to out
    writeString(DataOutput, String) - Static method in class org.apache.hadoop.io.WritableUtils
     
    writeString(String, String) - Method in class org.apache.hadoop.record.BinaryRecordOutput
    Deprecated.
     
    writeString(String, String) - Method in class org.apache.hadoop.record.CsvRecordOutput
    Deprecated.
     
    writeString(String, String) - Method in interface org.apache.hadoop.record.RecordOutput
    Deprecated.
    Write a unicode string to serialized record.
    writeString(String, String) - Method in class org.apache.hadoop.record.XmlRecordOutput
    Deprecated.
     
    writeStringArray(DataOutput, String[]) - Static method in class org.apache.hadoop.io.WritableUtils
     
    writeVInt(DataOutput, int) - Static method in class org.apache.hadoop.io.file.tfile.Utils
    Encoding an integer into a variable-length encoding format.
    writeVInt(DataOutput, int) - Static method in class org.apache.hadoop.io.WritableUtils
    Serializes an integer to a binary stream with zero-compressed encoding.
    writeVInt(DataOutput, int) - Static method in class org.apache.hadoop.record.Utils
    Deprecated.
    Serializes an int to a binary stream with zero-compressed encoding.
    writeVLong(DataOutput, long) - Static method in class org.apache.hadoop.io.file.tfile.Utils
    Encoding a Long integer into a variable-length encoding format.
    writeVLong(DataOutput, long) - Static method in class org.apache.hadoop.io.WritableUtils
    Serializes a long to a binary stream with zero-compressed encoding.
    writeVLong(DataOutput, long) - Static method in class org.apache.hadoop.record.Utils
    Deprecated.
    Serializes a long to a binary stream with zero-compressed encoding.
    writeXml(OutputStream) - Method in class org.apache.hadoop.conf.Configuration
    Write out the non-default properties in this configuration to the given OutputStream.
    writeXml(Writer) - Method in class org.apache.hadoop.conf.Configuration
    Write out the non-default properties in this configuration to the given Writer.
    written - Variable in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
     

    X

    xdr_int(int) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
    Puts an integer into the buffer as 4 bytes, big-endian.
    xdr_string(String) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
    Puts a string into the buffer by first writing the size of the string as an int, followed by the bytes of the string, padded if necessary to a multiple of 4.
    XmlRecordInput - Class in org.apache.hadoop.record
    Deprecated.
    Replaced by Avro.
    XmlRecordInput(InputStream) - Constructor for class org.apache.hadoop.record.XmlRecordInput
    Deprecated.
    Creates a new instance of XmlRecordInput
    XmlRecordOutput - Class in org.apache.hadoop.record
    Deprecated.
    Replaced by Avro.
    XmlRecordOutput(OutputStream) - Constructor for class org.apache.hadoop.record.XmlRecordOutput
    Deprecated.
    Creates a new instance of XmlRecordOutput
    xor(Filter) - Method in class org.apache.hadoop.util.bloom.BloomFilter
     
    xor(Filter) - Method in class org.apache.hadoop.util.bloom.CountingBloomFilter
     
    xor(Filter) - Method in class org.apache.hadoop.util.bloom.DynamicBloomFilter
     

    Y

    YarnApplicationState - Enum in org.apache.hadoop.yarn.api.records
    Ennumeration of various states of an ApplicationMaster.
    YarnClient - Interface in org.apache.hadoop.yarn.client
     
    YarnClient - Interface in org.hadoop.yarn.client
     
    YarnClientImpl - Class in org.apache.hadoop.yarn.client
     
    YarnClientImpl() - Constructor for class org.apache.hadoop.yarn.client.YarnClientImpl
     
    YarnClientImpl - Class in org.hadoop.yarn.client
     
    YarnClientImpl() - Constructor for class org.hadoop.yarn.client.YarnClientImpl
     
    YarnClusterMetrics - Interface in org.apache.hadoop.yarn.api.records
    YarnClusterMetrics represents cluster metrics.
    A B C D E F G H I J K L M N O P Q R S T U V W X Y 

    Copyright © 2014 Apache Software Foundation. All Rights Reserved.