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 Z 

A

ABORTED - Static variable in class org.apache.hadoop.yarn.api.records.ContainerExitStatus
Containers killed by the framework, either due to being released by the application or being 'lost' due to node failures etc.
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.
AbstractEvent<TYPE extends Enum<TYPE>> - Class in org.apache.hadoop.yarn.event
Parent class of all the events.
AbstractEvent(TYPE) - Constructor for class org.apache.hadoop.yarn.event.AbstractEvent
 
AbstractEvent(TYPE, long) - Constructor for class org.apache.hadoop.yarn.event.AbstractEvent
 
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.
AbstractLivelinessMonitor<O> - Class in org.apache.hadoop.yarn.util
A simple liveliness monitor with which clients can register, trust the component to monitor liveliness, get a call-back on expiry and then finally unregister.
AbstractLivelinessMonitor(String, Clock) - Constructor for class org.apache.hadoop.yarn.util.AbstractLivelinessMonitor
 
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
AbstractService - Class in org.apache.hadoop.service
This is the base implementation class for services.
AbstractService(String) - Constructor for class org.apache.hadoop.service.AbstractService
Construct the service.
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
access(Path, FsAction) - Method in class org.apache.hadoop.fs.AbstractFileSystem
The specification of this method matches that of FileContext.access(Path, FsAction) except that an UnresolvedLinkException may be thrown if a symlink is encountered in the path.
access(Path, FsAction) - Method in class org.apache.hadoop.fs.FileContext
Checks if the user can access a path.
access(Path, FsAction) - Method in class org.apache.hadoop.fs.FileSystem
Checks if the user can access a path.
access(Path, FsAction) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
access(Path, FsAction) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
access(Path, FsAction) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
ACCESS_DENIED - Static variable in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
Error code returned if the user is denied to access the timeline data
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).
AccessControlList - Class in org.apache.hadoop.security.authorize
Class representing a configured access control list.
AccessControlList() - Constructor for class org.apache.hadoop.security.authorize.AccessControlList
This constructor exists primarily for AccessControlList to be Writable.
AccessControlList(String) - Constructor for class org.apache.hadoop.security.authorize.AccessControlList
Construct a new ACL from a String representation of the same.
AccessControlList(String, String) - Constructor for class org.apache.hadoop.security.authorize.AccessControlList
Construct a new ACL from String representation of users and groups The arguments are comma separated lists
AclEntry - Class in org.apache.hadoop.fs.permission
Defines a single entry in an ACL.
AclEntryScope - Enum in org.apache.hadoop.fs.permission
Specifies the scope or intended usage of an ACL entry.
AclEntryType - Enum in org.apache.hadoop.fs.permission
Specifies the type of an ACL entry.
aclSpecToString(List<AclEntry>) - Static method in class org.apache.hadoop.fs.permission.AclEntry
Convert a List of AclEntries into a string - the reverse of parseAclSpec.
AclStatus - Class in org.apache.hadoop.fs.permission
An AclStatus contains the ACL information of a specific file.
acquireLease(Path) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
Get a self-renewing lease on the specified file.
activateOptions() - Method in class org.apache.hadoop.yarn.ContainerLogAppender
 
activateOptions() - Method in class org.apache.hadoop.yarn.ContainerRollingLogAppender
 
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(long) - Method in class org.apache.hadoop.metrics2.lib.MutableQuantiles
 
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.
addArchiveToClassPath(Path) - Method in class org.apache.hadoop.mapreduce.Job
Add an archive path to the current set of classpath entries.
addCacheArchive(URI) - Method in class org.apache.hadoop.mapreduce.Job
Add a archives to be localized
addCacheFile(URI) - Method in class org.apache.hadoop.mapreduce.Job
Add a file to be localized
addConfigurationPair(String, String) - Method in class org.apache.hadoop.tracing.SpanReceiverInfoBuilder
 
addContainerRequest(T) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
Request containers for resources before calling allocate
addContainerRequest(T) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
Request containers for resources before calling allocate
addCounter(Counters.Counter) - Method in class org.apache.hadoop.mapred.Counters.Group
 
addCounter(String, String, long) - Method in class org.apache.hadoop.mapred.Counters.Group
 
addCounter(T) - Method in 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(Job) - Method in class org.apache.hadoop.mapred.jobcontrol.Job
Add a job to this jobs' dependency list.
addDependingJob(ControlledJob) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
Add a job to this jobs' dependency list.
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 global 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 global deprecation map when no custom message is provided.
addDeprecations(Configuration.DeprecationDelta[]) - Static method in class org.apache.hadoop.conf.Configuration
Adds a set of deprecated keys to the global deprecations.
addDomain(TimelineDomain) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomains
Add a single domain into the existing domain list
addDomains(List<TimelineDomain>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomains
All a list of domains into the existing domain list
addEntities(List<TimelineEntity>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntities
All a list of entities into the existing entity list
addEntity(TimelineEntity) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntities
Add a single entity into the existing entity list
addError(TimelinePutResponse.TimelinePutError) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse
Add a single TimelinePutResponse.TimelinePutError instance into the existing list
addErrors(List<TimelinePutResponse.TimelinePutError>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse
Add a list of TimelinePutResponse.TimelinePutError instances into the existing list
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
addEvent(TimelineEvent) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Add a single event related to the entity to the existing event list
addEvent(TimelineEvents.EventsOfOneEntity) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents
Add a single TimelineEvents.EventsOfOneEntity instance into the existing list
addEvent(TimelineEvent) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents.EventsOfOneEntity
Add a single event to the existing event list
addEventInfo(String, Object) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
Add one piece of the information of the event to the existing information map
addEventInfo(Map<String, Object>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
Add a map of the information of the event to the existing information map
addEvents(List<TimelineEvent>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Add a list of events related to the entity to the existing event list
addEvents(List<TimelineEvents.EventsOfOneEntity>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents
Add a list of TimelineEvents.EventsOfOneEntity instances into the existing list
addEvents(List<TimelineEvent>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents.EventsOfOneEntity
Add a list of event to the existing event list
addExternalEndpoint(Endpoint) - Method in class org.apache.hadoop.registry.client.types.ServiceRecord
Add an external endpoint
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.
addFencingParameters(Map<String, String>) - Method in class org.apache.hadoop.ha.HAServiceTarget
Hook to allow subclasses to add any parameters they would like to expose to fencing implementations/scripts.
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
addGroup(String) - Method in class org.apache.hadoop.security.authorize.AccessControlList
Add group to the names of groups allowed for this service.
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.
addIfService(Object) - Method in class org.apache.hadoop.service.CompositeService
If the passed object is an instance of Service, add it to the list of services managed by this CompositeService
AddingCompositeService - Class in org.apache.hadoop.registry.server.services
Composite service that exports the add/remove methods.
AddingCompositeService(String) - Constructor for class org.apache.hadoop.registry.server.services.AddingCompositeService
 
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.
addInternalEndpoint(Endpoint) - Method in class org.apache.hadoop.registry.client.types.ServiceRecord
Add an internal endpoint
addJob(ControlledJob) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
Add a new controlled job.
addJob(Job) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
Add a new job.
addJobCollection(Collection<ControlledJob>) - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
Add a collection of jobs
addJobs(Collection<Job>) - Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
Add a collection of jobs
addLocalArchives(Configuration, String) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
addLocalFiles(Configuration, String) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
addMapper(JobConf, Class<? extends Mapper<K1, V1, K2, V2>>, Class<? extends K1>, Class<? extends V1>, Class<? extends K2>, Class<? extends V2>, boolean, JobConf) - Static method in class org.apache.hadoop.mapred.lib.ChainMapper
Adds a Mapper class to the chain job's JobConf.
addMapper(JobConf, Class<? extends Mapper<K1, V1, K2, V2>>, Class<? extends K1>, Class<? extends V1>, Class<? extends K2>, Class<? extends V2>, boolean, JobConf) - Static method in class org.apache.hadoop.mapred.lib.ChainReducer
Adds a Mapper class to the chain job's JobConf.
addMapper(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.
addOtherInfo(String, Object) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Add one piece of other information of the entity to the existing other info map
addOtherInfo(Map<String, Object>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Add a map of other information of the entity to the existing other info map
addPrimaryFilter(String, Object) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Add a single piece of primary filter to the existing primary filter map
addPrimaryFilters(Map<String, Set<Object>>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Add a map of primary filters to the existing primary filter map
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
addRelatedEntities(Map<String, Set<String>>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Add a map of related entities to the existing related entity map
addRelatedEntity(String, String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Add an entity to the existing related entity map
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.
addResource(Configuration) - Method in class org.apache.hadoop.conf.Configuration
Add a configuration resource.
ADDRESS_HOSTNAME_AND_PORT - Static variable in interface org.apache.hadoop.registry.client.types.AddressTypes
hostname/FQDN and port pair: "host/port".
ADDRESS_HOSTNAME_FIELD - Static variable in interface org.apache.hadoop.registry.client.types.AddressTypes
 
ADDRESS_OTHER - Static variable in interface org.apache.hadoop.registry.client.types.AddressTypes
Any other address: "".
ADDRESS_PATH - Static variable in interface org.apache.hadoop.registry.client.types.AddressTypes
Path /a/b/c style: "path".
ADDRESS_PORT_FIELD - Static variable in interface org.apache.hadoop.registry.client.types.AddressTypes
 
ADDRESS_URI - Static variable in interface org.apache.hadoop.registry.client.types.AddressTypes
URI entries: "uri".
ADDRESS_ZOOKEEPER - Static variable in interface org.apache.hadoop.registry.client.types.AddressTypes
Zookeeper addresses as a triple : "zktriple".
addresses - Variable in class org.apache.hadoop.registry.client.types.Endpoint
a list of address tuples —tuples whose format depends on the address type
addressType - Variable in class org.apache.hadoop.registry.client.types.Endpoint
Type of address.
AddressTypes - Interface in org.apache.hadoop.registry.client.types
Enum of address types -as integers.
addService(Service) - Method in class org.apache.hadoop.registry.server.services.AddingCompositeService
 
addService(Service) - Method in class org.apache.hadoop.service.CompositeService
Add the passed Service to the list of services managed by this CompositeService
addSpanReceiver(SpanReceiverInfo) - Method in interface org.apache.hadoop.tracing.TraceAdminProtocol
Add a new trace span receiver.
addToMap(Class<?>) - Method in class org.apache.hadoop.io.AbstractMapWritable
Add a Class to the maps if it is not already present.
addTransition(STATE, STATE, EVENTTYPE) - Method in class org.apache.hadoop.yarn.state.StateMachineFactory
 
addTransition(STATE, STATE, Set<EVENTTYPE>) - Method in class org.apache.hadoop.yarn.state.StateMachineFactory
 
addTransition(STATE, STATE, Set<EVENTTYPE>, SingleArcTransition<OPERAND, EVENT>) - Method in class org.apache.hadoop.yarn.state.StateMachineFactory
 
addTransition(STATE, STATE, EVENTTYPE, SingleArcTransition<OPERAND, EVENT>) - Method in class org.apache.hadoop.yarn.state.StateMachineFactory
 
addTransition(STATE, Set<STATE>, EVENTTYPE, MultipleArcTransition<OPERAND, EVENT, STATE>) - Method in class org.apache.hadoop.yarn.state.StateMachineFactory
 
addUser(String) - Method in class org.apache.hadoop.security.authorize.AccessControlList
Add user to the names of users allowed for this service.
addWriteAccessor(String, String) - Method in interface org.apache.hadoop.registry.client.api.RegistryOperations
Add a new write access entry to be added to node permissions in all future write operations of a session connected to a secure registry.
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.
AdminSecurityInfo - Class in org.apache.hadoop.yarn.security.admin
 
AdminSecurityInfo() - Constructor for class org.apache.hadoop.yarn.security.admin.AdminSecurityInfo
 
AggregatedLogFormat - Class in org.apache.hadoop.yarn.logaggregation
 
AggregatedLogFormat() - Constructor for class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat
 
AggregatedLogFormat.LogKey - Class in org.apache.hadoop.yarn.logaggregation
 
AggregatedLogFormat.LogKey() - Constructor for class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogKey
 
AggregatedLogFormat.LogKey(ContainerId) - Constructor for class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogKey
 
AggregatedLogFormat.LogKey(String) - Constructor for class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogKey
 
AggregatedLogFormat.LogReader - Class in org.apache.hadoop.yarn.logaggregation
 
AggregatedLogFormat.LogReader(Configuration, Path) - Constructor for class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogReader
 
aggregatorDescriptorList - Variable in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
 
aggregatorDescriptorList - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJobBase
 
AHSClient - Class in org.apache.hadoop.yarn.client.api
 
AHSClient(String) - Constructor for class org.apache.hadoop.yarn.client.api.AHSClient
 
AHSProxy<T> - Class in org.apache.hadoop.yarn.client
 
AHSProxy() - Constructor for class org.apache.hadoop.yarn.client.AHSProxy
 
allFinished() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
allocate(AllocateRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationMasterProtocol
The main interface between an ApplicationMaster and the ResourceManager.
allocate(float) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
Request additional containers and receive new container allocations.
AllocateRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The core request sent by the ApplicationMaster to the ResourceManager to obtain resources in the cluster.
AllocateRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
AllocateResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager the ApplicationMaster during resource negotiation.
AllocateResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
 
AMCommand - Enum in org.apache.hadoop.yarn.api.records
Command sent by the Resource Manager to the Application Master in the AllocateResponse
AMRMClient<T extends org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest> - Class in org.apache.hadoop.yarn.client.api
 
AMRMClient(String) - Constructor for class org.apache.hadoop.yarn.client.api.AMRMClient
 
AMRMClientAsync<T extends org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest> - Class in org.apache.hadoop.yarn.client.api.async
AMRMClientAsync handles communication with the ResourceManager and provides asynchronous updates on events such as container allocations and completions.
AMRMClientAsync(int, AMRMClientAsync.CallbackHandler) - Constructor for class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
 
AMRMClientAsync(AMRMClient<T>, int, AMRMClientAsync.CallbackHandler) - Constructor for class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
 
AMRMTokenIdentifier - Class in org.apache.hadoop.yarn.security
AMRMTokenIdentifier is the TokenIdentifier to be used by ApplicationMasters to authenticate to the ResourceManager.
AMRMTokenIdentifier() - Constructor for class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
 
AMRMTokenIdentifier(ApplicationAttemptId, int) - Constructor for class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
 
AMRMTokenSelector - Class in org.apache.hadoop.yarn.security
 
AMRMTokenSelector() - Constructor for class org.apache.hadoop.yarn.security.AMRMTokenSelector
 
and(FsAction) - Method in enum org.apache.hadoop.fs.permission.FsAction
AND operation.
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
 
ANY - Static variable in class org.apache.hadoop.yarn.api.records.ResourceRequest
The constant string representing no locality.
api - Variable in class org.apache.hadoop.registry.client.types.Endpoint
API implemented at the end of the binding
APP_SUBMIT_TIME_ENV - Static variable in interface org.apache.hadoop.yarn.api.ApplicationConstants
The environment variable for APP_SUBMIT_TIME.
appAttemptID - Variable in class org.apache.hadoop.yarn.applications.distributedshell.ApplicationMaster
 
appAttemptIdStrPrefix - Static variable in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
 
append(Path, int, Progressable) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
This optional operation is not yet supported.
append(Path, int, Progressable) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
 
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(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.RawLocalFileSystem
 
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
append(LoggingEvent) - Method in class org.apache.hadoop.yarn.ContainerLogAppender
 
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.
appIdStrPrefix - Static variable in class org.apache.hadoop.yarn.api.records.ApplicationId
 
APPLICATION_HISTORY_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The setting that controls whether application history service is enabled or not.
APPLICATION_HISTORY_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
APPLICATION_HISTORY_STORE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Application history store class
APPLICATION_MAX_TAG_LENGTH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
APPLICATION_MAX_TAGS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
APPLICATION_TYPE_LENGTH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Default application type length
APPLICATION_WEB_PROXY_BASE_ENV - Static variable in interface org.apache.hadoop.yarn.api.ApplicationConstants
The environmental variable for APPLICATION_WEB_PROXY_BASE.
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
 
ApplicationAttemptNotFoundException - Exception in org.apache.hadoop.yarn.exceptions
This exception is thrown on (GetApplicationAttemptReportRequest) API when the Application Attempt doesn't exist in Application History Server or ApplicationMasterProtocol.allocate(AllocateRequest) if application doesn't exist in RM.
ApplicationAttemptNotFoundException(Throwable) - Constructor for exception org.apache.hadoop.yarn.exceptions.ApplicationAttemptNotFoundException
 
ApplicationAttemptNotFoundException(String) - Constructor for exception org.apache.hadoop.yarn.exceptions.ApplicationAttemptNotFoundException
 
ApplicationAttemptNotFoundException(String, Throwable) - Constructor for exception org.apache.hadoop.yarn.exceptions.ApplicationAttemptNotFoundException
 
ApplicationAttemptReport - Class in org.apache.hadoop.yarn.api.records
ApplicationAttemptReport is a report of an application attempt.
ApplicationAttemptReport() - Constructor for class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
 
ApplicationClassLoader - Class in org.apache.hadoop.util
A URLClassLoader for application isolation.
ApplicationClassLoader(URL[], ClassLoader, List<String>) - Constructor for class org.apache.hadoop.util.ApplicationClassLoader
 
ApplicationClassLoader(String, ClassLoader, List<String>) - Constructor for class org.apache.hadoop.util.ApplicationClassLoader
 
ApplicationClassLoader - Class in org.apache.hadoop.yarn.util
Deprecated.
ApplicationClassLoader(URL[], ClassLoader, List<String>) - Constructor for class org.apache.hadoop.yarn.util.ApplicationClassLoader
Deprecated.
 
ApplicationClassLoader(String, ClassLoader, List<String>) - Constructor for class org.apache.hadoop.yarn.util.ApplicationClassLoader
Deprecated.
 
ApplicationClientProtocol - 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.
ApplicationConstants - Interface in org.apache.hadoop.yarn.api
This is the API for the applications comprising of constants that YARN sets up for the applications and the containers.
ApplicationHistoryProtocol - Interface in org.apache.hadoop.yarn.api
The protocol between clients and the ApplicationHistoryServer to get the information of completed applications etc.
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
 
ApplicationIdNotProvidedException - Exception in org.apache.hadoop.yarn.exceptions
Exception to be thrown when Client submit an application without providing ApplicationId in ApplicationSubmissionContext.
ApplicationIdNotProvidedException(Throwable) - Constructor for exception org.apache.hadoop.yarn.exceptions.ApplicationIdNotProvidedException
 
ApplicationIdNotProvidedException(String) - Constructor for exception org.apache.hadoop.yarn.exceptions.ApplicationIdNotProvidedException
 
ApplicationIdNotProvidedException(String, Throwable) - Constructor for exception org.apache.hadoop.yarn.exceptions.ApplicationIdNotProvidedException
 
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
 
ApplicationMasterProtocol - Interface in org.apache.hadoop.yarn.api
The protocol between a live instance of ApplicationMaster and the ResourceManager.
ApplicationNotFoundException - Exception in org.apache.hadoop.yarn.exceptions
This exception is thrown on (GetApplicationReportRequest) API when the Application doesn't exist in RM and AHS
ApplicationNotFoundException(Throwable) - Constructor for exception org.apache.hadoop.yarn.exceptions.ApplicationNotFoundException
 
ApplicationNotFoundException(String) - Constructor for exception org.apache.hadoop.yarn.exceptions.ApplicationNotFoundException
 
ApplicationNotFoundException(String, Throwable) - Constructor for exception org.apache.hadoop.yarn.exceptions.ApplicationNotFoundException
 
ApplicationReport - Class in org.apache.hadoop.yarn.api.records
ApplicationReport is a report of an application.
ApplicationReport() - Constructor for class org.apache.hadoop.yarn.api.records.ApplicationReport
 
ApplicationResourceUsageReport - Class in org.apache.hadoop.yarn.api.records
Contains various scheduling metrics to be reported by UI and CLI.
ApplicationResourceUsageReport() - Constructor for class org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
 
ApplicationsRequestScope - Enum in org.apache.hadoop.yarn.api.protocolrecords
Enumeration that controls the scope of applications fetched
ApplicationSubmissionContext - Class in org.apache.hadoop.yarn.api.records
ApplicationSubmissionContext represents all of the information needed by the ResourceManager to launch the ApplicationMaster for an application.
ApplicationSubmissionContext() - Constructor for class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
 
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.
areSymlinksEnabled() - Static method in class org.apache.hadoop.fs.FileSystem
 
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
 
asList() - Static method in enum org.apache.hadoop.fs.StorageType
 
AsyncDispatcher - Class in org.apache.hadoop.yarn.event
Dispatches Events in a separate thread.
AsyncDispatcher() - Constructor for class org.apache.hadoop.yarn.event.AsyncDispatcher
 
AsyncDispatcher(BlockingQueue<Event>) - Constructor for class org.apache.hadoop.yarn.event.AsyncDispatcher
 
ATTEMPT - Static variable in class org.apache.hadoop.mapreduce.TaskAttemptID
 
attributes() - Method in class org.apache.hadoop.registry.client.types.ServiceRecord
The map of "other" attributes set when parsing.
authenticate(URL, AuthenticatedURL.Token) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
 
authorize(UserGroupInformation, String) - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
 
authorize(UserGroupInformation, String) - Method in interface org.apache.hadoop.security.authorize.ImpersonationProvider
Authorize the superuser which is doing doAs
AUTO_FAILOVER_EMBEDDED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
AUTO_FAILOVER_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
AUTO_FAILOVER_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
AUTO_FAILOVER_ZK_BASE_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
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
 
AzureException - Exception in org.apache.hadoop.fs.azure
Thrown if there is a problem communicating with Azure Storage service.
AzureException(String) - Constructor for exception org.apache.hadoop.fs.azure.AzureException
 
AzureException(String, Throwable) - Constructor for exception org.apache.hadoop.fs.azure.AzureException
 
AzureException(Throwable) - Constructor for exception org.apache.hadoop.fs.azure.AzureException
 
AzureFileSystemInstrumentation - Class in org.apache.hadoop.fs.azure.metrics
A metrics source for the WASB file system to track all the metrics we care about for getting a clear picture of the performance/reliability/interaction of the Hadoop cluster with Azure Storage.
AzureFileSystemInstrumentation(Configuration) - Constructor for class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
 

B

backup(int) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
BadFencingConfigurationException - Exception in org.apache.hadoop.ha
Indicates that the operator has specified an invalid configuration for fencing methods.
BadFencingConfigurationException(String) - Constructor for exception org.apache.hadoop.ha.BadFencingConfigurationException
 
BadFencingConfigurationException(String, Throwable) - Constructor for exception org.apache.hadoop.ha.BadFencingConfigurationException
 
BASE_OUTPUT_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
BaseClientToAMTokenSecretManager - Class in org.apache.hadoop.yarn.security.client
A base SecretManager for AMs to extend and validate Client-RM tokens issued to clients by the RM using the underlying master-key shared by RM to the AMs on their launch.
BaseClientToAMTokenSecretManager() - Constructor for class org.apache.hadoop.yarn.security.client.BaseClientToAMTokenSecretManager
 
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
bind(String, ServiceRecord, int) - Method in interface org.apache.hadoop.registry.client.api.RegistryOperations
Bind a path in the registry to a service record
bind(String, ServiceRecord, int) - Method in class org.apache.hadoop.registry.client.impl.zk.RegistryOperationsService
 
BindFlags - Interface in org.apache.hadoop.registry.client.api
Combinable Flags to use when creating a service entry.
BindingInformation - Class in org.apache.hadoop.registry.client.impl.zk
Binding information provided by a RegistryBindingSource
BindingInformation() - Constructor for class org.apache.hadoop.registry.client.impl.zk.BindingInformation
 
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
 
blockDownloaded(long) - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Indicate that we just downloaded a block and record its latency.
BlockLocation - Class in org.apache.hadoop.fs
Represents the network location of a block, information about the hosts that contain block replicas, and other block metadata (E.g.
BlockLocation() - Constructor for class org.apache.hadoop.fs.BlockLocation
Default Constructor
BlockLocation(BlockLocation) - Constructor for class org.apache.hadoop.fs.BlockLocation
Copy 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
BlockLocation(String[], String[], String[], String[], long, long, boolean) - Constructor for class org.apache.hadoop.fs.BlockLocation
 
BlockStorageLocation - Class in org.apache.hadoop.fs
Wrapper for BlockLocation that also adds VolumeId volume location information for each replica.
BlockStorageLocation(BlockLocation, VolumeId[]) - Constructor for class org.apache.hadoop.fs.BlockStorageLocation
 
blockUploaded(long) - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Indicate that we just uploaded a block and record its latency.
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.
 
build() - Method in class org.apache.hadoop.tracing.SpanReceiverInfoBuilder
 
build() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
 
build() - Method in class org.apache.hadoop.yarn.api.records.ApplicationId
 
build() - Method in class org.apache.hadoop.yarn.api.records.ContainerId
 
build() - Method in class org.apache.hadoop.yarn.api.records.NodeId
 
build() - Method in class org.apache.hadoop.yarn.api.records.ReservationId
 
build() - Method in class org.apache.hadoop.yarn.api.records.ResourceOption
 
buildTimelineTokenService(Configuration) - Static method in class org.apache.hadoop.yarn.util.timeline.TimelineUtils
 
buildVersionName(String, int) - Static method in class org.apache.hadoop.crypto.key.KeyProvider
Build a version string from a basename and version number.
BYTE_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
ByteBufferPool - Interface in org.apache.hadoop.io
 
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

CACHE_ARCHIVES - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
CACHE_ARCHIVES_SIZES - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
CACHE_ARCHIVES_TIMESTAMPS - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
CACHE_FILES - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
CACHE_FILES_SIZES - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
CACHE_FILES_TIMESTAMPS - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
CACHE_LOCALARCHIVES - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
CACHE_LOCALFILES - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
CACHE_SYMLINK - Static variable in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
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
CacheFlag - Enum in org.apache.hadoop.fs
Specifies semantics for CacheDirective operations.
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
callbackHandler - Variable in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
 
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(URL, DelegationTokenAuthenticatedURL.Token) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
Cancels a delegation token from the server end-point.
cancelDelegationToken(URL, DelegationTokenAuthenticatedURL.Token, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
Cancels a delegation token from the server end-point.
cancelDelegationToken(URL, AuthenticatedURL.Token, Token<AbstractDelegationTokenIdentifier>) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
Cancels a delegation token from the server end-point.
cancelDelegationToken(URL, AuthenticatedURL.Token, Token<AbstractDelegationTokenIdentifier>, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
Cancels a delegation token from the server end-point.
cancelDelegationToken(Token<TimelineDelegationTokenIdentifier>) - Method in class org.apache.hadoop.yarn.client.api.TimelineClient
Cancel a timeline 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.
CancelDelegationTokenResponse - Interface in org.apache.hadoop.mapreduce.v2.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
canExecute(File) - Static method in class org.apache.hadoop.fs.FileUtil
Platform independent implementation for File.canExecute()
canonicalizeUri(URI) - Method in class org.apache.hadoop.fs.FileSystem
Canonicalize the given URI.
canonicalizeUri(URI) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
canRead(File) - Static method in class org.apache.hadoop.fs.FileUtil
Platform independent implementation for File.canRead()
CanSetDropBehind - Interface in org.apache.hadoop.fs
 
CanSetReadahead - Interface in org.apache.hadoop.fs
 
canWrite(File) - Static method in class org.apache.hadoop.fs.FileUtil
Platform independent implementation for File.canWrite()
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.
checkAllowedProtocols(Class<?>) - Method in class org.apache.hadoop.yarn.client.ClientRMProxy
 
checkAllowedProtocols(Class<?>) - Method in class org.apache.hadoop.yarn.client.RMProxy
Verify the passed protocol is supported.
checkArgs(String) - Method in interface org.apache.hadoop.ha.FenceMethod
Verify that the given fencing method's arguments are valid.
checkFencingConfigured() - Method in class org.apache.hadoop.ha.HAServiceTarget
 
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.azure.NativeAzureFileSystem
 
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.
checkPidPgrpidForMatch() - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Verify that the tree process id is same as its process group id.
checkpoint() - Method in class org.apache.hadoop.fs.Trash
Create a trash checkpoint.
Checkpointable - Annotation Type in org.apache.hadoop.mapreduce.task.annotation
Contract representing to the framework that the task can be safely preempted and restarted between invocations of the user-defined function.
checkScheme(URI, String) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Check that the Uri's scheme matches
checkStateTransition(String, Service.STATE, Service.STATE) - Static method in class org.apache.hadoop.service.ServiceStateModel
Check that a state tansition is valid and throw an exception if not
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
 
children - Variable in class org.apache.hadoop.registry.client.types.RegistryPathStatus
Number of child nodes
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.
CLASS_PATH_SEPARATOR - Static variable in interface org.apache.hadoop.yarn.api.ApplicationConstants
This constant is used to construct class path and it will be replaced with real class path separator(':' for Linux and ';' for Windows) by NodeManager on container launch.
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
cleanUpPartialOutputForTask(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.PartialFileOutputCommitter
 
cleanUpPartialOutputForTask(TaskAttemptContext) - Method in interface org.apache.hadoop.mapreduce.lib.output.PartialOutputCommitter
Remove all previously committed outputs from prior executions of this task.
cleanupProgress() - Method in class org.apache.hadoop.mapred.JobStatus
 
cleanupProgress() - Method in interface org.apache.hadoop.mapred.RunningJob
Get the progress of the job's cleanup-tasks, as a float between 0.0 and 1.0.
cleanupProgress() - Method in class org.apache.hadoop.mapreduce.Job
Get the progress of the job's cleanup-tasks, as a float between 0.0 and 1.0.
cleanupRunningContainersOnStop(boolean) - Method in class org.apache.hadoop.yarn.client.api.NMClient
Set whether the containers that are started by this client, and are still running should be stopped when the client stops.
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.
CLEAR_TEXT_FALLBACK - Static variable in class org.apache.hadoop.security.alias.CredentialProvider
 
clearCache() - Method in class org.apache.hadoop.yarn.client.api.NMTokenCache
It will remove all the nm tokens from its cache
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
 
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
clearWriteAccessors() - Method in interface org.apache.hadoop.registry.client.api.RegistryOperations
Clear all write accessors.
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
 
client - Variable in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
 
client - Variable in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
 
CLIENT_FAILOVER_MAX_ATTEMPTS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
CLIENT_FAILOVER_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
CLIENT_FAILOVER_PROXY_PROVIDER - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
CLIENT_FAILOVER_RETRIES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
CLIENT_FAILOVER_RETRIES_ON_SOCKET_TIMEOUTS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
CLIENT_FAILOVER_SLEEPTIME_BASE_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
CLIENT_FAILOVER_SLEEPTIME_MAX_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
CLIENT_NM_CONNECT_MAX_WAIT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Max time to wait to establish a connection to NM
CLIENT_NM_CONNECT_RETRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Time interval between each attempt to connect to NM
clientErrorEncountered() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Indicate that we just encountered a client-side error.
ClientRMProxy<T> - Class in org.apache.hadoop.yarn.client
 
ClientRMSecurityInfo - Class in org.apache.hadoop.yarn.security.client
 
ClientRMSecurityInfo() - Constructor for class org.apache.hadoop.yarn.security.client.ClientRMSecurityInfo
 
ClientSCMProtocol - Interface in org.apache.hadoop.yarn.api
The protocol between clients and the SharedCacheManager to claim and release resources in the shared cache.
ClientTimelineSecurityInfo - Class in org.apache.hadoop.yarn.security.client
 
ClientTimelineSecurityInfo() - Constructor for class org.apache.hadoop.yarn.security.client.ClientTimelineSecurityInfo
 
ClientToAMTokenIdentifier - Class in org.apache.hadoop.yarn.security.client
 
ClientToAMTokenIdentifier() - Constructor for class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
 
ClientToAMTokenIdentifier(ApplicationAttemptId, String) - Constructor for class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
 
ClientToAMTokenSecretManager - Class in org.apache.hadoop.yarn.security.client
A simple SecretManager for AMs to validate Client-RM tokens issued to clients by the RM using the underlying master-key shared by RM to the AMs on their launch.
ClientToAMTokenSecretManager(ApplicationAttemptId, byte[]) - Constructor for class org.apache.hadoop.yarn.security.client.ClientToAMTokenSecretManager
 
Clock - Interface in org.apache.hadoop.yarn.util
A simple clock interface that gives you time.
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.
 
clone() - Method in class org.apache.hadoop.registry.client.types.Endpoint
Shallow clone: the lists of addresses are shared
clone() - Method in class org.apache.hadoop.registry.client.types.ServiceRecord
Shallow clone: all endpoints will be shared across instances
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.crypto.key.KeyProvider
Can be used by implementing classes to close any resources that require closing
close() - Method in class org.apache.hadoop.fs.AvroFSInput
 
close() - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
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.CombineFileRecordReaderWrapper
 
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.CombineFileRecordReaderWrapper
 
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
 
close() - Method in class org.apache.hadoop.metrics2.sink.FileSink
 
close() - Method in class org.apache.hadoop.metrics2.sink.GraphiteSink
 
close() - Method in class org.apache.hadoop.service.AbstractService
close() - Method in interface org.apache.hadoop.service.Service
A version of stop() that is designed to be usable in Java7 closure clauses.
close() - Method in class org.apache.hadoop.yarn.ContainerLogAppender
 
close() - Method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogReader
 
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
 
ClusterMetrics(int, int, int, int, int, int, int, int, int, int, int, int, int) - Constructor for class org.apache.hadoop.mapreduce.ClusterMetrics
 
ClusterStatus - Class in org.apache.hadoop.mapred
Status information on the current state of the Map-Reduce cluster.
clusterTimestamp - Variable in class org.apache.hadoop.yarn.api.records.ReservationId
 
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.
CombineFileRecordReaderWrapper<K,V> - Class in org.apache.hadoop.mapred.lib
A wrapper class for a record reader that handles a single file split.
CombineFileRecordReaderWrapper(FileInputFormat<K, V>, CombineFileSplit, Configuration, Reporter, Integer) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
CombineFileRecordReaderWrapper<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
A wrapper class for a record reader that handles a single file split.
CombineFileRecordReaderWrapper(FileInputFormat<K, V>, CombineFileSplit, TaskAttemptContext, Integer) - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReaderWrapper
 
CombineFileSplit - Class in org.apache.hadoop.mapred.lib
 
CombineFileSplit() - Constructor for class org.apache.hadoop.mapred.lib.CombineFileSplit
 
CombineFileSplit(JobConf, Path[], long[], long[], String[]) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileSplit
 
CombineFileSplit(JobConf, Path[], long[]) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileSplit
 
CombineFileSplit(CombineFileSplit) - Constructor for class org.apache.hadoop.mapred.lib.CombineFileSplit
Copy constructor
CombineFileSplit - Class in org.apache.hadoop.mapreduce.lib.input
A sub-collection of input files.
CombineFileSplit() - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
default constructor
CombineFileSplit(Path[], long[], long[], String[]) - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
 
CombineFileSplit(Path[], long[]) - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
 
CombineFileSplit(CombineFileSplit) - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Copy constructor
CombineSequenceFileInputFormat<K,V> - Class in org.apache.hadoop.mapred.lib
Input format that is a CombineFileInputFormat-equivalent for SequenceFileInputFormat.
CombineSequenceFileInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.CombineSequenceFileInputFormat
 
CombineSequenceFileInputFormat<K,V> - Class in org.apache.hadoop.mapreduce.lib.input
Input format that is a CombineFileInputFormat-equivalent for SequenceFileInputFormat.
CombineSequenceFileInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineSequenceFileInputFormat
 
CombineTextInputFormat - Class in org.apache.hadoop.mapred.lib
Input format that is a CombineFileInputFormat-equivalent for TextInputFormat.
CombineTextInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.CombineTextInputFormat
 
CombineTextInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
Input format that is a CombineFileInputFormat-equivalent for TextInputFormat.
CombineTextInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.CombineTextInputFormat
 
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.
 
compare(ReservationRequest, ReservationRequest) - Method in class org.apache.hadoop.yarn.api.records.ReservationRequest.ReservationRequestComparator
 
compare(ResourceRequest, ResourceRequest) - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest.ResourceRequestComparator
 
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(VolumeId) - Method in class org.apache.hadoop.fs.HdfsVolumeId
 
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(VolumeId) - Method in interface org.apache.hadoop.fs.VolumeId
 
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(Priority) - Method in class org.apache.hadoop.yarn.api.records.Priority
 
compareTo(ReservationId) - Method in class org.apache.hadoop.yarn.api.records.ReservationId
 
compareTo(ReservationRequest) - Method in class org.apache.hadoop.yarn.api.records.ReservationRequest
 
compareTo(ResourceRequest) - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
 
compareTo(TimelineEntity) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
 
compareTo(TimelineEvent) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
 
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.RawLocalFileSystem
 
COMPLETION_POLL_INTERVAL_KEY - Static variable in class org.apache.hadoop.mapreduce.Job
Key in mapred-*.xml that sets completionPollInvervalMillis
componentListPath(String, String, String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
Create a path for listing components under a service
componentPath(String, String, String, String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
Create the path to a service record for a component
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.
CompositeService - Class in org.apache.hadoop.service
Composition of services.
CompositeService(String) - Constructor for class org.apache.hadoop.service.CompositeService
 
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.
computeChecksum(InputStream) - Method in interface org.apache.hadoop.yarn.sharedcache.SharedCacheChecksum
Calculate the checksum of the passed input 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
 
concat(Path, Path[]) - Method in class org.apache.hadoop.fs.FileSystem
Concat existing files together.
concat(Path, Path[]) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
conditions - Variable in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
conf - Variable in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
conf - Variable in class org.apache.hadoop.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 class org.apache.hadoop.mapred.FixedLengthInputFormat
 
configure(JobConf) - Method in interface org.apache.hadoop.mapred.JobConfigurable
Initializes a new instance from a JobConf.
configure(JobConf) - Method in class org.apache.hadoop.mapred.KeyValueTextInputFormat
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.aggregate.UserDefinedValueAggregatorDescriptor
Do nothing.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor
get the input file name.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorCombiner
Combiner does not need to configure.
configure(JobConf) - Method in interface org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorDescriptor
Configure the object
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJobBase
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.BinaryPartitioner
 
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.ChainMapper
Configures the ChainMapper and all the Mappers in the chain.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.ChainReducer
Configures the ChainReducer, the Reducer and all the Mappers in the chain.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
Initializes a new instance from a JobConf.
configure(JobConf) - Method in class org.apache.hadoop.mapred.lib.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.
confirmPrompt(String) - Static method in class org.apache.hadoop.util.ToolRunner
Print out a prompt to the user, and return true if the user responds with "y" or "yes".
connection - Variable in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
ConnectTimeoutException - Exception in org.apache.hadoop.net
Thrown by NetUtils.connect(java.net.Socket, java.net.SocketAddress, int) if it times out while connecting to the remote host.
ConnectTimeoutException(String) - Constructor for exception org.apache.hadoop.net.ConnectTimeoutException
 
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 - Class in org.apache.hadoop.yarn.api.records
Container represents an allocated resource in the cluster.
Container() - Constructor for class org.apache.hadoop.yarn.api.records.Container
 
CONTAINER_ID_BITMASK - Static variable in class org.apache.hadoop.yarn.api.records.ContainerId
 
CONTAINER_TOKEN_FILE_ENV_NAME - Static variable in interface org.apache.hadoop.yarn.api.ApplicationConstants
The cache file into which container token is written
ContainerExitStatus - Class in org.apache.hadoop.yarn.api.records
Container exit statuses indicating special exit circumstances.
ContainerExitStatus() - Constructor for class org.apache.hadoop.yarn.api.records.ContainerExitStatus
 
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 - Class in org.apache.hadoop.yarn.api.records
ContainerLaunchContext represents all of the information needed by the NodeManager to launch a container.
ContainerLaunchContext() - Constructor for class org.apache.hadoop.yarn.api.records.ContainerLaunchContext
 
ContainerLogAppender - Class in org.apache.hadoop.yarn
A simple log4j-appender for container's logs.
ContainerLogAppender() - Constructor for class org.apache.hadoop.yarn.ContainerLogAppender
 
ContainerManagementProtocol - 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.
ContainerManagerSecurityInfo - Class in org.apache.hadoop.yarn.security
 
ContainerManagerSecurityInfo() - Constructor for class org.apache.hadoop.yarn.security.ContainerManagerSecurityInfo
 
ContainerNotFoundException - Exception in org.apache.hadoop.yarn.exceptions
This exception is thrown on (GetContainerReportRequest) API when the container doesn't exist in AHS
ContainerNotFoundException(Throwable) - Constructor for exception org.apache.hadoop.yarn.exceptions.ContainerNotFoundException
 
ContainerNotFoundException(String) - Constructor for exception org.apache.hadoop.yarn.exceptions.ContainerNotFoundException
 
ContainerNotFoundException(String, Throwable) - Constructor for exception org.apache.hadoop.yarn.exceptions.ContainerNotFoundException
 
ContainerReport - Class in org.apache.hadoop.yarn.api.records
ContainerReport is a report of an container.
ContainerReport() - Constructor for class org.apache.hadoop.yarn.api.records.ContainerReport
 
ContainerResourceIncreaseRequest - Class in org.apache.hadoop.yarn.api.records
Used by Application Master, send a container resource increase request to Resource Manager
ContainerResourceIncreaseRequest() - Constructor for class org.apache.hadoop.yarn.api.records.ContainerResourceIncreaseRequest
 
ContainerRollingLogAppender - Class in org.apache.hadoop.yarn
A simple log4j-appender for container's logs.
ContainerRollingLogAppender() - Constructor for class org.apache.hadoop.yarn.ContainerRollingLogAppender
 
ContainerState - Enum in org.apache.hadoop.yarn.api.records
State of a Container.
ContainerStatus - Class in org.apache.hadoop.yarn.api.records
ContainerStatus represents the current status of a Container.
ContainerStatus() - Constructor for class org.apache.hadoop.yarn.api.records.ContainerStatus
 
ContainerTokenIdentifier - Class in org.apache.hadoop.yarn.security
TokenIdentifier for a container.
ContainerTokenIdentifier(ContainerId, String, String, Resource, long, int, long, Priority, long) - Constructor for class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
ContainerTokenIdentifier(ContainerId, String, String, Resource, long, int, long, Priority, long, LogAggregationContext) - Constructor for class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
ContainerTokenIdentifier() - Constructor for class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
Default constructor needed by RPC layer/SecretManager.
ContainerTokenSelector - Class in org.apache.hadoop.yarn.security
 
ContainerTokenSelector() - Constructor for class org.apache.hadoop.yarn.security.ContainerTokenSelector
 
containsKey(Object) - Method in class org.apache.hadoop.io.MapWritable
 
containsKey(Object) - Method in class org.apache.hadoop.io.SortedMapWritable
 
containsToken(String) - Method in class org.apache.hadoop.yarn.client.api.NMTokenCache
Returns true if NMToken is present in cache.
containsValue(Object) - Method in class org.apache.hadoop.io.MapWritable
 
containsValue(Object) - Method in class org.apache.hadoop.io.SortedMapWritable
 
contentEquals(Counters.Counter) - Method in class org.apache.hadoop.mapred.Counters.Counter
Deprecated. 
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
Deprecated.
ContentSummary(long, long, long) - Constructor for class org.apache.hadoop.fs.ContentSummary
Deprecated.
ContentSummary(long, long, long, long, long, long) - Constructor for class org.apache.hadoop.fs.ContentSummary
Deprecated.
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.
convert(Throwable) - Static method in exception org.apache.hadoop.service.ServiceStateException
Convert any exception into a RuntimeException.
convert(String, Throwable) - Static method in exception org.apache.hadoop.service.ServiceStateException
Convert any exception into a RuntimeException.
convertUsername(String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
Convert the username to that which can be used for registry entries.
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(FileSystem, FileStatus, 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.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.LocalFileSystem
 
CORE_SITE_CONFIGURATION_FILE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
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
Counters.Counter - Class in org.apache.hadoop.mapred
A counter record, comprising its name and value.
Counters.Counter() - Constructor for class org.apache.hadoop.mapred.Counters.Counter
 
Counters.Group - Class in org.apache.hadoop.mapred
Group of counters, comprising of counters from a particular counter Enum class.
Counters.Group() - Constructor for class org.apache.hadoop.mapred.Counters.Group
 
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.azure.NativeAzureFileSystem
 
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
 
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) - 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(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable, Options.ChecksumOpt) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
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, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
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 - Static variable in interface org.apache.hadoop.registry.client.api.BindFlags
Create the entry..
CREATE_DIR - Static variable in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
createAHSClient() - Static method in class org.apache.hadoop.yarn.client.api.AHSClient
Create a new instance of AHSClient.
createAHSProxy(Configuration, Class<T>, InetSocketAddress) - Static method in class org.apache.hadoop.yarn.client.AHSProxy
 
createAllSymlink(Configuration, File, File) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
Internal to MapReduce framework. Use DistributedCacheManager instead.
createAMRMClient() - Static method in class org.apache.hadoop.yarn.client.api.AMRMClient
Create a new instance of AMRMClient.
createAMRMClientAsync(int, AMRMClientAsync.CallbackHandler) - Static method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
 
createAMRMClientAsync(AMRMClient<T>, int, AMRMClientAsync.CallbackHandler) - Static method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
 
createAndSubmitJob() - Method in class org.apache.hadoop.tools.DistCp
Create and submit the mapreduce job.
createApplication() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Obtain a YarnClientApplication for a new application, which in turn contains the ApplicationSubmissionContext and GetNewApplicationResponse objects.
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
 
createConnection() - Method in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
createCredentialEntry(String, char[]) - Method in class org.apache.hadoop.security.alias.CredentialProvider
Create a new credential.
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
 
createDirectDecompressor() - Method in class org.apache.hadoop.io.compress.DefaultCodec
Create a new DirectDecompressor for use by this DirectDecompressionCodec.
createDirectDecompressor() - Method in interface org.apache.hadoop.io.compress.DirectDecompressionCodec
Create a new DirectDecompressor for use by this DirectDecompressionCodec.
createDirectDecompressor() - Method in class org.apache.hadoop.io.compress.GzipCodec
 
createFileSplit(Path, long, long) - Static method in class org.apache.hadoop.mapred.lib.NLineInputFormat
NLineInputFormat uses LineRecordReader, which always reads (and consumes) at least one character out of its upper split boundary.
createFileSplit(Path, long, long) - Static method in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
NLineInputFormat uses LineRecordReader, which always reads (and consumes) at least one character out of its upper split boundary.
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.
createIdentifier() - Method in class org.apache.hadoop.yarn.security.client.BaseClientToAMTokenSecretManager
 
createImmutable(short) - Static method in class org.apache.hadoop.fs.permission.FsPermission
Create an immutable FsPermission object.
createInputFileListing(Job) - Method in class org.apache.hadoop.tools.DistCp
Create input listing by invoking an appropriate copy listing implementation.
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.
createJarWithClassPath(String, Path, Map<String, String>) - Static method in class org.apache.hadoop.fs.FileUtil
 
createJarWithClassPath(String, Path, Path, Map<String, String>) - Static method in class org.apache.hadoop.fs.FileUtil
Create a jar file at the given path, containing a manifest with a classpath that references all specified entries.
createJobListCache() - Method in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
 
createKey(String, byte[], KeyProvider.Options) - Method in class org.apache.hadoop.crypto.key.KeyProvider
Create a new key.
createKey(String, KeyProvider.Options) - Method in class org.apache.hadoop.crypto.key.KeyProvider
Create a new key generating the material for it.
createKey() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Create a new key value common to all child RRs.
createKey() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Request new key from proxied RR.
createKey() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
 
createKey() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
createKey() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
createKey() - Method in 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.
createNMClient() - Static method in class org.apache.hadoop.yarn.client.api.NMClient
Create a new instance of NMClient.
createNMClient(String) - Static method in class org.apache.hadoop.yarn.client.api.NMClient
Create a new instance of NMClient.
createNMClientAsync(NMClientAsync.CallbackHandler) - Static method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
 
createNMProxy(Configuration, Class<T>, UserGroupInformation, YarnRPC, InetSocketAddress) - Static method in class org.apache.hadoop.yarn.client.NMProxy
 
createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
createNonRecursive(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
createNonRecursive(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
 
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, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FileSystem
Deprecated.
API only for 0.20-append
createNonRecursive(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.FilterFileSystem
Deprecated.
createNonRecursive(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
Deprecated.
createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
createNonRecursive(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
createOutputStream(Path, boolean) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
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
 
createOutputStreamWithMode(Path, boolean, FsPermission) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
createPassword(ClientToAMTokenIdentifier) - Method in class org.apache.hadoop.yarn.security.client.BaseClientToAMTokenSecretManager
 
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.
createProvider(URI, Configuration) - Method in class org.apache.hadoop.crypto.key.KeyProviderFactory
 
createProvider(URI, Configuration) - Method in class org.apache.hadoop.security.alias.CredentialProviderFactory
 
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.CombineSequenceFileInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineTextInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueTextInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.NLineInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsBinaryInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileAsTextInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
Create a record reader for the given split
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.input.TextInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.join.ComposableInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputFormat
Construct a CompositeRecordReader for the children of this InputFormat as defined in the init expression.
createRetriableProxy(Configuration, Class<T>, UserGroupInformation, YarnRPC, InetSocketAddress, RetryPolicy) - Static method in class org.apache.hadoop.yarn.client.ServerProxy
 
createRetryPolicy(Configuration) - Static method in class org.apache.hadoop.yarn.client.RMProxy
Fetch retry policy from Configuration
createRetryPolicy(Configuration, String, long, String, long) - Static method in class org.apache.hadoop.yarn.client.ServerProxy
 
createRMProxy(Configuration, Class<T>) - Static method in class org.apache.hadoop.yarn.client.ClientRMProxy
Create a proxy to the ResourceManager for the specified protocol.
createRMProxy(Configuration, Class<T>, RMProxy) - Static method in class org.apache.hadoop.yarn.client.RMProxy
Create a proxy for the specified protocol.
createRMProxy(Configuration, Class<T>, InetSocketAddress) - Static method in class org.apache.hadoop.yarn.client.RMProxy
Deprecated.
This method is deprecated and is not used by YARN internally any more. To create a proxy to the RM, use ClientRMProxy#createRMProxy or ServerRMProxy#createRMProxy. Create a proxy to the ResourceManager at the specified address.
createSharedCacheClient() - Static method in class org.apache.hadoop.yarn.client.api.SharedCacheClient
 
createSnapshot(Path) - Method in class org.apache.hadoop.fs.FileSystem
Create a snapshot with a default name.
createSnapshot(Path, String) - Method in class org.apache.hadoop.fs.FileSystem
Create a snapshot
createSnapshot(Path, String) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
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.FileSystem
createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.LocalFileSystem
 
createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
createSymlink(Path, Path, boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
createSymlink() - Method in class org.apache.hadoop.mapreduce.Job
Deprecated.
createTimelineClient() - Static method in class org.apache.hadoop.yarn.client.api.TimelineClient
Create a timeline client.
createTupleWritable() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Create a value to be used internally for joins.
createValue() - Method in class org.apache.hadoop.mapred.join.JoinRecordReader
Create an object of the appropriate type to be used as a value.
createValue() - Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader
Create an object of the appropriate type to be used as a value.
createValue() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Request new value from proxied RR.
createValue() - Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
 
createValue() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReader
 
createValue() - Method in class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
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[], Class<?>) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
Create an Aggregate based map/reduce job.
createValueAggregatorJob(String[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
Create an Aggregate based map/reduce job.
createValueAggregatorJob(String[], Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
 
createValueAggregatorJob(String[], Class<? extends ValueAggregatorDescriptor>[], Class<?>) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
 
createValueAggregatorJob(Configuration, String[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
Create an Aggregate based map/reduce job.
createValueAggregatorJob(String[], Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
 
createValueAggregatorJobs(String[], Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
 
createValueAggregatorJobs(String[]) - Static method in class org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob
 
createValueAggregatorJobs(String[], Class<? extends ValueAggregatorDescriptor>[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
 
createValueAggregatorJobs(String[]) - Static method in class org.apache.hadoop.mapreduce.lib.aggregate.ValueAggregatorJob
 
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
createYarnClient() - Static method in class org.apache.hadoop.yarn.client.api.YarnClient
Create a new instance of YarnClient.
createYarnClient() - Method in class org.apache.hadoop.yarn.client.cli.LogsCLI
 
CREDENTIAL_PROVIDER_PATH - Static variable in class org.apache.hadoop.security.alias.CredentialProviderFactory
 
CredentialProvider - Class in org.apache.hadoop.security.alias
A provider of credentials or password for Hadoop applications.
CredentialProvider() - Constructor for class org.apache.hadoop.security.alias.CredentialProvider
 
CredentialProviderFactory - Class in org.apache.hadoop.security.alias
A factory to create a list of CredentialProvider based on the path given in a Configuration.
CredentialProviderFactory() - Constructor for class org.apache.hadoop.security.alias.CredentialProviderFactory
 
CS_CONFIGURATION_FILE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
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
 
currentDownloadBytesPerSecond(long) - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Record the current bytes-per-second download rate seen.
currentToken - Variable in exception org.apache.hadoop.record.compiler.generated.ParseException
Deprecated.
This is the last token that has been consumed successfully.
currentUploadBytesPerSecond(long) - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Record the current bytes-per-second upload rate seen.
currentUser() - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
Get the current user path formatted for the registry

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
 
dbConf - Variable in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
DBConfiguration - Class in org.apache.hadoop.mapred.lib.db
 
DBConfiguration - Class in org.apache.hadoop.mapreduce.lib.db
A container for configuration property names for jobs with DB input/output.
DBConfiguration(Configuration) - Constructor for class org.apache.hadoop.mapreduce.lib.db.DBConfiguration
 
DBInputFormat<T extends DBWritable> - Class in org.apache.hadoop.mapred.lib.db
 
DBInputFormat() - Constructor for class org.apache.hadoop.mapred.lib.db.DBInputFormat
 
DBInputFormat<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A InputFormat that reads input data from an SQL table.
DBInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
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
 
dbProductName - Variable in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
DBRecordReader<T extends DBWritable> - Class in org.apache.hadoop.mapreduce.lib.db
A RecordReader that reads records from a SQL table.
DBRecordReader(DBInputFormat.DBInputSplit, Class<T>, Configuration, Connection, DBConfiguration, String, String[], String) - Constructor for class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
 
DBSplitter - Interface in org.apache.hadoop.mapreduce.lib.db
DBSplitter will generate DBInputSplits to use with DataDrivenDBInputFormat.
DBWritable - Interface in org.apache.hadoop.mapred.lib.db
 
DBWritable - Interface in org.apache.hadoop.mapreduce.lib.db
Objects that are read from/written to a database should implement DBWritable.
DEBUG_NM_DELETE_DELAY_SEC - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Delay before deleting resource to ease debugging of NM issues
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.
decodeValue(String) - Static method in enum org.apache.hadoop.fs.XAttrCodec
Decode string representation of a value and check whether it's encoded.
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
 
decompress(ByteBuffer, ByteBuffer) - Method in interface org.apache.hadoop.io.compress.DirectDecompressor
 
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 enum org.apache.hadoop.fs.StorageType
 
DEFAULT - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
Deprecated.
 
DEFAULT_APPLICATION_HISTORY_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_APPLICATION_NAME - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Default application name
DEFAULT_APPLICATION_TYPE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Default application type
DEFAULT_AUTO_FAILOVER_EMBEDDED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_AUTO_FAILOVER_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_AUTO_FAILOVER_ZK_BASE_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_BITLENGTH - Static variable in class org.apache.hadoop.crypto.key.KeyProvider
 
DEFAULT_BITLENGTH_NAME - Static variable in class org.apache.hadoop.crypto.key.KeyProvider
 
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_CIPHER - Static variable in class org.apache.hadoop.crypto.key.KeyProvider
 
DEFAULT_CIPHER_NAME - Static variable in class org.apache.hadoop.crypto.key.KeyProvider
 
DEFAULT_CLIENT_FAILOVER_PROXY_PROVIDER - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_CLIENT_FAILOVER_RETRIES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_CLIENT_FAILOVER_RETRIES_ON_SOCKET_TIMEOUTS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_CLIENT_NM_CONNECT_MAX_WAIT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_CLIENT_NM_CONNECT_RETRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_CONTAINER_TEMP_DIR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Container temp directory
DEFAULT_DISPATCHER_EXIT_ON_ERROR - Static variable in interface org.apache.hadoop.yarn.event.Dispatcher
 
DEFAULT_EXPIRE - Static variable in class org.apache.hadoop.yarn.util.AbstractLivelinessMonitor
 
DEFAULT_FS - Static variable in class org.apache.hadoop.fs.FileSystem
 
DEFAULT_FS_APPLICATION_HISTORY_STORE_COMPRESSION_TYPE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_FS_BASED_RM_CONF_STORE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_FS_NODE_LABELS_STORE_RETRY_POLICY_SPEC - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_FS_RM_STATE_STORE_NUM_RETRIES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_FS_RM_STATE_STORE_RETRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_FS_RM_STATE_STORE_RETRY_POLICY_SPEC - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_IN_MEMORY_CHECK_PERIOD_MINS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_IN_MEMORY_INITIAL_DELAY_MINS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_IN_MEMORY_STALENESS_PERIOD_MINS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_IPC_CLIENT_FACTORY_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_IPC_RECORD_FACTORY_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_IPC_RPC_IMPL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_IPC_SERVER_FACTORY_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_LIST_STATUS_NUM_THREADS - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
DEFAULT_LOG_AGGREGATION_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_LOG_AGGREGATION_RETAIN_CHECK_INTERVAL_SECONDS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_LOG_AGGREGATION_RETAIN_SECONDS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
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_MAPREDUCE_RECOVER_JOB - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.
DEFAULT_MAX_LEN - Static variable in class org.apache.hadoop.io.Text
 
DEFAULT_NM_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_ADMIN_USER_ENV - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_CLIENT_ASYNC_THREAD_POOL_MAX_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_CLIENT_MAX_NM_PROXIES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_CONTAINER_EXECUTOR_SCHED_PRIORITY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_CONTAINER_METRICS_ENABLE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_CONTAINER_METRICS_PERIOD_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_CONTAINER_MGR_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_CONTAINER_MON_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_DELETE_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_DISK_HEALTH_CHECK_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
By default, disks' health is checked every 2 minutes.
DEFAULT_NM_ENV_WHITELIST - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_HEALTH_CHECK_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_HEALTH_CHECK_SCRIPT_TIMEOUT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LINUX_CONTAINER_CGROUPS_DELETE_DELAY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LINUX_CONTAINER_CGROUPS_DELETE_TIMEOUT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LINUX_CONTAINER_CGROUPS_STRICT_RESOURCE_USAGE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOCAL_CACHE_MAX_FILES_PER_DIRECTORY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOCAL_DIRS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOCALIZER_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOCALIZER_CACHE_CLEANUP_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOCALIZER_CACHE_TARGET_SIZE_MB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOCALIZER_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOCALIZER_FETCH_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOCALIZER_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOG_AGG_COMPRESSION_TYPE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOG_AGGREGATION_ROLL_MONITORING_INTERVAL_SECONDS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOG_DELETE_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOG_DIRS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_LOG_RETAIN_SECONDS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_MAX_PER_DISK_UTILIZATION_PERCENTAGE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
By default, 90% of the disk can be used before it is marked as offline.
DEFAULT_NM_MIN_HEALTHY_DISKS_FRACTION - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
By default, at least 25% of disks are to be healthy to say that the node is healthy in terms of disks.
DEFAULT_NM_MIN_PER_DISK_FREE_SPACE_MB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
By default, all of the disk can be used before it is marked as offline.
DEFAULT_NM_NONSECURE_MODE_LIMIT_USERS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_NONSECURE_MODE_LOCAL_USER - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_NONSECURE_MODE_USER_PATTERN - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_PMEM_CHECK_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_PMEM_MB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_PROCESS_KILL_WAIT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_RECOVERY_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_REMOTE_APP_LOG_DIR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_REMOTE_APP_LOG_DIR_SUFFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_RESOURCE_PERCENTAGE_PHYSICAL_CPU_LIMIT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_RESOURCEMANAGER_MINIMUM_VERSION - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_SLEEP_DELAY_BEFORE_SIGKILL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_USER_HOME_DIR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_VCORES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_VMEM_CHECK_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_VMEM_PMEM_RATIO - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_WEBAPP_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_WEBAPP_HTTPS_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_WEBAPP_HTTPS_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_WEBAPP_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_WINDOWS_CONTAINER_CPU_LIMIT_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NM_WINDOWS_CONTAINER_MEMORY_LIMIT_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_NODE_LABELS_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
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_PROCFS_USE_SMAPS_BASED_RSS_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_PROXY_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_PROXY_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
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_QUEUE_NAME - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Default queue name
DEFAULT_REGISTRY_CLIENT_JAAS_CONTEXT - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
default client-side registry JAAS context: "Client"
DEFAULT_REGISTRY_ENABLED - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Defaut value for enabling the registry in the RM: false
DEFAULT_REGISTRY_SECURE - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Default registry security policy: false.
DEFAULT_REGISTRY_SYSTEM_ACCOUNTS - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Default system accounts given global access to the registry: "sasl:yarn@, sasl:mapred@, sasl:hdfs@, sasl:hadoop@".
DEFAULT_REGISTRY_USER_ACCOUNTS - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Default system acls: "".
DEFAULT_REGISTRY_ZK_QUORUM - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
The default zookeeper quorum binding for the registry: "localhost:2181"
DEFAULT_RESOURCEMANAGER_CONNECT_MAX_WAIT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RESOURCEMANAGER_CONNECT_RETRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_ADMIN_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_ADMIN_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_ADMIN_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_AM_EXPIRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_AM_MAX_ATTEMPTS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_AMLAUNCHER_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_AMRM_TOKEN_MASTER_KEY_ROLLING_INTERVAL_SECS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_CONFIGURATION_PROVIDER_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_CONTAINER_ALLOC_EXPIRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_CONTAINER_TOKEN_MASTER_KEY_ROLLING_INTERVAL_SECS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_DELAYED_DELEGATION_TOKEN_REMOVAL_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_DELEGATION_TOKEN_RENEWER_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_HA_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_HISTORY_WRITER_MULTI_THREADED_DISPATCHER_POOL_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_MAX_COMPLETED_APPLICATIONS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_METRICS_RUNTIME_BUCKETS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Default sizes of the runtime metric buckets in minutes.
DEFAULT_RM_NM_EXPIRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_NM_HEARTBEAT_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_NMTOKEN_MASTER_KEY_ROLLING_INTERVAL_SECS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_NODEMANAGER_CONNECT_RETIRES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_NODEMANAGER_MINIMUM_VERSION - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_NODES_EXCLUDE_FILE_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_NODES_INCLUDE_FILE_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_PROXY_USER_PRIVILEGES_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_RECOVERY_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_RESERVATION_SYSTEM_ENABLE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_RESERVATION_SYSTEM_PLAN_FOLLOWER_TIME_STEP - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_RESOURCE_TRACKER_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_RESOURCE_TRACKER_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_RESOURCE_TRACKER_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_SCHEDULER - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_SCHEDULER_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_SCHEDULER_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_SCHEDULER_ENABLE_MONITORS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_SCHEDULER_MAXIMUM_ALLOCATION_MB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_SCHEDULER_MAXIMUM_ALLOCATION_VCORES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_SCHEDULER_MINIMUM_ALLOCATION_MB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_SCHEDULER_MINIMUM_ALLOCATION_VCORES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_SCHEDULER_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_SCHEDULER_USE_PORT_FOR_NODE_NAME - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_STATE_STORE_MAX_COMPLETED_APPLICATIONS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_SYSTEM_METRICS_PUBLISHER_DISPATCHER_POOL_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_SYSTEM_METRICS_PUBLISHER_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_WEBAPP_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_WEBAPP_DELEGATION_TOKEN_AUTH_FILTER - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_WEBAPP_HTTPS_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_WEBAPP_HTTPS_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_WEBAPP_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_WEBAPP_UI_ACTIONS_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_WORK_PRESERVING_RECOVERY_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_WORK_PRESERVING_RECOVERY_SCHEDULING_WAIT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_ZK_ACL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_ZK_RETRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_RM_ZK_TIMEOUT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_ADMIN_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_ADMIN_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_ADMIN_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_APP_CHECKER_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_CLEANER_INITIAL_DELAY_MINS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_CLEANER_PERIOD_MINS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_CLEANER_RESOURCE_SLEEP_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_CLIENT_SERVER_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_CLIENT_SERVER_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_CLIENT_SERVER_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_STORE_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_UPLOADER_SERVER_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_UPLOADER_SERVER_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_UPLOADER_SERVER_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_WEBAPP_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SCM_WEBAPP_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SHARED_CACHE_CHECKSUM_ALGO_IMPL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SHARED_CACHE_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SHARED_CACHE_NESTED_LEVEL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SHARED_CACHE_NM_UPLOADER_REPLICATION_FACTOR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SHARED_CACHE_NM_UPLOADER_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SHARED_CACHE_ROOT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_SUBMIT_REPLICATION - Static variable in class org.apache.hadoop.mapreduce.Job
 
DEFAULT_TIMELINE_DELEGATION_KEY_UPDATE_INTERVAL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_DELEGATION_TOKEN_MAX_LIFETIME - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_DELEGATION_TOKEN_RENEW_INTERVAL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_CLIENT_BEST_EFFORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_CLIENT_MAX_RETRIES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_CLIENT_RETRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_LEVELDB_READ_CACHE_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_LEVELDB_START_TIME_READ_CACHE_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_LEVELDB_START_TIME_WRITE_CACHE_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_LEVELDB_TTL_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_RECOVERY_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_TTL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_WEBAPP_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_WEBAPP_HTTPS_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_WEBAPP_HTTPS_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_TIMELINE_SERVICE_WEBAPP_PORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_UMASK - Static variable in class org.apache.hadoop.fs.permission.FsPermission
 
DEFAULT_YARN_ACL_ENABLE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_YARN_ADMIN_ACL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_YARN_APP_ACL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
ACL used in case none is found.
DEFAULT_YARN_APPLICATION_CLASSPATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Default platform-specific CLASSPATH for YARN applications.
DEFAULT_YARN_CLIENT_APPLICATION_CLIENT_PROTOCOL_POLL_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_YARN_CLIENT_APPLICATION_CLIENT_PROTOCOL_POLL_TIMEOUT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_YARN_CROSS_PLATFORM_APPLICATION_CLASSPATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Default platform-agnostic CLASSPATH for YARN applications.
DEFAULT_YARN_INTERMEDIATE_DATA_ENCRYPTION - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_YARN_MINICLUSTER_CONTROL_RESOURCE_MONITORING - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_YARN_MINICLUSTER_FIXED_PORTS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Default is false to be able to run tests concurrently without port conflicts.
DEFAULT_YARN_MINICLUSTER_NM_PMEM_MB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_YARN_MINICLUSTER_USE_RPC - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_ZK_CONNECTION_TIMEOUT - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
The default ZK connection timeout: 15000.
DEFAULT_ZK_REGISTRY_ROOT - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Default root of the yarn registry: "/registry"
DEFAULT_ZK_RETRY_CEILING - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Default limit on retries: 60000.
DEFAULT_ZK_RETRY_INTERVAL - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
The default interval between connection retries: 1000.
DEFAULT_ZK_RETRY_TIMES - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
The default # of times to retry a ZK connection: 5.
DEFAULT_ZK_RM_NUM_RETRIES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_ZK_RM_STATE_STORE_PARENT_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
DEFAULT_ZK_SESSION_TIMEOUT - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
The default ZK session timeout: 60000.
DefaultCodec - Class in org.apache.hadoop.io.compress
 
DefaultCodec() - Constructor for class org.apache.hadoop.io.compress.DefaultCodec
 
DefaultImpersonationProvider - Class in org.apache.hadoop.security.authorize
 
DefaultImpersonationProvider() - Constructor for class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
 
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.
DELEGATION_PARAM - Static variable in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
 
DELEGATION_TOKEN_HEADER - Static variable in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
 
DELEGATION_TOKEN_JSON - Static variable in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
 
DELEGATION_TOKEN_URL_STRING_JSON - Static variable in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
 
DelegationTokenAuthenticatedURL - Class in org.apache.hadoop.security.token.delegation.web
The DelegationTokenAuthenticatedURL is a AuthenticatedURL sub-class with built-in Hadoop Delegation Token functionality.
DelegationTokenAuthenticatedURL() - Constructor for class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
Creates an DelegationTokenAuthenticatedURL.
DelegationTokenAuthenticatedURL(DelegationTokenAuthenticator) - Constructor for class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
Creates an DelegationTokenAuthenticatedURL.
DelegationTokenAuthenticatedURL(ConnectionConfigurator) - Constructor for class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
Creates an DelegationTokenAuthenticatedURL using the default DelegationTokenAuthenticator class.
DelegationTokenAuthenticatedURL(DelegationTokenAuthenticator, ConnectionConfigurator) - Constructor for class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
Creates an DelegationTokenAuthenticatedURL.
DelegationTokenAuthenticatedURL.Token - Class in org.apache.hadoop.security.token.delegation.web
Client side authentication token that handles Delegation Tokens.
DelegationTokenAuthenticatedURL.Token() - Constructor for class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL.Token
 
DelegationTokenAuthenticator - Class in org.apache.hadoop.security.token.delegation.web
Authenticator wrapper that enhances an Authenticator with Delegation Token support.
DelegationTokenAuthenticator(Authenticator) - Constructor for class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
 
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) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
Deprecated.
delete(Path, boolean) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
delete(Path, boolean, boolean) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
Delete the specified file or folder.
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.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(String, boolean) - Method in interface org.apache.hadoop.registry.client.api.RegistryOperations
Delete a path.
delete(String, boolean) - Method in class org.apache.hadoop.registry.client.impl.zk.RegistryOperationsService
 
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).
deleteCredentialEntry(String) - Method in class org.apache.hadoop.security.alias.CredentialProvider
Delete the given credential.
deleteDir(FileStatus) - Method in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
 
deleteFilesWithDanglingTempData(Path) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
Looks under the given root path for any blob that are left "dangling", meaning that they are place-holder blobs that we created while we upload the data to a temporary blob, but for some reason we crashed in the middle of the upload and left them there.
deleteKey(String) - Method in class org.apache.hadoop.crypto.key.KeyProvider
Delete the given key.
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.
deleteReservation(ReservationDeleteRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationClientProtocol
The interface used by clients to remove an existing Reservation.
deleteReservation(ReservationDeleteRequest) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
The interface used by clients to remove an existing Reservation.
deleteSnapshot(Path, String) - Method in class org.apache.hadoop.fs.FileSystem
Delete a snapshot of a directory
deleteSnapshot(Path, String) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
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
 
description - Variable in class org.apache.hadoop.registry.client.impl.zk.BindingInformation
Any information that may be useful for diagnostics
description - Variable in class org.apache.hadoop.registry.client.types.ServiceRecord
Description string
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
 
DirectDecompressionCodec - Interface in org.apache.hadoop.io.compress
This class encapsulates a codec which can decompress direct bytebuffers.
DirectDecompressor - Interface in org.apache.hadoop.io.compress
Specification of a direct ByteBuffer 'de-compressor'.
directoryCreated() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Indicate that we just created a directory through WASB.
directoryDeleted() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Indicate that we just deleted a directory through WASB.
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
Deprecated.
DISKS_FAILED - Static variable in class org.apache.hadoop.yarn.api.records.ContainerExitStatus
When threshold number of the nodemanager-local-directories or threshold number of the nodemanager-log-directories become bad.
dispatch(Event) - Method in class org.apache.hadoop.yarn.event.AsyncDispatcher
 
Dispatcher - Interface in org.apache.hadoop.yarn.event
Event Dispatcher interface.
DISPATCHER_EXIT_ON_ERROR_KEY - Static variable in interface org.apache.hadoop.yarn.event.Dispatcher
 
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
DistCp - Class in org.apache.hadoop.tools
DistCp is the main driver-class for DistCpV2.
DistCp(Configuration, DistCpOptions) - Constructor for class org.apache.hadoop.tools.DistCp
Public Constructor.
DistributedCache - Class in org.apache.hadoop.filecache
Deprecated.
DistributedCache() - Constructor for class org.apache.hadoop.filecache.DistributedCache
Deprecated.
 
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.
DISTRIBUTEDSHELLTIMELINEDOMAIN - Static variable in class org.apache.hadoop.yarn.applications.distributedshell.DSConstants
Environment key name denoting the timeline domain ID.
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.
 
doTransition(EVENTTYPE, EVENT) - Method in interface org.apache.hadoop.yarn.state.StateMachine
 
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(TaskCompletionEvent) - Static method in class org.apache.hadoop.mapred.TaskCompletionEvent
 
downgrade(TaskID) - Static method in class org.apache.hadoop.mapred.TaskID
Downgrade a new TaskID to an old one
driver(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}...
dumpDeprecatedKeys() - Static method in class org.apache.hadoop.conf.Configuration
 
dumpTimelineRecordtoJSON(Object) - Static method in class org.apache.hadoop.yarn.util.timeline.TimelineUtils
Serialize a POJO object into a JSON string not in a pretty format
dumpTimelineRecordtoJSON(Object, boolean) - Static method in class org.apache.hadoop.yarn.util.timeline.TimelineUtils
Serialize a POJO object into a JSON string
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

E_SAME_DIRECTORY_ONLY - Static variable in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
ElasticByteBufferPool - Class in org.apache.hadoop.io
This is a simple ByteBufferPool which just creates ByteBuffers as needed.
ElasticByteBufferPool() - Constructor for class org.apache.hadoop.io.ElasticByteBufferPool
 
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.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 enum org.apache.hadoop.fs.StorageType
 
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.
 
enableSymlinks() - Static method in class org.apache.hadoop.fs.FileSystem
 
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.
encodeValue(byte[], XAttrCodec) - Static method in enum org.apache.hadoop.fs.XAttrCodec
Encode byte[] value to string representation with 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.
 
Endpoint - Class in org.apache.hadoop.registry.client.types
Description of a single service/component endpoint.
Endpoint() - Constructor for class org.apache.hadoop.registry.client.types.Endpoint
Create an empty instance.
Endpoint(Endpoint) - Constructor for class org.apache.hadoop.registry.client.types.Endpoint
Create an endpoint from another endpoint.
Endpoint(String, String, String, List<Map<String, String>>) - Constructor for class org.apache.hadoop.registry.client.types.Endpoint
Build an endpoint with a list of addresses
Endpoint(String, String, String) - Constructor for class org.apache.hadoop.registry.client.types.Endpoint
Build an endpoint with an empty address list
Endpoint(String, String, String, Map<String, String>) - Constructor for class org.apache.hadoop.registry.client.types.Endpoint
Build an endpoint with a single address entry.
Endpoint(String, String, String, Map<String, String>...) - Constructor for class org.apache.hadoop.registry.client.types.Endpoint
Build an endpoint with a list of addresses
Endpoint(String, String, URI...) - Constructor for class org.apache.hadoop.registry.client.types.Endpoint
Build an endpoint from a list of URIs; each URI is ASCII-encoded and added to the list of addresses.
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.
 
ensembleProvider - Variable in class org.apache.hadoop.registry.client.impl.zk.BindingInformation
The Curator Ensemble Provider
ensureCurrentState(Service.STATE) - Method in class org.apache.hadoop.service.ServiceStateModel
Verify that that a service is in a given state.
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.
enterState(Service.STATE) - Method in class org.apache.hadoop.service.ServiceStateModel
Enter a state -thread safe.
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.HdfsVolumeId
 
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.AclEntry
 
equals(Object) - Method in class org.apache.hadoop.fs.permission.AclStatus
 
equals(Object) - Method in class org.apache.hadoop.fs.permission.FsPermission
 
equals(Object) - Method in interface org.apache.hadoop.fs.VolumeId
 
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.Counters.Counter
 
equals(Object) - Method in class org.apache.hadoop.mapred.Counters.Group
 
equals(Object) - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Return true iff compareTo(other) retn true.
equals(Object) - Method in class org.apache.hadoop.mapreduce.counters.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.registry.client.types.RegistryPathStatus
Equality operator checks size, time and path of the entries.
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.ContainerResourceIncreaseRequest
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.NMToken
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.NodeId
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.Priority
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.ReservationId
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.ReservationRequest
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.Resource
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
 
equals(Object) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
 
equals(Object) - Method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogKey
 
equals(Object) - Method in class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
 
equals(Object) - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
 
equals(Object) - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
equals(Object) - Method in class org.apache.hadoop.yarn.security.NMTokenIdentifier
 
Event<TYPE extends Enum<TYPE>> - Interface in org.apache.hadoop.yarn.event
Interface defining events api.
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
 
eventDispatchers - Variable in class org.apache.hadoop.yarn.event.AsyncDispatcher
 
EventHandler<T extends Event> - Interface in org.apache.hadoop.yarn.event
Interface for handling events of type T
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
execute() - Method in class org.apache.hadoop.tools.DistCp
Implements the core-execution.
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.
exists(String) - Method in interface org.apache.hadoop.registry.client.api.RegistryOperations
Probe for a path existing.
exists(String) - Method in class org.apache.hadoop.registry.client.impl.zk.RegistryOperationsService
 
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.
expire(O) - Method in class org.apache.hadoop.yarn.util.AbstractLivelinessMonitor
 
expunge() - Method in class org.apache.hadoop.fs.Trash
Delete old checkpoint(s).
external - Variable in class org.apache.hadoop.registry.client.types.ServiceRecord
List of endpoints intended for use to external callers
extractOutputKeyValue(String, String, String, List<Integer>, List<Integer>, int, boolean, boolean) - Method in class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
extractServiceRecords(RegistryOperations, String, Collection<RegistryPathStatus>) - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
Extract all service records under a list of stat operations...this skips entries that are too short or simply not matching
extractServiceRecords(RegistryOperations, String, Map<String, RegistryPathStatus>) - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
Extract all service records under a list of stat operations...this non-atomic action skips entries that are too short or simply not matching.
extractServiceRecords(RegistryOperations, String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
Extract all service records under a list of stat operations...this non-atomic action skips entries that are too short or simply not matching.

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
 
FailoverFailedException - Exception in org.apache.hadoop.ha
Exception thrown to indicate service failover has failed.
FailoverFailedException(String) - Constructor for exception org.apache.hadoop.ha.FailoverFailedException
 
FailoverFailedException(String, Throwable) - Constructor for exception org.apache.hadoop.ha.FailoverFailedException
 
failTask(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.Job
Fail indicated task attempt.
FenceMethod - Interface in org.apache.hadoop.ha
A fencing method is a method by which one node can forcibly prevent another node from making continued progress.
Field() - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
fieldNames - Variable in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
 
FieldSelectionHelper - Class in org.apache.hadoop.mapreduce.lib.fieldsel
This class implements a mapper/reducer class that can be used to perform field selections in a manner similar to unix cut.
FieldSelectionHelper() - Constructor for class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
FieldSelectionHelper(Text, Text) - Constructor for class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionHelper
 
FieldSelectionMapper<K,V> - Class in org.apache.hadoop.mapreduce.lib.fieldsel
This class implements a mapper class that can be used to perform field selections in a manner similar to unix cut.
FieldSelectionMapper() - Constructor for class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionMapper
 
FieldSelectionMapReduce<K,V> - Class in org.apache.hadoop.mapred.lib
This class implements a mapper/reducer class that can be used to perform field selections in a manner similar to unix cut.
FieldSelectionMapReduce() - Constructor for class org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
 
FieldSelectionReducer<K,V> - Class in org.apache.hadoop.mapreduce.lib.fieldsel
This class implements a reducer class that can be used to perform field selections in a manner similar to unix cut.
FieldSelectionReducer() - Constructor for class org.apache.hadoop.mapreduce.lib.fieldsel.FieldSelectionReducer
 
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
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.
fileCreated() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Indicate that we just created a file through WASB.
fileDeleted() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Indicate that we just deleted a file through WASB.
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
FILEOUTPUTCOMMITTER_ALGORITHM_VERSION - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
 
FILEOUTPUTCOMMITTER_ALGORITHM_VERSION_DEFAULT - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
 
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(Path, long, long, String[], 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
FileSplit(Path, long, long, String[], String[]) - Constructor for class org.apache.hadoop.mapreduce.lib.input.FileSplit
Constructs a split with host and cached-blocks 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
 
FileStatus(FileStatus) - Constructor for class org.apache.hadoop.fs.FileStatus
Copy constructor.
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.
finalize() - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
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.mapred.Counters.Group
 
findCounter(String, boolean) - Method in class org.apache.hadoop.mapred.Counters.Group
 
findCounter(String) - Method in class org.apache.hadoop.mapred.Counters.Group
 
findCounter(String, String) - Method in class org.apache.hadoop.mapreduce.counters.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.
findProvider(List<KeyProvider>, String) - Static method in class org.apache.hadoop.crypto.key.KeyProvider
Find the provider with the given key.
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
 
findTimestampedDirectories() - Method in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
Finds all history directories with a timestamp component by scanning the filesystem.
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
 
finish() - Method in class org.apache.hadoop.yarn.applications.distributedshell.ApplicationMaster
 
finishApplicationMaster(FinishApplicationMasterRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationMasterProtocol
The interface used by an ApplicationMaster to notify the ResourceManager about its completion (success or failed).
FinishApplicationMasterRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The finalization request sent by the ApplicationMaster to inform the ResourceManager about its completion.
FinishApplicationMasterRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.FinishApplicationMasterRequest
 
FinishApplicationMasterResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a ApplicationMaster on it's completion.
FinishApplicationMasterResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.FinishApplicationMasterResponse
 
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.
FIXED_RECORD_LENGTH - Static variable in class org.apache.hadoop.mapred.FixedLengthInputFormat
 
FIXED_RECORD_LENGTH - Static variable in class org.apache.hadoop.mapreduce.lib.input.FixedLengthInputFormat
 
FixedLengthInputFormat - Class in org.apache.hadoop.mapred
FixedLengthInputFormat is an input format used to read input files which contain fixed length records.
FixedLengthInputFormat() - Constructor for class org.apache.hadoop.mapred.FixedLengthInputFormat
 
FixedLengthInputFormat - Class in org.apache.hadoop.mapreduce.lib.input
FixedLengthInputFormat is an input format used to read input files which contain fixed length records.
FixedLengthInputFormat() - Constructor for class org.apache.hadoop.mapreduce.lib.input.FixedLengthInputFormat
 
fixRelativePart(Path) - Method in class org.apache.hadoop.fs.FileSystem
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.crypto.key.KeyProvider
Ensures that any changes to the keys are written to persistent store.
flush() - Method in class org.apache.hadoop.io.compress.CompressionOutputStream
 
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
 
flush() - Method in class org.apache.hadoop.metrics2.sink.GraphiteSink
 
flush() - Method in class org.apache.hadoop.security.alias.CredentialProvider
Ensures that any changes to the credentials are written to persistent store.
flush() - Method in class org.apache.hadoop.yarn.ContainerLogAppender
 
flush() - Method in class org.apache.hadoop.yarn.ContainerRollingLogAppender
 
FORBIDDEN_RELATION - Static variable in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
Error code returned if the user is denied to relate the entity to another one in different domain
forceKillApplication(KillApplicationRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationClientProtocol
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.
fromString(String) - Static method in class org.apache.hadoop.yarn.api.records.ContainerId
 
fs - Variable in class org.apache.hadoop.fs.FilterFileSystem
 
fs - Variable in class org.apache.hadoop.fs.TrashPolicy
 
FS_APPLICATION_HISTORY_STORE_COMPRESSION_TYPE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
T-file compression types used to compress history data.
FS_APPLICATION_HISTORY_STORE_URI - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
URI for FileSystemApplicationHistoryStore
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_BASED_RM_CONF_STORE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Store the related configuration files in File System
FS_CLIENT_RESOLVE_REMOTE_SYMLINKS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for FS_CLIENT_RESOLVE_REMOTE_SYMLINKS_KEY
FS_CLIENT_RESOLVE_REMOTE_SYMLINKS_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_DU_INTERVAL_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for FS_DU_INTERVAL_KEY
FS_DU_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 - Static variable in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
FS_FTP_HOST_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
FS_FTP_HOST_PORT - Static variable in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
FS_FTP_HOST_PORT_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
FS_FTP_PASSWORD_PREFIX - Static variable in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
FS_FTP_USER_PREFIX - Static variable in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
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_NODE_LABELS_STORE_RETRY_POLICY_SPEC - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
FS_NODE_LABELS_STORE_ROOT_DIR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
URI for NodeLabelManager
FS_RM_STATE_STORE_NUM_RETRIES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
FS_RM_STATE_STORE_RETRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
FS_RM_STATE_STORE_RETRY_POLICY_SPEC - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
FS_RM_STATE_STORE_URI - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
URI for FileSystemRMStateStore
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
FsAction - Enum in org.apache.hadoop.fs.permission
File system actions, e.g.
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.
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, boolean, long, 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.
generateKey(int, String) - Method in class org.apache.hadoop.crypto.key.KeyProvider
Generates a key material.
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.
 
generateStateGraph(String) - Method in class org.apache.hadoop.yarn.state.StateMachineFactory
Generate a graph represents the state graph of this StateMachine
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.crypto.key.KeyProviderFactory
Create a KeyProvider based on a provided URI.
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
For backwards compatibility.
get(Class<? extends WritableComparable>, Configuration) - 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.
get(String) - Method in class org.apache.hadoop.registry.client.types.ServiceRecord
Get the "other" attribute with a specific key
get(String, String) - Method in class org.apache.hadoop.registry.client.types.ServiceRecord
Get the "other" attribute with a specific key.
getAccessibleNodeLabels() - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
Get the accessible node labels of the queue.
getAccessTime() - Method in class org.apache.hadoop.fs.FileStatus
Get the access time of the file.
getAclBit() - Method in class org.apache.hadoop.fs.permission.FsPermission
Returns true if there is also an ACL (access control list).
getAclStatus(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Gets the ACLs of files and directories.
getAclStatus(Path) - Method in class org.apache.hadoop.fs.FileContext
Gets the ACLs of files and directories.
getAclStatus(Path) - Method in class org.apache.hadoop.fs.FileSystem
Gets the ACL of a file or directory.
getAclStatus(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getAclStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getAclStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getAclString() - Method in class org.apache.hadoop.security.authorize.AccessControlList
Returns the access control list as a String that can be used for building a new instance by sending it to the constructor of AccessControlList.
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.
getAddress() - Method in class org.apache.hadoop.ha.HAServiceTarget
 
getAddressField(Map<String, String>, String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
Get a specific field from an address -raising an exception if the field is not present
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
getAliases() - Method in class org.apache.hadoop.security.alias.CredentialProvider
Get the aliases for all credentials.
getAllEvents() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents
Get a list of TimelineEvents.EventsOfOneEntity instances
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 class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
Get the list of newly allocated Container by the ResourceManager.
getAllocatedResource() - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
Get the allocated Resource of the container.
getAllPartialJobs() - Method in interface org.apache.hadoop.mapreduce.v2.hs.HistoryStorage
Get all of the cached jobs.
getAllQueues() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get information (QueueInfo) about all queues, recursively if there is a hierarchy
getAllRecords() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
Retrieves all the records managed by this MetricsContext.
getAllServicesMetaData() - Method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainersResponse
Get the meta-data 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
 
getAMCommand() - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
If the ResourceManager needs the ApplicationMaster to take some action then it will send an AMCommand to the ApplicationMaster.
getAMContainerId() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
Get the ContainerId of AMContainer for this attempt
getAMContainerResourceRequest() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get ResourceRequest of AM container, if this is not null, scheduler will use this to acquire resource for AM container.
getAMContainerSpec() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the ContainerLaunchContext to describe the Container with which the ApplicationMaster is launched.
getAMRMToken() - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
The AMRMToken that belong to this attempt
getAMRMToken() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the AMRM token of the application.
getAMRMToken(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get the AMRM token of the application.
getAMRMTokenService(Configuration) - Static method in class org.apache.hadoop.yarn.client.ClientRMProxy
 
getAppId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReleaseSharedCacheResourceRequest
Get the ApplicationId of the resource to be released.
getAppId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.UseSharedCacheResourceRequest
Get the ApplicationId of the resource to be used.
getApplicationACLs() - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
Get the ApplicationACLs for the application.
getApplicationACLs() - Method in class org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get the ApplicationACLs for the application.
getApplicationAcls() - Method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogReader
Returns ACLs for the application.
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptReportRequest
Get the ApplicationAttemptId of an application attempt.
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainersRequest
Get the ApplicationAttemptId of an application attempt.
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
Get the ApplicationAttemptId of this attempt of the application
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.api.records.ContainerId
Get the ApplicationAttemptId of the application to which the Container was assigned.
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
 
getApplicationAttemptID() - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
 
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.security.NMTokenIdentifier
 
getApplicationAttemptList() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptsResponse
Get a list of ApplicationReport of an application.
getApplicationAttemptReport() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptReportResponse
Get the ApplicationAttemptReport for the application attempt.
getApplicationAttemptReport(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.AHSClient
Get a report of the given ApplicationAttempt.
getApplicationAttemptReport(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get a report of the given ApplicationAttempt.
GetApplicationAttemptReportRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request sent by a client to the ResourceManager to get an ApplicationAttemptReport for an application attempt.
GetApplicationAttemptReportRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptReportRequest
 
GetApplicationAttemptReportResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting an application attempt report.
GetApplicationAttemptReportResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptReportResponse
 
getApplicationAttempts(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.AHSClient
Get a report of all (ApplicationAttempts) of Application in the cluster.
getApplicationAttempts(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get a report of all (ApplicationAttempts) of Application in the cluster.
GetApplicationAttemptsRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request from clients to get a list of application attempt reports of an application from the ResourceManager.
GetApplicationAttemptsRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptsRequest
 
GetApplicationAttemptsResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting a list of ApplicationAttemptReport for application attempts.
GetApplicationAttemptsResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptsResponse
 
getApplicationId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptsRequest
Get the ApplicationId of an application
getApplicationId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportRequest
Get the ApplicationId of the application.
getApplicationId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse
Get the new ApplicationId allocated by the ResourceManager.
getApplicationId() - Method in class 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.protocolrecords.MoveApplicationAcrossQueuesRequest
Get the ApplicationId of the application to be moved.
getApplicationId() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
Get the ApplicationId of the ApplicationAttempId.
getApplicationId() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the ApplicationId of the application.
getApplicationId() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the ApplicationId of the submitted application.
getApplicationList() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsResponse
Get ApplicationReport for applications.
getApplicationName() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the application name.
getApplicationOwner() - Method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogReader
Returns the owner of the application.
getApplicationReport() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportResponse
Get the ApplicationReport for the application.
getApplicationReport(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.AHSClient
Get a report of the given Application.
getApplicationReport(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get a report of the given Application.
GetApplicationReportRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request sent by a client to the ResourceManager to get an ApplicationReport for an application.
GetApplicationReportRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportRequest
 
GetApplicationReportResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting an application report.
GetApplicationReportResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportResponse
 
getApplicationResourceUsageReport() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Retrieve the structure containing the job resources for this application
getApplications() - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
Get the running applications of the queue.
getApplications() - Method in class org.apache.hadoop.yarn.client.api.AHSClient
Get a report (ApplicationReport) of all Applications in the cluster.
getApplications() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get a report (ApplicationReport) of all Applications in the cluster.
getApplications(Set<String>) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get a report (ApplicationReport) of Applications matching the given application types in the cluster.
getApplications(EnumSet<YarnApplicationState>) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get a report (ApplicationReport) of Applications matching the given application states in the cluster.
getApplications(Set<String>, EnumSet<YarnApplicationState>) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get a report (ApplicationReport) of Applications matching the given application types and application states in the cluster.
GetApplicationsRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request from clients to get a report of Applications in the cluster from the ResourceManager.
GetApplicationsRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
 
GetApplicationsResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting an ApplicationReport for applications.
GetApplicationsResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsResponse
 
getApplicationStates() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
Get the application states to filter applications on
getApplicationSubmissionContext() - Method in class org.apache.hadoop.yarn.api.protocolrecords.SubmitApplicationRequest
Get the ApplicationSubmissionContext for the application.
getApplicationSubmissionContext() - Method in class org.apache.hadoop.yarn.client.api.YarnClientApplication
 
getApplicationSubmitter() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
getApplicationSubmitter() - Method in class org.apache.hadoop.yarn.security.NMTokenIdentifier
 
getApplicationTags() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
Get the tags to filter applications on
getApplicationTags() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Get all tags corresponding to the application
getApplicationTags() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get tags for the application
getApplicationType() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the application's Type
getApplicationType() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the application type
getApplicationTypes() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
Get the application types to filter applications on
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.
getArrival() - Method in class org.apache.hadoop.yarn.api.records.ReservationDefinition
Get the arrival time or the earliest time from which the resource(s) can be allocated.
getAskList() - Method in class 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
 
getAssignedNode() - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
Get the allocated NodeId where container is running.
getAttemptFailuresValidityInterval() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the attemptFailuresValidityInterval in milliseconds for the application
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.
getAuthMethod() - Method in enum org.apache.hadoop.security.UserGroupInformation.AuthenticationMethod
 
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 class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
Get the available headroom for resources in the cluster for the application.
getAvailableResources() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
Get the currently available resources in the cluster.
getAvailableResources() - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
Get the currently available resources in the cluster.
getBaseName(String) - Static method in class org.apache.hadoop.crypto.key.KeyProvider
Split the versionName in to a base name.
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.
 
getBlacklistAdditions() - Method in class org.apache.hadoop.yarn.api.records.ResourceBlacklistRequest
Get the list of resource-names which should be added to the application blacklist.
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.
getBlacklistRemovals() - Method in class org.apache.hadoop.yarn.api.records.ResourceBlacklistRequest
Get the list of resource-names which should be removed from the application blacklist.
getBlacklistReport() - Method in class org.apache.hadoop.mapreduce.TaskTrackerInfo
Gets a descriptive report about why the tasktracker was blacklisted.
getBlockDownloadLatency() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Get the current rolling average of the download latency.
getBlockers() - Method in class org.apache.hadoop.service.AbstractService
 
getBlockers() - Method in interface org.apache.hadoop.service.Service
Get the blockers on a service -remote dependencies that are stopping the service from being live.
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
 
getBlockUploadLatency() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Get the current rolling average of the upload latency.
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
 
getBuffer(boolean, int) - Method in interface org.apache.hadoop.io.ByteBufferPool
Get a new direct ByteBuffer.
getBuffer(boolean, int) - Method in class org.apache.hadoop.io.ElasticByteBufferPool
 
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
getCachedHosts() - Method in class org.apache.hadoop.fs.BlockLocation
Get the list of hosts (hostname) hosting a cached replica of the block
getCacheFiles() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get cache files set in the Configuration
getCachePoolDefault() - Static method in class org.apache.hadoop.fs.permission.FsPermission
Get the default permission for cache pools.
getCallbackHandler() - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
 
getCancelTokensWhenComplete() - Method in class 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.
getCanonicalServiceName() - Method in class org.apache.hadoop.fs.s3.S3FileSystem
 
getCanonicalServiceName() - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
 
getCanonicalUri() - Method in class org.apache.hadoop.fs.FileSystem
Return a canonicalized form of this FileSystem's URI.
getCanonicalUri() - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getCapability() - Method in class org.apache.hadoop.yarn.api.records.ContainerResourceIncreaseRequest
 
getCapability() - Method in class org.apache.hadoop.yarn.api.records.NodeReport
Get the total Resource on the node.
getCapability() - Method in class org.apache.hadoop.yarn.api.records.ReservationRequest
Get the Resource capability of the request.
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 class org.apache.hadoop.yarn.api.records.QueueInfo
Get the configured capacity of the queue.
getChecksum(Configuration) - Static method in class org.apache.hadoop.yarn.sharedcache.SharedCacheChecksumFactory
Get a new SharedCacheChecksum object based on the configurable algorithm implementation (see yarn.sharedcache.checksum.algo.impl)
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.
getChecksumOpt() - Method in class org.apache.hadoop.fs.FileChecksum
 
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 class org.apache.hadoop.yarn.client.api.YarnClient
Get information (QueueInfo) about all the immediate children queues of the given queue
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 class 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.
getClassName() - Method in class org.apache.hadoop.tracing.SpanReceiverInfo
 
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.
getClient() - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
 
getClientAcls() - Method in class org.apache.hadoop.registry.client.impl.zk.RegistryOperationsService
Get the aggregate set of ACLs the client should use to create directories
getClientName() - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
 
getClientToAMToken() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the client token for communicating with the ApplicationMaster.
getClientToAMTokenMasterKey() - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
Get ClientToAMToken master key.
getCluster() - Method in class org.apache.hadoop.mapreduce.Job
 
getClusterHandle() - Method in class org.apache.hadoop.mapred.JobClient
Get a handle to the Cluster
getClusterId(Configuration) - Static method in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
getClusterMetrics(GetClusterMetricsRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationClientProtocol
The interface used by clients to get metrics about the cluster from the ResourceManager.
getClusterMetrics() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterMetricsResponse
Get the YarnClusterMetrics for the cluster.
GetClusterMetricsRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request sent by clients to get cluster metrics from the ResourceManager.
GetClusterMetricsRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetClusterMetricsRequest
 
GetClusterMetricsResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting cluster metrics.
GetClusterMetricsResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetClusterMetricsResponse
 
getClusterNodeCount() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
Get the current number of nodes in the cluster.
getClusterNodeCount() - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
Get the current number of nodes in the cluster.
getClusterNodeLabels(GetClusterNodeLabelsRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationClientProtocol
The interface used by client to get node labels in the cluster
getClusterNodeLabels() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
The interface used by client to get node labels in the cluster
GetClusterNodeLabelsRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
 
GetClusterNodeLabelsRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodeLabelsRequest
 
GetClusterNodeLabelsResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
 
GetClusterNodeLabelsResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodeLabelsResponse
 
getClusterNodes(GetClusterNodesRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationClientProtocol
The interface used by clients to get a report of all nodes in the cluster from the ResourceManager.
GetClusterNodesRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request from clients to get a report of all nodes in the cluster from the ResourceManager.
GetClusterNodesRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesRequest
 
GetClusterNodesResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting a NodeReport for all nodes.
GetClusterNodesResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesResponse
 
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.
getClusterTimestamp() - Method in class org.apache.hadoop.yarn.api.records.ReservationId
Get the start time of the ResourceManager which is used to generate globally unique ReservationId.
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 discovered via a Java ServiceLoader, or 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.
getCombinerKeyGroupingComparator() - Method in class org.apache.hadoop.mapred.JobConf
Get the user defined WritableComparable comparator for grouping keys of inputs to the combiner.
getCombinerKeyGroupingComparator() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the user defined RawComparator comparator for grouping keys of inputs to the combiner.
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 class 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
 
getCommittedTaskPath(int, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Compute the path where the output of a committed task is stored until the entire job is committed for a specific application attempt.
getCommittedTaskPath(int, TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.PartialFileOutputCommitter
 
getComparator() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Return comparator defining the ordering for RecordReaders in this composite.
getComparator() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Return comparator defining the ordering for RecordReaders in this composite.
getCompletedContainersStatuses() - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
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?
getConcurrency() - Method in class org.apache.hadoop.yarn.api.records.ReservationRequest
Get the number of containers that need to be scheduled concurrently.
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.crypto.key.KeyProvider
Return the provider configuration.
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
 
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.io.WritableComparator
 
getConf() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Return the configuration used by this object.
getConf() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
 
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
 
getConf() - Method in class org.apache.hadoop.net.TableMapping
 
getConf() - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
 
getConfig() - Method in class org.apache.hadoop.service.AbstractService
 
getConfig() - Method in interface org.apache.hadoop.service.Service
Get the configuration of this service.
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
 
getContainerExitStatus() - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
Get the final exit status of the container.
getContainerId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerReportRequest
Get the ContainerId of the Container.
getContainerId() - Method in class org.apache.hadoop.yarn.api.records.ContainerId
Get the identifier of the ContainerId.
getContainerId() - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
Get the ContainerId of the container.
getContainerId() - Method in class org.apache.hadoop.yarn.api.records.ContainerResourceIncreaseRequest
 
getContainerId() - Method in class org.apache.hadoop.yarn.api.records.ContainerStatus
Get the ContainerId of the container.
getContainerID() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
getContainerIds() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusesRequest
Get the list of ContainerIds of containers for which to obtain the ContainerStatus.
getContainerIds() - Method in class org.apache.hadoop.yarn.api.protocolrecords.StopContainersRequest
Get the ContainerIds of the containers to be stopped.
getContainerLaunchContext() - Method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainerRequest
Get the ContainerLaunchContext for the container to be started by the NodeManager.
getContainerList() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainersResponse
Get a list of ContainerReport for all the containers of an application attempt.
getContainerLogDir() - Method in class org.apache.hadoop.yarn.ContainerLogAppender
Getter/Setter methods for log4j.
getContainerLogDir() - Method in class org.apache.hadoop.yarn.ContainerRollingLogAppender
Getter/Setter methods for log4j.
getContainerLogFile() - Method in class org.apache.hadoop.yarn.ContainerLogAppender
 
getContainerLogFile() - Method in class org.apache.hadoop.yarn.ContainerRollingLogAppender
 
getContainerLogsReader(ContainerId) - Method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogReader
Get a ContainerLogsReader to read the logs for the specified container.
getContainerReport() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerReportResponse
Get the ContainerReport for the container.
getContainerReport(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.AHSClient
Get a report of the given Container.
getContainerReport(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get a report of the given Container.
GetContainerReportRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request sent by a client to the ResourceManager to get an ContainerReport for a container.
GetContainerReportRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetContainerReportRequest
 
GetContainerReportResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting a container report.
GetContainerReportResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetContainerReportResponse
 
getContainers() - Method in class org.apache.hadoop.yarn.api.records.PreemptionContract
Assign the set of PreemptionContainer specifying which containers owned by the ApplicationMaster that may be reclaimed by the ResourceManager.
getContainers() - Method in class org.apache.hadoop.yarn.api.records.StrictPreemptionContract
Get the set of PreemptionContainer specifying containers owned by the ApplicationMaster that may be reclaimed by the ResourceManager.
getContainers(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.AHSClient
Get a report of all (Containers) of ApplicationAttempt in the cluster.
getContainers(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get a report of all (Containers) of ApplicationAttempt in the cluster.
getContainersFromPreviousAttempts() - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
Get the list of running containers as viewed by ResourceManager from previous application attempts.
GetContainersRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request from clients to get a list of container reports, which belong to an application attempt from the ResourceManager.
GetContainersRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetContainersRequest
 
GetContainersResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting a list of ContainerReport for containers.
GetContainersResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetContainersResponse
 
getContainerState() - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
Get the final ContainerState of the container.
getContainerStatus(ContainerId, NodeId) - Method in class org.apache.hadoop.yarn.client.api.NMClient
Query the status of a container.
getContainerStatusAsync(ContainerId, NodeId) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
 
getContainerStatuses(GetContainerStatusesRequest) - Method in interface org.apache.hadoop.yarn.api.ContainerManagementProtocol
The API used by the ApplicationMaster to request for current statuses of Containers from the NodeManager.
getContainerStatuses() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusesResponse
Get the ContainerStatuses of the requested containers.
GetContainerStatusesRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request sent by the ApplicationMaster to the NodeManager to get ContainerStatus of requested containers.
GetContainerStatusesRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusesRequest
 
GetContainerStatusesResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the NodeManager to the ApplicationMaster when asked to obtain the ContainerStatus of requested containers.
GetContainerStatusesResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusesResponse
 
getContainerToken() - Method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainerRequest
Get the container token to be used for authorization during starting container.
getContainerToken() - Method in class org.apache.hadoop.yarn.api.records.Container
Get the ContainerToken for the container.
getContent() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDelegationTokenResponse
 
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.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.
getContract() - Method in class org.apache.hadoop.yarn.api.records.PreemptionMessage
 
getCount() - Method in class org.apache.hadoop.record.Buffer
Deprecated.
Get the current count of the buffer.
getCounter() - Method in class org.apache.hadoop.mapred.Counters.Counter
 
getCounter(Enum<?>) - Method in class org.apache.hadoop.mapred.Counters
Returns current value of the specified counter, or 0 if the counter does not exist.
getCounter(String) - Method in class org.apache.hadoop.mapred.Counters.Group
 
getCounter(int, String) - Method in class org.apache.hadoop.mapred.Counters.Group
Deprecated.
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
 
getCounterForName(String) - Method in class org.apache.hadoop.mapred.Counters.Group
Get the counter for the given name and create it if it doesn't exist.
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.
getCpuUsagePercent() - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Get the CPU usage by all the processes in the process-tree based on average between samples as a ratio of overall CPU cycles similar to top.
getCreatedTime() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
Get the created time of the domain
getCreationTime() - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
Get the creation time of the container.
getCreationTime() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
getCredentialEntry(String) - Method in class org.apache.hadoop.security.alias.CredentialProvider
Get the credential entry for a specific alias.
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.
getCumulativeCpuTime() - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Get the CPU time in millisecond used by all the processes in the process-tree since the process-tree was created
getCumulativeRssmem() - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Deprecated.
getCumulativeRssmem(int) - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Deprecated.
getCumulativeVmem() - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Deprecated.
getCumulativeVmem(int) - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Deprecated.
getCurrentApplicationAttemptId() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the ApplicationAttemptId of the current attempt of the application
getCurrentCapacity() - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
Get the current capacity of the queue.
getCurrentKey(String) - Method in class org.apache.hadoop.crypto.key.KeyProvider
Get the current version of the key, which should be used for encrypting new data.
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Get the current key
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReaderWrapper
 
getCurrentKey() - Method in class org.apache.hadoop.mapreduce.lib.input.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.
getCurrentMaximumDownloadBandwidth() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Get the current maximum download bandwidth.
getCurrentMaximumUploadBandwidth() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Get the current maximum upload bandwidth.
getCurrentState() - Method in exception org.apache.hadoop.yarn.state.InvalidStateTransitonException
 
getCurrentState() - Method in interface org.apache.hadoop.yarn.state.StateMachine
 
getCurrentTrashDir() - Method in class org.apache.hadoop.fs.TrashPolicy
Get the current working directory of the Trash Policy
getCurrentUsernameUnencoded(String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
Get the current username, using the value of the parameter env_hadoop_username if it is set on an insecure cluster.
getCurrentValue(V) - Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.db.DBRecordReader
Get the current value.
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReader
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileRecordReaderWrapper
 
getCurrentValue() - Method in class org.apache.hadoop.mapreduce.lib.input.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.
getCurrentWebResponses() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Gets the current number of web responses obtained from Azure Storage.
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
 
getDeadline() - Method in class org.apache.hadoop.yarn.api.records.ReservationDefinition
Get the deadline or the latest time by when the resource(s) must be allocated.
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
 
getDeclaredFieldsIncludingInherited(Class<?>) - Static method in class org.apache.hadoop.util.ReflectionUtils
Gets all the declared fields of a class including fields declared in superclasses.
getDeclaredMethodsIncludingInherited(Class<?>) - Static method in class org.apache.hadoop.util.ReflectionUtils
Gets all the declared methods of a class including methods declared in superclasses.
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
 
getDecreasedContainers() - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
Get the list of newly decreased containers by NodeManager
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
Deprecated.
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.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
getDefaultDelegationTokenAuthenticator() - Static method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
Returns the default DelegationTokenAuthenticator class to use when an DelegationTokenAuthenticatedURL instance is created without specifying one.
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.
getDefaultNodeLabelExpression() - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
Get the default node label expression of the queue, this takes affect only when the ApplicationSubmissionContext and ResourceRequest don't specify their NodeLabelExpression.
getDefaultPort() - Method in class org.apache.hadoop.fs.FileSystem
Get the default port for this file system.
getDefaultPort() - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
Get the default port for this FTPFileSystem.
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
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.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(Credentials, String) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
Deprecated.
Use Credentials.getToken(org.apache.hadoop.io.Text) instead, this method is included for compatibility against Hadoop-1
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(URL, DelegationTokenAuthenticatedURL.Token, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
Requests a delegation token using the configured Authenticator for authentication.
getDelegationToken(URL, DelegationTokenAuthenticatedURL.Token, String, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
Requests a delegation token using the configured Authenticator for authentication.
getDelegationToken() - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL.Token
 
getDelegationToken(URL, AuthenticatedURL.Token, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
Requests a delegation token using the configured Authenticator for authentication.
getDelegationToken(URL, AuthenticatedURL.Token, String, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
Requests a delegation token using the configured Authenticator for authentication.
getDelegationToken(String) - Method in class org.apache.hadoop.yarn.client.api.TimelineClient
Get a delegation token so as to be able to talk to the timeline server in a secure way.
GetDelegationTokenRequest - Interface in org.apache.hadoop.mapreduce.v2.api.protocolrecords
 
GetDelegationTokenRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request issued by the client to get a delegation token from the ResourceManager.
GetDelegationTokenRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenRequest
 
GetDelegationTokenResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
Response to a GetDelegationTokenRequest request from the client.
GetDelegationTokenResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenResponse
 
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
 
getDescription() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
Get the domain description
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 class org.apache.hadoop.yarn.api.protocolrecords.FinishApplicationMasterRequest
Get diagnostic information on application failure.
getDiagnostics() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
Get the diagnositic information of the application attempt in case of errors.
getDiagnostics() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the diagnositic information of the application in case of errors.
getDiagnostics() - Method in class org.apache.hadoop.yarn.api.records.ContainerStatus
Get diagnostic messages for failed containers.
getDiagnosticsInfo() - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
Get the DiagnosticsInfo of the container.
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 class org.apache.hadoop.mapred.Counters.Counter
 
getDisplayName() - Method in class org.apache.hadoop.mapred.Counters.Group
 
getDisplayName() - Method in interface org.apache.hadoop.mapreduce.Counter
Get the display name of the counter.
getDisplayName() - Method in 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
 
getDomainId() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Get the ID of the domain that the entity is to be put
getDomains() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomains
Get a list of domains
getDouble(String, double) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a double.
getDU(File) - Static method in class org.apache.hadoop.fs.FileUtil
Takes an input dir and returns the du on that local directory.
getDuration() - Method in class org.apache.hadoop.yarn.api.records.ReservationRequest
Get the duration in milliseconds for which the resource is required.
getEffectivePermission(AclEntry) - Method in class org.apache.hadoop.fs.permission.AclStatus
Get the effective permission for the AclEntry
getEffectivePermission(AclEntry, FsPermission) - Method in class org.apache.hadoop.fs.permission.AclStatus
Get the effective permission for the AclEntry.
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.
getEncryptDataTransfer() - Method in class org.apache.hadoop.fs.FsServerDefaults
 
getEncryptedBit() - Method in class org.apache.hadoop.fs.permission.FsPermission
Returns true if the file is encrypted or directory is in an encryption zone
getEncryptedSpillKey(Credentials) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
 
getEndColumn() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
getEndLine() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
getEndTime() - Method in class org.apache.hadoop.conf.ReconfigurationTaskStatus
 
getEntities() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntities
Get a list of entities
getEntityId() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Get the entity Id
getEntityId() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents.EventsOfOneEntity
Get the entity Id
getEntityId() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
Get the entity Id
getEntityType() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Get the entity type
getEntityType() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents.EventsOfOneEntity
Get the entity type
getEntityType() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
Get the entity type
getEntries() - Method in class org.apache.hadoop.fs.permission.AclStatus
Returns the list of all ACL entries, ordered by their natural ordering.
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 class org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get environment variables for the container.
getError() - Static method in class org.apache.hadoop.log.metrics.EventCounter
 
getErrorCode() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
Get the error code
getErrors() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse
Get a list of TimelinePutResponse.TimelinePutError instances
getEvent() - Method in exception org.apache.hadoop.yarn.state.InvalidStateTransitonException
 
getEventHandler() - Method in class org.apache.hadoop.yarn.event.AsyncDispatcher
 
getEventHandler() - Method in interface org.apache.hadoop.yarn.event.Dispatcher
 
getEventId() - Method in class org.apache.hadoop.mapreduce.TaskCompletionEvent
Returns event Id.
getEventInfo() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
Set the information of the event
getEventInfoJAXB() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
 
getEvents() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Get a list of events related to the entity
getEvents() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents.EventsOfOneEntity
Get a list of events
getEventType() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
Get the event type
getExceptions() - Method in exception org.apache.hadoop.io.MultipleIOException
 
getExcludePattern() - Method in class org.apache.hadoop.yarn.api.records.LogAggregationContext
Get exclude pattern.
getExecutable(JobConf) - Static method in class org.apache.hadoop.mapred.pipes.Submitter
Get the URI of the application's executable.
getExitStatus() - Method in class org.apache.hadoop.yarn.api.records.ContainerStatus
Get the exit status for the container.
getExpiryTimeStamp() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
getExternalEndpoint(String) - Method in class org.apache.hadoop.registry.client.types.ServiceRecord
Look up an external endpoint
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
 
getFailedRequests() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusesResponse
Get the containerId-to-exception map in which the exception indicates error from per container for failed requests
getFailedRequests() - Method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainersResponse
Get the containerId-to-exception map in which the exception indicates error from per container for failed requests
getFailedRequests() - Method in class org.apache.hadoop.yarn.api.protocolrecords.StopContainersResponse
Get the containerId-to-exception map in which the exception indicates error from per container for failed requests
getFailureCause() - Method in class org.apache.hadoop.service.AbstractService
 
getFailureCause() - Method in interface org.apache.hadoop.service.Service
Get the first exception raised during the service failure.
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.
getFailureState() - Method in class org.apache.hadoop.service.AbstractService
 
getFailureState() - Method in interface org.apache.hadoop.service.Service
Get the state in which the failure in Service.getFailureCause() occurred.
getFatal() - Static method in class org.apache.hadoop.log.metrics.EventCounter
 
getFencer() - Method in class org.apache.hadoop.ha.HAServiceTarget
 
getFencingParameters() - Method in class org.apache.hadoop.ha.HAServiceTarget
 
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 class 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(FileStatus, long, long) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
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.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.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, long) - Method in class org.apache.hadoop.fs.FileSystem
Get the checksum of a file, from the beginning of the file till the specific length.
getFileChecksum(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getFileChecksum(Path, long) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getFileChecksum(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getFileChecksum(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getFileChecksum(Path) - Method in class org.apache.hadoop.yarn.client.api.SharedCacheClient
A convenience method to calculate the checksum of a specified file.
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.
getFileDescriptor() - Method in class org.apache.hadoop.fs.FSDataInputStream
 
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.FileSystem
getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.LocalFileSystem
 
getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
Return a FileStatus representing the given path.
getFileLinkStatus(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getFileListingPath() - Method in class org.apache.hadoop.tools.DistCp
Get default name of the copy listing file.
getFileStatus(Configuration, URI) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
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.azure.NativeAzureFileSystem
 
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.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
getFileSystemClass(String, Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
 
getFileSystemInstanceId() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
The unique identifier for this file system in the metrics.
getFileTimestamps() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get the timestamps of the files.
getFinalApplicationStatus() - Method in class org.apache.hadoop.yarn.api.protocolrecords.FinishApplicationMasterRequest
Get final state of the ApplicationMaster.
getFinalApplicationStatus() - Method in class 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.
getFinishRange() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
Get the range of finish times to filter applications on
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 class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the finish time of the application.
getFinishTime() - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
Get the Finish time of the container.
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.
getFsAction(String) - Static method in enum org.apache.hadoop.fs.permission.FsAction
Get the FsAction enum for String representation of permissions
getFSofPath(Path) - Method in class org.apache.hadoop.fs.FileContext
Get the file system of supplied path.
getFSofPath(Path, Configuration) - Static method in class org.apache.hadoop.fs.FileSystem
 
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.
getGid(String) - Method in interface org.apache.hadoop.security.IdMappingServiceProvider
 
getGidAllowingUnknown(String) - Method in interface org.apache.hadoop.security.IdMappingServiceProvider
 
getGrayListedTaskTrackerCount() - Method in class org.apache.hadoop.mapreduce.ClusterMetrics
Get the number of graylisted trackers in the cluster.
getGraylistedTrackerNames() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated.
getGraylistedTrackers() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated.
getGroup() - Method in class org.apache.hadoop.fs.FileStatus
Get the group associated with the file.
getGroup() - Method in class org.apache.hadoop.fs.permission.AclStatus
Returns the file group.
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.
getGroupName(int, String) - Method in interface org.apache.hadoop.security.IdMappingServiceProvider
 
getGroupNames() - Method in class org.apache.hadoop.mapred.Counters
 
getGroupNames() - Method in class org.apache.hadoop.mapreduce.counters.AbstractCounters
Returns the names of all counter classes.
getGroups() - Method in class org.apache.hadoop.security.authorize.AccessControlList
Get the names of user groups allowed for this service.
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 class org.apache.hadoop.yarn.api.records.NodeReport
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 class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
Get the host on which the ApplicationMaster is running.
getHost() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
Get the host on which this attempt of ApplicationMaster is running.
getHost() - Method in class 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 class org.apache.hadoop.yarn.api.records.URL
Get the host of the URL.
getHosts() - Method in class org.apache.hadoop.fs.BlockLocation
Get the list of hosts (hostname) hosting this block
getHttpAddress() - Method in class 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.tracing.SpanReceiverInfo
 
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 class 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
Deprecated.
getId() - Method in class org.apache.hadoop.yarn.api.records.PreemptionContainer
 
getId() - Method in class org.apache.hadoop.yarn.api.records.ReservationId
Get the long identifier of the ReservationId which is unique for all Reservations started by a particular instance of the ResourceManager.
getId() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
Get the domain ID
getIdentifier() - Method in class org.apache.hadoop.yarn.api.records.Token
Get the token identifier.
GetImage() - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
getIncludeApplications() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
Is information about active applications required?
getIncludeChildQueues() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
Is information about child queues required?
getIncludePattern() - Method in class org.apache.hadoop.yarn.api.records.LogAggregationContext
Get include pattern.
getIncreasedContainers() - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
Get the list of newly increased containers by ResourceManager
getIncreaseRequests() - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
Get the ContainerResourceIncreaseRequest being sent by the ApplicationMaster
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 parameter 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.
getInstrumentation() - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
Gets the metrics source for this file system.
getInt(String, int) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as an int.
getInternalEndpoint(String) - Method in class org.apache.hadoop.registry.client.types.ServiceRecord
Look up an internal endpoint
getInterpreter() - Method in class org.apache.hadoop.yarn.api.records.ReservationRequests
Get the ReservationRequestInterpreter, representing how the list of resources should be allocated, this captures temporal ordering and other constraints.
getInterval() - Method in class org.apache.hadoop.metrics2.lib.MutableQuantiles
 
getInts(String) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a set of comma-delimited int values.
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.
getIsKillCompleted() - Method in class org.apache.hadoop.yarn.api.protocolrecords.KillApplicationResponse
Get the flag which indicates that the process of killing application is completed or not.
getIsUnregistered() - Method in class org.apache.hadoop.yarn.api.protocolrecords.FinishApplicationMasterResponse
Get the flag which indicates that the application has successfully unregistered with the RM and the application can safely stop.
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.
getJobAttemptPath(int) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Compute the path where the output of a given job attempt will be placed.
getJobClient() - Method in class org.apache.hadoop.mapred.jobcontrol.Job
 
getJobConf() - Method in interface org.apache.hadoop.mapred.JobContext
Get the job Configuration
getJobConf() - Method in class org.apache.hadoop.mapred.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.
getJobInner(JobID) - Method in class org.apache.hadoop.mapred.JobClient
 
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
 
getJobStatus() - Method in interface org.apache.hadoop.mapred.RunningJob
Returns a snapshot of the current status, JobStatus, of the Job.
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
 
getJobTrackerState() - Method in class org.apache.hadoop.mapred.ClusterStatus
Deprecated.
getJobTrackerStatus() - Method in class org.apache.hadoop.mapred.ClusterStatus
Get the JobTracker's status.
getJobTrackerStatus() - Method in class org.apache.hadoop.mapreduce.Cluster
Get the JobTracker's status.
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.
getKeepContainersAcrossApplicationAttempts() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the flag which indicates whether to keep containers across application attempts or not.
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.
getKerberosInfo(Class<?>, Configuration) - Method in class org.apache.hadoop.yarn.security.admin.AdminSecurityInfo
 
getKerberosInfo(Class<?>, Configuration) - Method in class org.apache.hadoop.yarn.security.client.ClientRMSecurityInfo
 
getKerberosInfo(Class<?>, Configuration) - Method in class org.apache.hadoop.yarn.security.client.ClientTimelineSecurityInfo
 
getKerberosInfo(Class<?>, Configuration) - Method in class org.apache.hadoop.yarn.security.ContainerManagerSecurityInfo
 
getKerberosInfo(Class<?>, Configuration) - Method in class org.apache.hadoop.yarn.security.SchedulerSecurityInfo
 
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
getKeyId() - Method in class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
 
getKeyId() - Method in class org.apache.hadoop.yarn.security.NMTokenIdentifier
 
getKeys() - Method in class org.apache.hadoop.crypto.key.KeyProvider
Get the key names for all keys.
getKeysMetadata(String...) - Method in class org.apache.hadoop.crypto.key.KeyProvider
Get key metadata in bulk.
getKeyTypeID() - Method in class org.apache.hadoop.record.meta.MapTypeID
Deprecated.
get the TypeID of the map's key element
getKeyVersion(String) - Method in class org.apache.hadoop.crypto.key.KeyProvider
Get the key material for a specific version of the key.
getKeyVersions(String) - Method in class org.apache.hadoop.crypto.key.KeyProvider
Get the key material for all versions of a specific key name.
getKind() - Method in class org.apache.hadoop.yarn.api.records.Token
Get the token kind.
getKind() - Method in class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
 
getKind() - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
 
getKind() - Method in class org.apache.hadoop.yarn.security.client.RMDelegationTokenIdentifier
 
getKind() - Method in class org.apache.hadoop.yarn.security.client.TimelineDelegationTokenIdentifier
 
getKind() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
getKind() - Method in class org.apache.hadoop.yarn.security.NMTokenIdentifier
 
getLabelsToNodes(GetLabelsToNodesRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationClientProtocol
The interface used by client to get labels to nodes mappings in existing cluster
getLabelsToNodes() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
The interface used by client to get labels to nodes mapping in existing cluster
getLabelsToNodes(Set<String>) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
The interface used by client to get labels to nodes mapping for specified labels in existing cluster
getLastHealthReportTime() - Method in class org.apache.hadoop.yarn.api.records.NodeReport
Get the last timestamp at which the health report was received.
getLeasedCompressorsCount(CompressionCodec) - Static method in class org.apache.hadoop.io.compress.CodecPool
Return the number of leased Compressors for this CompressionCodec
getLeasedDecompressorsCount(CompressionCodec) - Static method in class org.apache.hadoop.io.compress.CodecPool
Return the number of leased Decompressors for this CompressionCodec
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
getLifecycleHistory() - Method in class org.apache.hadoop.service.AbstractService
 
getLifecycleHistory() - Method in interface org.apache.hadoop.service.Service
Get a snapshot of the lifecycle history; it is a static list
getLimit() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
Get the limit on the number applications to return
getLinkTarget(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Partially resolves the 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.FileSystem
getLinkTarget(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getLinkTarget(Path) - Method in class org.apache.hadoop.fs.LocalFileSystem
 
getLinkTarget(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
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 class 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() - Method in class org.apache.hadoop.mapred.SplitLocationInfo
 
getLocation(int) - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeInputSplit
getLocations from ith InputSplit.
getLocationInfo() - Method in class org.apache.hadoop.mapred.FileSplit
 
getLocationInfo() - Method in interface org.apache.hadoop.mapred.InputSplitWithLocationInfo
Gets info about which nodes the input split is stored on and how it is stored at each location.
getLocationInfo() - Method in class org.apache.hadoop.mapreduce.InputSplit
Gets info about which nodes the input split is stored on and how it is stored at each location.
getLocationInfo() - Method in class org.apache.hadoop.mapreduce.lib.input.FileSplit
 
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.
getLogAggregationContext() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get LogAggregationContext of the application
getLogAggregationContext() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
getLogParams(JobID, TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.Cluster
Get log parameters for the specified jobID or taskAttemptID
getLogUrl() - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
Get the LogURL of the container.
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.mapred.jobcontrol.Job
 
getMapredJobId() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
getMapRunnerClass() - Method in class org.apache.hadoop.mapred.JobConf
Get the MapRunnable class for the job.
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.
getMasterKey(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.security.client.BaseClientToAMTokenSecretManager
 
getMasterKey(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenSecretManager
 
getMasterKeyId() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
getMatchingRequests(Priority, String, Resource) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
Get outstanding ContainerRequests matching the given parameters.
getMatchingRequests(Priority, String, Resource) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
 
getMaxAppAttempts() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
 
getMaximumCapacity() - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
Get the maximum capacity of the queue.
getMaximumResourceCapability() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse
Get the maximum capability for any Resource allocated by the ResourceManager in the cluster.
getMaximumResourceCapability() - Method in class 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.
getMemorySeconds() - Method in class org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
Get the aggregated amount of memory (in megabytes) the application has allocated times the number of seconds the application has been running.
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.
getMetadata(String) - Method in class org.apache.hadoop.crypto.key.KeyProvider
Get metadata about the key.
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 class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
 
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.
getMetricsRegistryInfo() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Get the metrics registry information.
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.
getModifiedTime() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
Get the modified time of the domain
getMountPoints() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getMountPoints() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getMovableTypes() - Static method in enum org.apache.hadoop.fs.StorageType
 
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 class org.apache.hadoop.fs.permission.AclEntry
Returns the optional ACL entry name.
getName() - Method in class org.apache.hadoop.mapred.Counters.Counter
 
getName() - Method in class org.apache.hadoop.mapred.Counters.Group
 
getName() - Method in interface org.apache.hadoop.mapreduce.Counter
 
getName() - Method in 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 class org.apache.hadoop.service.AbstractService
 
getName() - Method in interface org.apache.hadoop.service.Service
Get the name of this service.
getName() - Method in class 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 (IP:xferPort) hosting this block
getNeededMem() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getNeededResources() - Method in class 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.ApplicationClientProtocol
The interface used by clients to obtain a new ApplicationId for submitting new applications.
GetNewApplicationRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request sent by clients to get a new ApplicationId for submitting an application.
GetNewApplicationRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationRequest
 
GetNewApplicationResponse - Class 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.
GetNewApplicationResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse
 
getNewApplicationResponse() - Method in class org.apache.hadoop.yarn.client.api.YarnClientApplication
 
getNextExpirationTime() - Method in interface org.apache.hadoop.mapreduce.v2.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.
 
getNmHostAddress() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
getNMToken(String) - Static method in class org.apache.hadoop.yarn.client.api.NMTokenCache
Returns NMToken, null if absent.
getNMTokenCache() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
Get the NM token cache of the AMRMClient.
getNMTokenCache() - Method in class org.apache.hadoop.yarn.client.api.NMClient
Get the NM token cache of the NMClient.
getNMTokens() - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
Get the list of NMTokens required for communicating with NM.
getNMTokensFromPreviousAttempts() - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
Get the list of NMTokens for communicating with the NMs where the containers of previous application attempts are running.
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
 
getNodeHttpAddress() - Method in class org.apache.hadoop.yarn.api.records.Container
Get the http uri of the node on which the container is allocated.
getNodeHttpAddress() - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
Get the Node Http address of the container
getNodeId() - Method in class org.apache.hadoop.yarn.api.records.Container
Get the identifier of the node on which the container is allocated.
getNodeId() - Method in class org.apache.hadoop.yarn.api.records.NMToken
Get the NodeId of the NodeManager for which the NMToken is used to authenticate.
getNodeId() - Method in class org.apache.hadoop.yarn.api.records.NodeReport
Get the NodeId of the node.
getNodeId() - Method in class org.apache.hadoop.yarn.security.NMTokenIdentifier
 
getNodeLabelExpression() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get node-label-expression for this app.
getNodeLabelExpression() - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
Get node-label-expression for this Resource Request.
getNodeLabels() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodeLabelsResponse
 
getNodeLabels() - Method in class org.apache.hadoop.yarn.api.records.NodeReport
Get labels of this node
getNodeReports() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesResponse
Get NodeReport for all nodes in the cluster.
getNodeReports(NodeState...) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get a report of nodes (NodeReport) in the cluster.
getNodeState() - Method in class org.apache.hadoop.yarn.api.records.NodeReport
Get the NodeState of the node.
getNodeStates() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesRequest
The state to filter the cluster nodes with.
getNodeToLabels(GetNodesToLabelsRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationClientProtocol
The interface used by client to get node to labels mappings in existing cluster
getNodeToLabels() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
The interface used by client to get node to labels mappings in existing cluster
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 class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
Get the number of hosts available on the cluster.
getNumContainers() - Method in class org.apache.hadoop.yarn.api.records.NodeReport
Get the number of allocated containers on the node.
getNumContainers() - Method in class org.apache.hadoop.yarn.api.records.ReservationRequest
Get the number of containers required with the given specifications.
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 class 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 class 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 class 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 class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
Get the original tracking url for the application attempt.
getOriginalTrackingUrl() - Method in class 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.
getOtherInfo() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Get the other information of the entity
getOtherInfoJAXB() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
 
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.
getOverCommitTimeout() - Method in class org.apache.hadoop.yarn.api.records.ResourceOption
Get timeout for tolerant of resource over-commitment Note: negative value means no timeout so that allocated containers will keep running until the end even under resource over-commitment cases.
getOwner() - Method in class org.apache.hadoop.fs.FileStatus
Get the owner of the file.
getOwner() - Method in class org.apache.hadoop.fs.permission.AclStatus
Returns the file owner.
getOwner() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
Get the domain owner
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(JobConf) - Static method in class org.apache.hadoop.mapred.lib.TotalOrderPartitioner
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(String) - Method in class org.apache.hadoop.conf.Configuration
Get the value for a known password configuration element.
getPassword() - Method in class org.apache.hadoop.yarn.api.records.Token
Get the token password
getPasswordFromConfig(String) - Method in class org.apache.hadoop.conf.Configuration
Fallback to clear text passwords in configuration.
getPasswordFromCredentialProviders(String) - Method in class org.apache.hadoop.conf.Configuration
Try and resolve the provided element name as a credential provider alias.
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.
getPath() - Method in class org.apache.hadoop.yarn.api.protocolrecords.UseSharedCacheResourceResponse
Get the Path corresponding to the requested resource in the shared cache.
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.
getPathNameWarning() - Method in class org.apache.hadoop.fs.azure.WasbFsck
 
getPaths() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns all the Paths in the split
getPathWithoutSchemeAndAuthority(Path) - Static method in class org.apache.hadoop.fs.Path
 
getPattern(String, Pattern) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a Pattern.
getPattern() - Method in class 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.
getPermission() - Method in class org.apache.hadoop.fs.permission.AclEntry
Returns the set of permissions in the ACL entry.
getPermission() - Method in class org.apache.hadoop.fs.permission.AclStatus
Returns the permission set for the path
getPort() - Method in class org.apache.hadoop.yarn.api.records.NodeId
Get the port for communicating with the node.
getPort() - Method in class 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 class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
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. 
getPreemptionMessage() - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
Get the description of containers owned by the AM, but requested back by the cluster.
getPrimaryFilters() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Get the primary filters
getPrimaryFiltersJAXB() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
 
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 class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the Priority of the application.
getPriority() - Method in class 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.ContainerReport
Get the allocated Priority of the container.
getPriority() - Method in class org.apache.hadoop.yarn.api.records.Priority
Get the assigned priority
getPriority() - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
Get the Priority of the request.
getPriority() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
getProblems() - Method in exception org.apache.hadoop.mapred.InvalidInputException
Get the complete list of the problems reported.
getProblems() - Method in exception org.apache.hadoop.mapreduce.lib.input.InvalidInputException
Get the complete list of the problems reported.
getProcessTreeDump() - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Get a dump of the process-tree.
getProfileEnabled() - Method in class org.apache.hadoop.mapred.JobConf
Get whether the task profiling is enabled.
getProfileEnabled() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get whether the task profiling is enabled.
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 class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
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.CombineFileRecordReaderWrapper
 
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 class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
Get the current progress of application.
getProgress() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the application's progress ( range 0.0 to 1.0 )
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
 
getProto() - Method in class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
 
getProto() - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
 
getProto() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
getProto() - Method in class org.apache.hadoop.yarn.security.NMTokenIdentifier
 
getProviders(Configuration) - Static method in class org.apache.hadoop.crypto.key.KeyProviderFactory
 
getProviders(Configuration) - Static method in class org.apache.hadoop.security.alias.CredentialProviderFactory
 
getProxy(Configuration, int) - Method in class org.apache.hadoop.ha.HAServiceTarget
 
getProxy(Configuration, Class<T>, InetSocketAddress) - Static method in class org.apache.hadoop.yarn.client.AHSProxy
 
getProxyGroups() - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
 
getProxyHosts() - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
 
getProxySuperuserGroupConfKey(String) - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
Returns configuration key for effective groups allowed for a superuser
getProxySuperuserIpConfKey(String) - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
Return configuration key for superuser ip addresses
getProxySuperuserUserConfKey(String) - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
Returns configuration key for effective usergroups allowed for a superuser
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 class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
Get the queue that the application was placed in.
getQueue() - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationSubmissionRequest
Get the name of the Plan that corresponds to the name of the QueueInfo in the scheduler to which the reservation will be submitted to.
getQueue() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the queue to which the application was submitted.
getQueue() - Method in class 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 class org.apache.hadoop.yarn.client.api.YarnClient
Get information about acls for current user on all the existing queues.
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.ApplicationClientProtocol
The interface used by clients to get information about queues from the ResourceManager.
getQueueInfo() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoResponse
Get the QueueInfo for the specified queue.
getQueueInfo(String) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get information (QueueInfo) about a given queue.
GetQueueInfoRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request sent by clients to get queue information from the ResourceManager.
GetQueueInfoRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
 
GetQueueInfoResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a client requesting information about queues in the system.
GetQueueInfoResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoResponse
 
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 class org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
Get the queue name for which to get queue information.
getQueueName() - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
Get the name of the queue.
getQueueName() - Method in class 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.
getQueues() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
Get the queues to filter applications on
getQueueState() - Method in class org.apache.hadoop.mapred.JobQueueInfo
Deprecated.
getQueueState() - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
Get the QueueState of the queue.
getQueueUserAcls(GetQueueUserAclsInfoRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationClientProtocol
The interface used by clients to get information about queue acls for current user from the ResourceManager.
GetQueueUserAclsInfoRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request sent by clients to the ResourceManager to get queue acls for the current user.
GetQueueUserAclsInfoRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetQueueUserAclsInfoRequest
 
GetQueueUserAclsInfoResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to clients seeking queue acls for the user.
GetQueueUserAclsInfoResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.GetQueueUserAclsInfoResponse
 
getQuota() - Method in class org.apache.hadoop.fs.ContentSummary
Return the directory quota
getRackName() - Method in class 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.
getReaders() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
Get the reader (and/or reader group) list string
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.
getRecordLength(Configuration) - Static method in class org.apache.hadoop.mapred.FixedLengthInputFormat
Get record length value
getRecordLength(Configuration) - Static method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthInputFormat
Get record length value
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 class org.apache.hadoop.mapred.FixedLengthInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in interface org.apache.hadoop.mapred.InputFormat
Get the RecordReader for the given InputSplit.
getRecordReader(InputSplit, JobConf, Reporter) - Method in interface org.apache.hadoop.mapred.join.ComposableInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.join.CompositeInputFormat
Construct a CompositeRecordReader for the children of this InputFormat as defined in the init expression.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.KeyValueTextInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
This is not implemented yet.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.CombineSequenceFileInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.CombineTextInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.db.DBInputFormat
Get the RecordReader for the given InputSplit.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.mapred.lib.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 class 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.
getRelatedEntities() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Get the related entities
getRelatedEntitiesJAXB() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
 
getRelaxLocality() - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
Get whether locality relaxation is enabled with this ResourceRequest.
getReleaseList() - Method in class 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 class 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
getReservationDefinition() - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationSubmissionRequest
Get the ReservationDefinition representing the user constraints for this reservation
getReservationDefinition() - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationUpdateRequest
Get the ReservationDefinition representing the updated user constraints for this reservation
getReservationId() - Method in class org.apache.hadoop.mapreduce.Job
Get the reservation to which the job is submitted to, if any
getReservationId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationDeleteRequest
Get the ReservationId, that corresponds to a valid resource allocation in the scheduler (between start and end time of this reservation)
getReservationId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationSubmissionResponse
Get the ReservationId, that corresponds to a valid resource allocation in the scheduler (between start and end time of this reservation)
getReservationId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationUpdateRequest
Get the ReservationId, that corresponds to a valid resource allocation in the scheduler (between start and end time of this reservation)
getReservationID() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the reservation id, that corresponds to a valid resource allocation in the scheduler (between start and end time of the corresponding reservation)
getReservationName() - Method in class org.apache.hadoop.yarn.api.records.ReservationDefinition
Get the name for this reservation.
getReservationRequests() - Method in class org.apache.hadoop.yarn.api.records.ReservationDefinition
Get the list of ReservationRequests representing the resources required by the application
getReservationResources() - Method in class org.apache.hadoop.yarn.api.records.ReservationRequests
Get the list of ReservationRequest representing the resources required by the application
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 class 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(String) - Method in class org.apache.hadoop.util.ApplicationClassLoader
 
getResource() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get the resource required by the ApplicationMaster for this application.
getResource() - Method in class org.apache.hadoop.yarn.api.records.Container
Get the Resource allocated to the container.
getResource() - Method in class org.apache.hadoop.yarn.api.records.LocalResource
Get the location of the resource to be localized.
getResource() - Method in class org.apache.hadoop.yarn.api.records.ResourceOption
Get the resource of the ResourceOption.
getResource() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
getResourceBlacklistRequest() - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
Get the ResourceBlacklistRequest being sent by the ApplicationMaster.
getResourceCalculatorProcessTree(String, Class<? extends ResourceCalculatorProcessTree>, Configuration) - Static method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Create the ResourceCalculatorProcessTree rooted to specified process from the class name and configure it.
getResourceKey() - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReleaseSharedCacheResourceRequest
Get the key of the resource to be released.
getResourceKey() - Method in class org.apache.hadoop.yarn.api.protocolrecords.UseSharedCacheResourceRequest
Get the key of the resource to be used.
getResourceName() - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
Get the resource (e.g.
getResourceRequest() - Method in class org.apache.hadoop.yarn.api.records.PreemptionContract
If the AM releases resources matching these requests, then the PreemptionContainers enumerated in PreemptionContract.getContainers() should not be evicted from the cluster.
getResourceRequest() - Method in class org.apache.hadoop.yarn.api.records.PreemptionResourceRequest
 
getResponseId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
Get the response id used to track duplicate responses.
getResponseId() - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
Get the last response id.
getRMAddress(YarnConfiguration, Class<?>) - Method in class org.apache.hadoop.yarn.client.ClientRMProxy
 
getRMAddress(YarnConfiguration, Class<?>) - Method in class org.apache.hadoop.yarn.client.RMProxy
Get the ResourceManager address from the provided Configuration for the given protocol.
getRMDefaultPortNumber(String, Configuration) - Static method in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
getRMDelegationToken() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenResponse
The Delegation tokens have a identifier which maps to AbstractDelegationTokenIdentifier.
getRMDelegationToken(Text) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get a delegation token so as to be able to talk to YARN using those tokens.
getRMDelegationTokenService(Configuration) - Static method in class org.apache.hadoop.yarn.client.ClientRMProxy
Get the token service name to be used for RMDelegationToken.
getRMIdentifier() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
Get the RMIdentifier of RM in which containers are allocated
getRolledLogsExcludePattern() - Method in class org.apache.hadoop.yarn.api.records.LogAggregationContext
Get exclude pattern for aggregation in a rolling fashion.
getRolledLogsIncludePattern() - Method in class org.apache.hadoop.yarn.api.records.LogAggregationContext
Get include pattern in a rolling fashion.
getRootQueueInfos() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get information (QueueInfo) about top level queues.
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 class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
Get the RPC port on which the ApplicationMaster is responding.
getRpcPort() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
Get the RPC port of this attempt ApplicationMaster.
getRpcPort() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the RPC port of the ApplicationMaster.
getRssMemorySize() - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Get the resident set size (rss) memory used by all the processes in the process-tree.
getRssMemorySize(int) - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Get the resident set size (rss) memory used by all the processes in the process-tree that are older than the passed in age.
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
 
getSchedulerResourceTypes() - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
Get a set of the resource types considered by the scheduler.
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 class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
getScheme() - Method in class org.apache.hadoop.fs.FileSystem
Return the protocol scheme for the FileSystem.
getScheme() - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
Return the protocol scheme for the FileSystem.
getScheme() - Method in class org.apache.hadoop.fs.LocalFileSystem
Return the protocol scheme for the FileSystem.
getScheme() - Method in class org.apache.hadoop.fs.s3.S3FileSystem
Return the protocol scheme for the FileSystem.
getScheme() - Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
Return the protocol scheme for the FileSystem.
getScheme() - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
Return the protocol scheme for the FileSystem.
getScheme() - Method in class org.apache.hadoop.yarn.api.records.URL
Get the scheme of the URL.
getScope() - Method in class org.apache.hadoop.fs.permission.AclEntry
Returns the scope of the ACL entry.
getScope() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
Get the ApplicationsRequestScope of applications to be filtered.
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
Deprecated.
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 class org.apache.hadoop.yarn.api.records.Token
Get the service to which the token is allocated.
getServiceAddressConfKeys(Configuration) - Static method in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
getServiceData() - Method in class org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get application-specific binary service data.
getServices() - Method in class org.apache.hadoop.service.CompositeService
Get a cloned list of services
getServiceState() - Method in class org.apache.hadoop.service.AbstractService
 
getServiceState() - Method in interface org.apache.hadoop.service.Service
Get the current service state
getServiceStatus() - Method in interface org.apache.hadoop.ha.HAServiceProtocol
Return the current status of the service.
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.
getShouldBeUploadedToSharedCache() - Method in class org.apache.hadoop.yarn.api.records.LocalResource
NM uses it to decide whether if it is necessary to upload the resource to the shared cache
getShuffleSecretKey(Credentials) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
 
getSingleton() - Static method in class org.apache.hadoop.yarn.client.api.NMTokenCache
Returns the singleton NM token cache.
getSize() - Method in class org.apache.hadoop.io.BytesWritable
Deprecated.
getSize() - Method in class 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, String, int) - Method in class org.apache.hadoop.conf.Configuration
Get the socket address for hostProperty as a InetSocketAddress.
getSocketAddr(String, String, int) - Method in class org.apache.hadoop.conf.Configuration
Get the socket address for name property as a InetSocketAddress.
getSocketAddr(String, String, int) - Method in class org.apache.hadoop.yarn.conf.YarnConfiguration
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 storage space consumed
getSpaceQuota() - Method in class org.apache.hadoop.fs.ContentSummary
Returns storage 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.mapred.JobClient
Fetch the staging area directory for the application
getStagingAreaDir() - Method in class org.apache.hadoop.mapreduce.Cluster
Grab the jobtracker's view of the staging directory path where job-specific files will be placed.
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.
getStartContainerRequests() - Method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainersRequest
Get a list of StartContainerRequest to start containers.
getStartOffsets() - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileSplit
Returns an array containing the start offsets of the files in the split
getStartRange() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
Get the range of start times to filter applications on
getStartTime() - Method in class org.apache.hadoop.conf.ReconfigurationTaskStatus
 
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 class org.apache.hadoop.service.AbstractService
 
getStartTime() - Method in interface org.apache.hadoop.service.Service
Get the service start time
getStartTime() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the start time of the application.
getStartTime() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
Get the start time of the entity
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 class org.apache.hadoop.service.ServiceStateModel
Query the service state.
getState() - Method in class 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.conf.ReconfigurationTaskStatus
 
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
 
getStatus(Path) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
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
getStickyBit() - Method in class org.apache.hadoop.fs.permission.FsPermission
 
getStore() - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
For unit test purposes, retrieves the AzureNativeFileSystemStore store backing this file system.
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
 
getStrictContract() - Method in class org.apache.hadoop.yarn.api.records.PreemptionMessage
 
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
 
getSuccessfullyStartedContainers() - Method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainersResponse
Get the list of ContainerId s of the containers that are started successfully.
getSuccessfullyStoppedContainers() - Method in class org.apache.hadoop.yarn.api.protocolrecords.StopContainersResponse
Get the list of containerIds of successfully stopped containers.
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.
getTargetQueue() - Method in class org.apache.hadoop.yarn.api.protocolrecords.MoveApplicationAcrossQueuesRequest
Get the queue to place the application in.
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.mapred.FileOutputCommitter
 
getTaskAttemptPath(TaskAttemptContext) - Method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Compute the path where the output of a task attempt is stored until that task is committed.
getTaskAttemptPath(TaskAttemptContext, Path) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
Compute the path where the output of a task attempt is stored until that task is committed.
getTaskCleanupNeeded() - Method in interface org.apache.hadoop.mapreduce.JobContext
Get whether task-cleanup is needed for the job
getTaskCompletionEvents(int) - Method in interface org.apache.hadoop.mapred.RunningJob
Get events indicating completion (success/failure) of component tasks.
getTaskCompletionEvents(int, int) - Method in class org.apache.hadoop.mapreduce.Job
Get events indicating completion (success/failure) of component tasks.
getTaskCompletionEvents(int) - Method in class org.apache.hadoop.mapreduce.Job
Get events indicating completion (success/failure) of component tasks.
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 string of the task id.
getTaskID() - Method in class org.apache.hadoop.mapred.TaskReport
The id of the task.
getTaskID() - Method in class org.apache.hadoop.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
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
getTestProvider() - Static method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
 
getThreadState() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.JobControl
 
getTime() - Method in interface org.apache.hadoop.yarn.util.Clock
 
getTime() - Method in class org.apache.hadoop.yarn.util.SystemClock
 
getTime() - Method in class org.apache.hadoop.yarn.util.UTCClock
 
getTimeDuration(String, long, TimeUnit) - Method in class org.apache.hadoop.conf.Configuration
Return time duration in the given time unit.
getTimelineTokenServiceAddress(Configuration) - Static method in class org.apache.hadoop.yarn.util.timeline.TimelineUtils
 
getTimestamp(Configuration, URI) - Static method in class org.apache.hadoop.filecache.DistributedCache
Deprecated.
getTimestamp() - Method in class org.apache.hadoop.yarn.api.records.LocalResource
Get the original timestamp of the resource to be localized, used for verification.
getTimestamp() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
Get the timestamp of the event
getTimestamp() - Method in class org.apache.hadoop.yarn.event.AbstractEvent
 
getTimestamp() - Method in interface org.apache.hadoop.yarn.event.Event
 
getTmax(String) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
getToken(int) - Method in class org.apache.hadoop.record.compiler.generated.Rcc
Deprecated.
 
getToken() - Method in class org.apache.hadoop.yarn.api.records.NMToken
Get the Token used for authenticating with NodeManager
getToken(String) - Method in class org.apache.hadoop.yarn.client.api.NMTokenCache
Returns NMToken, null if absent
getTokenInfo(Class<?>, Configuration) - Method in class org.apache.hadoop.yarn.security.admin.AdminSecurityInfo
 
getTokenInfo(Class<?>, Configuration) - Method in class org.apache.hadoop.yarn.security.client.ClientRMSecurityInfo
 
getTokenInfo(Class<?>, Configuration) - Method in class org.apache.hadoop.yarn.security.client.ClientTimelineSecurityInfo
 
getTokenInfo(Class<?>, Configuration) - Method in class org.apache.hadoop.yarn.security.ContainerManagerSecurityInfo
 
getTokenInfo(Class<?>, Configuration) - Method in class org.apache.hadoop.yarn.security.SchedulerSecurityInfo
 
getTokens() - Method in class org.apache.hadoop.yarn.api.records.ContainerLaunchContext
Get all the tokens needed by this container.
getTokenService(Configuration, String, String, int) - Static method in class org.apache.hadoop.yarn.client.ClientRMProxy
 
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.
getTotalLogFileSize() - Method in class org.apache.hadoop.yarn.ContainerLogAppender
 
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 class org.apache.hadoop.yarn.api.protocolrecords.FinishApplicationMasterRequest
Get the tracking URL for the ApplicationMaster.
getTrackingUrl() - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
Get the tracking URL for the ApplicationMaster.
getTrackingUrl() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
Get the tracking url for the application attempt.
getTrackingUrl() - Method in class 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
 
getTrashInterval() - Method in class org.apache.hadoop.fs.FsServerDefaults
 
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.
getTrimmed(String, String) - Method in class org.apache.hadoop.conf.Configuration
Get the value of the name property as a trimmed String, defaultValue 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.fs.permission.AclEntry
Returns the ACL entry type.
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 class org.apache.hadoop.yarn.api.records.LocalResource
Get the LocalResourceType of the resource to be localized.
getType() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDelegationTokenResponse
 
getType() - Method in class org.apache.hadoop.yarn.event.AbstractEvent
 
getType() - Method in interface org.apache.hadoop.yarn.event.Event
 
getTypeConsumed(StorageType) - Method in class org.apache.hadoop.fs.ContentSummary
Returns storage type consumed
getTypeID() - Method in class org.apache.hadoop.record.meta.FieldTypeInfo
Deprecated.
get the field's TypeID object
getTypeQuota(StorageType) - Method in class org.apache.hadoop.fs.ContentSummary
Returns storage type quota
getTypes() - Method in class org.apache.hadoop.io.GenericWritable
Return all classes that may be wrapped.
getTypesSupportingQuota() - Static method in enum org.apache.hadoop.fs.StorageType
 
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
getUid(String) - Method in interface org.apache.hadoop.security.IdMappingServiceProvider
 
getUidAllowingUnknown(String) - Method in interface org.apache.hadoop.security.IdMappingServiceProvider
 
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 class org.apache.hadoop.mapred.Counters.Counter
 
getUnderlyingCounter() - Method in interface org.apache.hadoop.mapreduce.Counter
 
getUnderlyingGroup() - Method in class org.apache.hadoop.mapred.Counters.Group
 
getUnderlyingGroup() - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
 
getUniqueFile(TaskAttemptContext, String, String) - Static method in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
Generate a unique filename, based on the task id, name, and extension
getUniqueItems() - Method in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
 
getUniqueName(JobConf, String) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
Helper function to generate a name that is unique for the task.
getUnits(String) - Method in class org.apache.hadoop.metrics.ganglia.GangliaContext
 
getUnmanagedAM() - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
Get if the RM should manage the execution of the AM.
getUpdatedNodes() - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
Get the list of updated NodeReports.
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.azure.NativeAzureFileSystem
 
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.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.azure.Wasb
 
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 class 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 class 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 class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the user who submitted the application.
getUser() - Method in class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
 
getUser() - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
 
getUser() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
getUser() - Method in class org.apache.hadoop.yarn.security.NMTokenIdentifier
 
getUserAcls() - Method in class org.apache.hadoop.yarn.api.records.QueueUserACLInfo
Get the list of QueueACL for the given user.
getUserAclsInfoList() - Method in class 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.
getUserInfo() - Method in class org.apache.hadoop.yarn.api.records.URL
Get the user info of the URL.
getUsername() - Method in class org.apache.hadoop.mapreduce.JobStatus
 
getUserName(int, String) - Method in interface org.apache.hadoop.security.IdMappingServiceProvider
 
getUsers() - Method in class org.apache.hadoop.security.authorize.AccessControlList
Get the names of users allowed for this service.
getUsers() - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
Get the users to filter applications on
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 class org.apache.hadoop.mapred.Counters.Counter
 
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
getVcoreSeconds() - Method in class org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
Get the aggregated number of vcores that the application has allocated times the number of seconds the application has been running.
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
getVirtualCores() - Method in class org.apache.hadoop.yarn.api.records.Resource
Get number of virtual cpu cores of the resource.
getVirtualMemorySize() - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Get the virtual memory used by all the processes in the process-tree.
getVirtualMemorySize(int) - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
Get the virtual memory used by all the processes in the process-tree that are older than the passed in age.
getVisibility() - Method in class org.apache.hadoop.yarn.api.records.LocalResource
Get the LocalResourceVisibility of the resource to be localized.
getVolumeIds() - Method in class org.apache.hadoop.fs.BlockStorageLocation
Gets the list of VolumeId corresponding to the block's replicas.
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.azure.NativeAzureFileSystem
 
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.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
 
getWriters() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
Get the writer (and/or writer group) list string
getXAttr(Path, String) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Get an xattr for a file or directory.
getXAttr(Path, String) - Method in class org.apache.hadoop.fs.FileContext
Get an xattr for a file or directory.
getXAttr(Path, String) - Method in class org.apache.hadoop.fs.FileSystem
Get an xattr name and value for a file or directory.
getXAttr(Path, String) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getXAttr(Path, String) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getXAttr(Path, String) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getXAttrs(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Get all of the xattrs for a file or directory.
getXAttrs(Path, List<String>) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Get all of the xattrs for a file or directory.
getXAttrs(Path) - Method in class org.apache.hadoop.fs.FileContext
Get all of the xattrs for a file or directory.
getXAttrs(Path, List<String>) - Method in class org.apache.hadoop.fs.FileContext
Get all of the xattrs for a file or directory.
getXAttrs(Path) - Method in class org.apache.hadoop.fs.FileSystem
Get all of the xattr name/value pairs for a file or directory.
getXAttrs(Path, List<String>) - Method in class org.apache.hadoop.fs.FileSystem
Get all of the xattrs name/value pairs for a file or directory.
getXAttrs(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getXAttrs(Path, List<String>) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
getXAttrs(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getXAttrs(Path, List<String>) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
getXAttrs(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getXAttrs(Path, List<String>) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
getYarnApplicationAttemptState() - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
Get the YarnApplicationAttemptState of the application attempt.
getYarnApplicationState() - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
Get the YarnApplicationState of the application.
getYarnClusterMetrics() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Get metrics (YarnClusterMetrics) about the cluster.
getZKFCAddress() - Method in class org.apache.hadoop.ha.HAServiceTarget
 
getZKFCProxy(Configuration, int) - Method in class org.apache.hadoop.ha.HAServiceTarget
 
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.
GraphiteSink - Class in org.apache.hadoop.metrics2.sink
A metrics sink that writes to a Graphite server
GraphiteSink() - Constructor for class org.apache.hadoop.metrics2.sink.GraphiteSink
 
GROUP - Static variable in class org.apache.hadoop.mapreduce.lib.map.RegexMapper
 
GROUP_MAPPING_CONFIG_PREFIX - Static variable in interface org.apache.hadoop.security.GroupMappingServiceProvider
 
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_POLICY_CONFIGURATION_FILE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
HADOOP_RPC_PROTECTION - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_RPC_SOCKET_FACTORY_CLASS_DEFAULT_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
 
HADOOP_RPC_SOCKET_FACTORY_CLASS_DEFAULT_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_AUTH_TO_LOCAL - 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_CRYPTO_BUFFER_SIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Defalt value for HADOOP_SECURITY_CRYPTO_BUFFER_SIZE_KEY
HADOOP_SECURITY_CRYPTO_BUFFER_SIZE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_CRYPTO_CIPHER_SUITE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
 
HADOOP_SECURITY_CRYPTO_CIPHER_SUITE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_CRYPTO_CODEC_CLASSES_KEY_PREFIX - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
 
HADOOP_SECURITY_CRYPTO_JCE_PROVIDER_KEY - 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_GROUPS_CACHE_SECS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_GROUPS_CACHE_WARN_AFTER_MS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_GROUPS_CACHE_WARN_AFTER_MS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
 
HADOOP_SECURITY_GROUPS_NEGATIVE_CACHE_SECS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_GROUPS_NEGATIVE_CACHE_SECS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_IMPERSONATION_PROVIDER_CLASS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Class to override Impersonation provider
HADOOP_SECURITY_INSTRUMENTATION_REQUIRES_ADMIN - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_JAVA_SECURE_RANDOM_ALGORITHM_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Defalt value for HADOOP_SECURITY_JAVA_SECURE_RANDOM_ALGORITHM_KEY
HADOOP_SECURITY_JAVA_SECURE_RANDOM_ALGORITHM_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_SASL_PROPS_RESOLVER_CLASS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Class to override Sasl Properties for a connection
HADOOP_SECURITY_SECURE_RANDOM_DEVICE_FILE_PATH_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
 
HADOOP_SECURITY_SECURE_RANDOM_DEVICE_FILE_PATH_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
HADOOP_SECURITY_SECURE_RANDOM_IMPL_KEY - 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_SSL_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Deprecated.
HADOOP_SSL_ENABLED_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Deprecated.
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.
handle(T) - Method in interface org.apache.hadoop.yarn.event.EventHandler
 
handler - Variable in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
 
has(int) - Method in class org.apache.hadoop.mapreduce.lib.join.TupleWritable
Return true if tuple has an element at the position provided.
HAServiceProtocol - Interface in org.apache.hadoop.ha
Protocol interface that provides High Availability related primitives to monitor and fail-over the service.
HAServiceProtocolHelper - Class in org.apache.hadoop.ha
Helper for making HAServiceProtocol RPC calls.
HAServiceProtocolHelper() - Constructor for class org.apache.hadoop.ha.HAServiceProtocolHelper
 
HAServiceProtocolPB - Interface in org.apache.hadoop.ha.protocolPB
 
HAServiceTarget - Class in org.apache.hadoop.ha
Represents a target of the client side HA administration commands.
HAServiceTarget() - Constructor for class org.apache.hadoop.ha.HAServiceTarget
 
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.HdfsVolumeId
 
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.AclEntry
 
hashCode() - Method in class org.apache.hadoop.fs.permission.AclStatus
 
hashCode() - Method in class org.apache.hadoop.fs.permission.FsPermission
 
hashCode() - Method in interface org.apache.hadoop.fs.VolumeId
 
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.Counters.Counter
 
hashCode() - Method in class org.apache.hadoop.mapred.Counters.Group
 
hashCode() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
 
hashCode() - Method in class org.apache.hadoop.mapreduce.counters.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.registry.client.types.RegistryPathStatus
The hash code is derived from the path.
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.ContainerResourceIncreaseRequest
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.NMToken
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.NodeId
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.Priority
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.ReservationId
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.ReservationRequest
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.Resource
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
 
hashCode() - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
 
hashCode() - Method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogKey
 
hashCode() - Method in class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
 
hashCode() - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
 
hashCode() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
hashCode() - Method in class org.apache.hadoop.yarn.security.NMTokenIdentifier
 
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
 
hasTask() - Method in class org.apache.hadoop.conf.ReconfigurationTaskStatus
Return true if - A reconfiguration task has finished or - an active reconfiguration task is running
hasWarnedDeprecation(String) - Static method in class org.apache.hadoop.conf.Configuration
Returns whether or not a deprecated name has been warned.
HdfsVolumeId - Class in org.apache.hadoop.fs
HDFS-specific volume identifier which implements VolumeId.
HdfsVolumeId(byte[]) - Constructor for class org.apache.hadoop.fs.HdfsVolumeId
 
headerPattern - Static variable in class org.apache.hadoop.mapreduce.tools.CLI
 
headMap(WritableComparable) - Method in class org.apache.hadoop.io.SortedMapWritable
 
HealthCheckFailedException - Exception in org.apache.hadoop.ha
Exception thrown to indicate that health check of a service failed.
HealthCheckFailedException(String) - Constructor for exception org.apache.hadoop.ha.HealthCheckFailedException
 
HealthCheckFailedException(String, Throwable) - Constructor for exception org.apache.hadoop.ha.HealthCheckFailedException
 
heartbeatIntervalMs - Variable in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
 
HELP_CMD - Static variable in class org.apache.hadoop.yarn.client.cli.LogsCLI
 
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.
homePathForCurrentUser() - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
Get the home path of the current user.
homePathForUser(String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
Buld the user path -switches to the system path if the user is "".
hostnamePortPair(String, int) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
Create a (hostname, port) address pair
hostnamePortPair(InetSocketAddress) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
Create a (hostname, port) address pair
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).
HTTP_POLICY_HTTP_ONLY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Deprecated.
HTTP_POLICY_HTTPS_ONLY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Deprecated.

I

ID - Class in org.apache.hadoop.mapred
A general identifier, which internally stores the id as an integer.
ID(int) - Constructor for class org.apache.hadoop.mapred.ID
constructs an ID object from the given int
ID() - Constructor for class org.apache.hadoop.mapred.ID
 
id() - Method in interface org.apache.hadoop.mapred.join.ComposableRecordReader
Return the position in the collector this class occupies.
id() - Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
Return the position in the collector this class occupies.
id - Variable in class org.apache.hadoop.mapred.join.Parser.Node
 
id() - Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
Return the position in the collector this class occupies.
ID - Class in org.apache.hadoop.mapreduce
A general identifier, which internally stores the id as an integer.
ID(int) - Constructor for class org.apache.hadoop.mapreduce.ID
constructs an ID object from the given int
ID() - Constructor for class org.apache.hadoop.mapreduce.ID
 
id - Variable in class org.apache.hadoop.mapreduce.ID
 
id() - Method in class org.apache.hadoop.mapreduce.lib.join.CompositeRecordReader
Return the position in the collector this class occupies.
id - Variable in class org.apache.hadoop.mapreduce.lib.join.Parser.Node
 
id() - Method in class org.apache.hadoop.mapreduce.lib.join.WrappedRecordReader
Return the position in the collector this class occupies.
id - Variable in class org.apache.hadoop.yarn.api.records.ReservationId
 
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
 
IdMappingServiceProvider - Interface in org.apache.hadoop.security
An interface for the implementation of mapping and mapping
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.
ImpersonationProvider - Interface in org.apache.hadoop.security.authorize
 
implies(FsAction) - Method in enum org.apache.hadoop.fs.permission.FsAction
Return true if this action implies that action.
in - Variable in class org.apache.hadoop.io.compress.CompressionInputStream
The input stream to be compressed.
IN_MEMORY_CHECK_PERIOD_MINS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The frequency at which the in-memory store checks to remove dead initial applications.
IN_MEMORY_INITIAL_DELAY_MINS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Initial delay before the in-memory store runs its first check to remove dead initial applications.
IN_MEMORY_STALENESS_PERIOD_MINS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
A resource in the InMemorySCMStore is considered stale if the time since the last reference exceeds the staleness period.
IN_MEMORY_STORE_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
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(CounterGroupBase<Counters.Counter>) - Method in class org.apache.hadoop.mapred.Counters.Group
 
incrAllCounters(Counters) - Method in class org.apache.hadoop.mapred.Counters
Increments multiple counters by their amounts in another Counters instance.
incrAllCounters(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 class org.apache.hadoop.mapred.Counters.Counter
 
increment(long) - Method in interface org.apache.hadoop.mapreduce.Counter
Increment this counter by the given value
INCREMENT - 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.
inetAddrEndpoint(String, String, String, int) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
Create an internet address endpoint from a list of URIs
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(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(SubsetConfiguration) - Method in class org.apache.hadoop.metrics2.sink.GraphiteSink
 
init(String) - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
 
init(String) - Method in interface org.apache.hadoop.security.authorize.ImpersonationProvider
Specifies the configuration prefix for the proxy user properties and initializes the provider.
init(Configuration) - Method in class org.apache.hadoop.service.AbstractService
Initialize the service.
init(Configuration) - Method in interface org.apache.hadoop.service.Service
Initialize the service.
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
initialize(URI, Configuration) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
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.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.CombineFileRecordReaderWrapper
 
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
 
InputSplitWithLocationInfo - Interface in org.apache.hadoop.mapred
 
inputStream - Variable in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
Deprecated.
 
installTopology() - Method in class org.apache.hadoop.yarn.state.StateMachineFactory
 
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
 
internal - Variable in class org.apache.hadoop.registry.client.types.ServiceRecord
List of endpoints for use within an application.
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
 
INVALID - Static variable in class org.apache.hadoop.yarn.api.records.ContainerExitStatus
 
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.
InvalidPathnameException - Exception in org.apache.hadoop.registry.client.exceptions
A path name was invalid.
InvalidPathnameException(String, String) - Constructor for exception org.apache.hadoop.registry.client.exceptions.InvalidPathnameException
 
InvalidPathnameException(String, String, Throwable) - Constructor for exception org.apache.hadoop.registry.client.exceptions.InvalidPathnameException
 
InvalidRecordException - Exception in org.apache.hadoop.registry.client.exceptions
Raised if an attempt to parse a record failed.
InvalidRecordException(String, String) - Constructor for exception org.apache.hadoop.registry.client.exceptions.InvalidRecordException
 
InvalidRecordException(String, String, Throwable) - Constructor for exception org.apache.hadoop.registry.client.exceptions.InvalidRecordException
 
InvalidStateTransitonException - Exception in org.apache.hadoop.yarn.state
 
InvalidStateTransitonException(Enum<?>, Enum<?>) - Constructor for exception org.apache.hadoop.yarn.state.InvalidStateTransitonException
 
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_EXCEPTION - Static variable in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
Error code returned if an IOException is encountered when putting an entity.
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_CONNECT_MAX_RETRIES_ON_SOCKET_TIMEOUTS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IPC_CLIENT_CONNECT_MAX_RETRIES_ON_SOCKET_TIMEOUTS_KEY
IPC_CLIENT_CONNECT_MAX_RETRIES_ON_SOCKET_TIMEOUTS_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IPC_CLIENT_CONNECT_RETRY_INTERVAL_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IPC_CLIENT_CONNECT_RETRY_INTERVAL_KEY
IPC_CLIENT_CONNECT_RETRY_INTERVAL_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
IPC_CLIENT_CONNECT_TIMEOUT_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IPC_CLIENT_CONNECT_TIMEOUT_KEY
IPC_CLIENT_CONNECT_TIMEOUT_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_FACTORY_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Factory to create client IPC classes.
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_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
IPC_RECORD_FACTORY_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Factory to create serializeable records.
IPC_RPC_IMPL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
RPC class implementation
IPC_SERVER_FACTORY_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Factory to create server IPC classes.
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_MAX_CONNECTIONS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for IPC_SERVER_MAX_CONNECTIONS_KEY
IPC_SERVER_MAX_CONNECTIONS_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
ipcEndpoint(String, InetSocketAddress) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
Create an IPC endpoint
IPList - Interface in org.apache.hadoop.util
 
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
 
IS_MINI_YARN_CLUSTER - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
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.
isAllAllowed() - Method in class org.apache.hadoop.security.authorize.AccessControlList
 
isAnyLocation(String) - Static method in class org.apache.hadoop.yarn.api.records.ResourceRequest
Check whether the given host/rack string represents an arbitrary host name.
isAutoFailoverEnabled() - Method in class org.apache.hadoop.ha.HAServiceTarget
 
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.
isDrained() - Method in class org.apache.hadoop.yarn.event.AsyncDispatcher
 
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
isEncrypted() - Method in class org.apache.hadoop.fs.FileStatus
Tell whether the underlying file or directory is encrypted or not.
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.s3.S3FileSystem
 
isIn(String) - Method in interface org.apache.hadoop.util.IPList
returns true if the ipAddress is in the IPList.
isIncrement() - Method in class org.apache.hadoop.metrics.spi.MetricValue
 
isInMemory() - Method in class org.apache.hadoop.mapred.SplitLocationInfo
 
isInState(Service.STATE) - Method in class org.apache.hadoop.service.AbstractService
 
isInState(Service.STATE) - Method in interface org.apache.hadoop.service.Service
Query to see if the service is in a specific state.
isInState(Service.STATE) - Method in class org.apache.hadoop.service.ServiceStateModel
Query that the state is in a specific state
isJobComplete() - Method in class org.apache.hadoop.mapreduce.JobStatus
Returns true if the status is for a completed job.
isJobDirValid(Path, FileSystem) - Static method in class org.apache.hadoop.mapred.JobClient
Checks if the job directory is clean and has all the required components for (re) starting the job
isMap() - 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.
isMovable() - Method in enum org.apache.hadoop.fs.StorageType
 
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
isOnDisk() - Method in class org.apache.hadoop.mapred.SplitLocationInfo
 
isReady() - Method in class org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob
 
isRecoverySupported() - Method in class org.apache.hadoop.mapred.FileOutputCommitter
Deprecated.
isRecoverySupported(JobContext) - Method in class org.apache.hadoop.mapred.FileOutputCommitter
 
isRecoverySupported() - Method in class org.apache.hadoop.mapred.OutputCommitter
isRecoverySupported(JobContext) - Method in class org.apache.hadoop.mapred.OutputCommitter
Is task output recovery supported for restarting jobs? If task output recovery is supported, job restart can be done more efficiently.
isRecoverySupported(JobContext) - 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
Deprecated.
isRecoverySupported() - Method in class org.apache.hadoop.mapreduce.OutputCommitter
isRecoverySupported(JobContext) - 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.
isRoot() - Method in class org.apache.hadoop.fs.Path
 
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.FixedLengthInputFormat
 
isSplitable(FileSystem, Path) - Method in class org.apache.hadoop.mapred.KeyValueTextInputFormat
 
isSplitable(JobContext, Path) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
Subclasses should avoid overriding this method and should instead only override CombineFileInputFormat.isSplitable(FileSystem, Path).
isSplitable(FileSystem, Path) - Method in class org.apache.hadoop.mapred.lib.CombineFileInputFormat
 
isSplitable(FileSystem, Path) - Method in class org.apache.hadoop.mapred.TextInputFormat
 
isSplitable(JobContext, Path) - Method in class org.apache.hadoop.mapreduce.lib.input.CombineFileInputFormat
 
isSplitable(JobContext, Path) - Method in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
Is the given filename splitable? Usually, true, but if the file is stream compressed, it will not be.
isSplitable(JobContext, Path) - Method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthInputFormat
 
isSplitable(JobContext, Path) - Method in class org.apache.hadoop.mapreduce.lib.input.KeyValueTextInputFormat
 
isSplitable(JobContext, Path) - Method in class org.apache.hadoop.mapreduce.lib.input.TextInputFormat
 
isStickyBit() - Method in class org.apache.hadoop.fs.permission.AclStatus
Returns the sticky bit.
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?
isSystemClass(String, List<String>) - Static method in class org.apache.hadoop.util.ApplicationClassLoader
Checks if a class should be included as a system class.
isTransient() - Method in class org.apache.hadoop.crypto.key.KeyProvider
Indicates whether this provider represents a store that is intended for transient use - such as the UserProvider is.
isTransient() - Method in enum org.apache.hadoop.fs.StorageType
 
isTransient() - Method in class org.apache.hadoop.security.alias.CredentialProvider
Indicates whether this provider represents a store that is intended for transient use - such as the UserProvider is.
isTypeConsumedAvailable() - Method in class org.apache.hadoop.fs.ContentSummary
Returns true if any storage type consumption information is available
isTypeQuotaSet() - Method in class org.apache.hadoop.fs.ContentSummary
Returns true if any storage type quota has been set
isUber() - Method in class org.apache.hadoop.mapreduce.Job
 
isUber() - Method in class org.apache.hadoop.mapreduce.JobStatus
Whether job running in uber mode
isUnusable() - Method in enum org.apache.hadoop.yarn.api.records.NodeState
 
isUriPathAbsolute() - Method in class org.apache.hadoop.fs.Path
True if the path component (i.e.
isUserAllowed(UserGroupInformation) - Method in class org.apache.hadoop.security.authorize.AccessControlList
 
isUserInList(UserGroupInformation) - Method in class org.apache.hadoop.security.authorize.AccessControlList
Checks if a user represented by the provided UserGroupInformation is a member of the Access Control List
isValidName(String) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Returns true if the specified string is considered valid in the path part of a URI by this file system.
isValidName(String) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
isValidStateTransition(Service.STATE, Service.STATE) - Static method in class org.apache.hadoop.service.ServiceStateModel
Is a state transition valid? There are no checks for current==proposed as that is considered a non-transition.
isWindowsAbsolutePath(String, boolean) - Static method in class org.apache.hadoop.fs.Path
Determine whether a given path string represents an absolute path on Windows.
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.mapred.Counters.Group
 
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
Job(Configuration, String) - Constructor for class org.apache.hadoop.mapreduce.Job
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) - Constructor for class org.apache.hadoop.mapred.JobStatus
Deprecated.
JobStatus(JobID, float, float, int) - Constructor for class org.apache.hadoop.mapred.JobStatus
Deprecated.
JobStatus(JobID, float, float, float, int, JobPriority) - Constructor for class org.apache.hadoop.mapred.JobStatus
Deprecated.
JobStatus(JobID, float, float, float, float, int, JobPriority) - Constructor for class org.apache.hadoop.mapred.JobStatus
Deprecated.
JobStatus(JobID, float, float, float, int, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, int, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, int, JobPriority, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, int, JobPriority, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, int, JobPriority, String, String, String, String, boolean) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, int, JobPriority, String, String, String, String, String) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus(JobID, float, float, float, float, int, JobPriority, String, String, String, String, String, boolean) - Constructor for class org.apache.hadoop.mapred.JobStatus
Create a job status object for a given jobid.
JobStatus - 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

KerberosDelegationTokenAuthenticator - Class in org.apache.hadoop.security.token.delegation.web
The KerberosDelegationTokenAuthenticator provides support for Kerberos SPNEGO authentication mechanism and support for Hadoop Delegation Token operations.
KerberosDelegationTokenAuthenticator() - Constructor for class org.apache.hadoop.security.token.delegation.web.KerberosDelegationTokenAuthenticator
 
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_PROVIDER_PATH - Static variable in class org.apache.hadoop.crypto.key.KeyProviderFactory
 
KEY_REGISTRY_CLIENT_AUTH - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Registry client authentication policy.
KEY_REGISTRY_CLIENT_AUTHENTICATION_ID - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Registry client authentication ID
KEY_REGISTRY_CLIENT_AUTHENTICATION_PASSWORD - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Registry client authentication password.
KEY_REGISTRY_CLIENT_JAAS_CONTEXT - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Key to define the JAAS context.
KEY_REGISTRY_ENABLED - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
flag to indicate whether or not the registry should be enabled in the RM: "hadoop.registry.rm.enabled"
KEY_REGISTRY_KERBEROS_REALM - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
The kerberos realm: "hadoop.registry.kerberos.realm".
KEY_REGISTRY_SECURE - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Key to set if the registry is secure: "hadoop.registry.secure".
KEY_REGISTRY_SYSTEM_ACCOUNTS - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
A comma separated list of Zookeeper ACL identifiers with system access to the registry in a secure cluster: "hadoop.registry.system.accounts".
KEY_REGISTRY_USER_ACCOUNTS - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
A comma separated list of Zookeeper ACL identifiers with system access to the registry in a secure cluster: "hadoop.registry.user.accounts".
KEY_REGISTRY_ZK_CONNECTION_TIMEOUT - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Zookeeper connection timeout in milliseconds: "hadoop.registry.zk.connection.timeout.ms".
KEY_REGISTRY_ZK_QUORUM - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
List of hostname:port pairs defining the zookeeper quorum binding for the registry "hadoop.registry.zk.quorum"
KEY_REGISTRY_ZK_RETRY_CEILING - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Zookeeper retry limit in milliseconds, during exponential backoff: "hadoop.registry.zk.retry.ceiling.ms".
KEY_REGISTRY_ZK_RETRY_INTERVAL - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Zookeeper connect interval in milliseconds: "hadoop.registry.zk.retry.interval.ms".
KEY_REGISTRY_ZK_RETRY_TIMES - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Zookeeper connection retry count before failing: "hadoop.registry.zk.retry.times".
KEY_REGISTRY_ZK_ROOT - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Root path in the ZK tree for the registry: "hadoop.registry.zk.root"
KEY_REGISTRY_ZK_SESSION_TIMEOUT - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Zookeeper session timeout in milliseconds: "hadoop.registry.zk.session.timeout.ms"
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
 
KeyProvider - Class in org.apache.hadoop.crypto.key
A provider of secret key material for Hadoop applications.
KeyProvider(Configuration) - Constructor for class org.apache.hadoop.crypto.key.KeyProvider
Constructor.
KeyProviderFactory - Class in org.apache.hadoop.crypto.key
A factory to create a list of KeyProvider based on the path given in a Configuration.
KeyProviderFactory() - Constructor for class org.apache.hadoop.crypto.key.KeyProviderFactory
 
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 class org.apache.hadoop.yarn.client.api.YarnClient
Kill an application identified by given ID.
KillApplicationRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request sent by the client to the ResourceManager to abort a submitted application.
KillApplicationRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.KillApplicationRequest
 
KillApplicationResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to the client aborting a submitted application.
KillApplicationResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.KillApplicationResponse
 
KILLED - Static variable in class org.apache.hadoop.mapred.JobStatus
 
KILLED_AFTER_APP_COMPLETION - Static variable in class org.apache.hadoop.yarn.api.records.ContainerExitStatus
Container was terminated after the application finished.
KILLED_BY_APPMASTER - Static variable in class org.apache.hadoop.yarn.api.records.ContainerExitStatus
Container was terminated by stop request by the app master.
KILLED_BY_RESOURCEMANAGER - Static variable in class org.apache.hadoop.yarn.api.records.ContainerExitStatus
Container was terminated by the resource manager.
KILLED_EXCEEDED_PMEM - Static variable in class org.apache.hadoop.yarn.api.records.ContainerExitStatus
Container terminated because of exceeding allocated physical memory.
KILLED_EXCEEDED_VMEM - Static variable in class org.apache.hadoop.yarn.api.records.ContainerExitStatus
Container terminated because of exceeding allocated virtual memory.
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, boolean) - Method in class org.apache.hadoop.mapreduce.Job
Kill indicated task attempt.
killTask(TaskAttemptID) - Method in class org.apache.hadoop.mapreduce.Job
Kill indicated task attempt.
kind - Variable in class org.apache.hadoop.record.compiler.generated.Token
Deprecated.
An integer that describes the kind of this token.
KIND - Static variable in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
KIND - Static variable in class org.apache.hadoop.yarn.security.NMTokenIdentifier
 
KIND_NAME - Static variable in class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
 
KIND_NAME - Static variable in class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
 
KIND_NAME - Static variable in class org.apache.hadoop.yarn.security.client.RMDelegationTokenIdentifier
 
KIND_NAME - Static variable in class org.apache.hadoop.yarn.security.client.TimelineDelegationTokenIdentifier
 
KMS_CLIENT_ENC_KEY_CACHE_EXPIRY_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for KMS_CLIENT_ENC_KEY_CACHE_EXPIRY (12 hrs)
KMS_CLIENT_ENC_KEY_CACHE_EXPIRY_MS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
KMS_CLIENT_ENC_KEY_CACHE_LOW_WATERMARK - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
KMS_CLIENT_ENC_KEY_CACHE_LOW_WATERMARK_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for KMS_CLIENT_ENC_KEY_CACHE_LOW_WATERMARK
KMS_CLIENT_ENC_KEY_CACHE_NUM_REFILL_THREADS - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
KMS_CLIENT_ENC_KEY_CACHE_NUM_REFILL_THREADS_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for KMS_CLIENT_ENC_KEY_NUM_REFILL_THREADS
KMS_CLIENT_ENC_KEY_CACHE_SIZE - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
KMS_CLIENT_ENC_KEY_CACHE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
Default value for KMS_CLIENT_ENC_KEY_CACHE_SIZE

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.
 
LifecycleEvent - Class in org.apache.hadoop.service
A serializable lifecycle event: the time a state transition occurred, and what state was entered.
LifecycleEvent() - Constructor for class org.apache.hadoop.service.LifecycleEvent
 
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().
list(String) - Method in interface org.apache.hadoop.registry.client.api.RegistryOperations
List all entries under a registry path, returning the relative names of the entries.
list(String) - Method in class org.apache.hadoop.registry.client.impl.zk.RegistryOperationsService
 
LIST_STATUS_NUM_THREADS - Static variable in class org.apache.hadoop.mapreduce.lib.input.FileInputFormat
 
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
 
listDirectory(File, FilenameFilter) - Static method in class org.apache.hadoop.io.IOUtils
Return the complete list of files in a directory as strings.

This is better than File#listDir because it does not ignore IOExceptions.

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.
listServiceRecords(RegistryOperations, String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
List service records directly under a path
listSpanReceivers() - Method in interface org.apache.hadoop.tracing.TraceAdminProtocol
List the currently active trace span receivers.
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.azure.NativeAzureFileSystem
Retrieve the status of a given path if it is a file, or of all the contained files if it is a directory.
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.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.FileSystem
Returns a remote iterator so that followup calls are made on demand while consuming the entries.
listStatusIterator(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
Return a remote iterator for listing in a directory
listStatusIterator(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
listXAttrs(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Get all of the xattr names for a file or directory.
listXAttrs(Path) - Method in class org.apache.hadoop.fs.FileContext
Get all of the xattr names for a file or directory.
listXAttrs(Path) - Method in class org.apache.hadoop.fs.FileSystem
Get all of the xattr names for a file or directory.
listXAttrs(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
listXAttrs(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
listXAttrs(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.util.ApplicationClassLoader
 
loadClass(String, boolean) - Method in class org.apache.hadoop.util.ApplicationClassLoader
 
loadTokens(String, JobConf) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
Deprecated.
Use Credentials.readTokenStorageFile(org.apache.hadoop.fs.Path, org.apache.hadoop.conf.Configuration) instead, this method is included for compatibility against Hadoop-1.
loadTokens(String, Configuration) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
Deprecated.
Use Credentials.readTokenStorageFile(org.apache.hadoop.fs.Path, org.apache.hadoop.conf.Configuration) instead, this method is included for compatibility against Hadoop-1.
LOCAL_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 - Class in org.apache.hadoop.yarn.api.records
LocalResource represents a local resource required to run a container.
LocalResource() - Constructor for class org.apache.hadoop.yarn.api.records.LocalResource
 
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
LOG - Static variable in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
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
 
LOG_AGGREGATION_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Whether to enable log aggregation
LOG_AGGREGATION_RETAIN_CHECK_INTERVAL_SECONDS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
How long to wait between aggregated log retention checks.
LOG_AGGREGATION_RETAIN_SECONDS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
How long to wait before deleting aggregated logs, -1 disables.
LOG_DIR_EXPANSION_VAR - Static variable in interface org.apache.hadoop.yarn.api.ApplicationConstants
The temporary environmental variable for container log directory.
LogAggregationContext - Class in org.apache.hadoop.yarn.api.records
LogAggregationContext represents all of the information needed by the NodeManager to handle the logs for an application.
LogAggregationContext() - Constructor for class org.apache.hadoop.yarn.api.records.LogAggregationContext
 
LoggingStateChangeListener - Class in org.apache.hadoop.service
This is a state change listener that logs events at INFO level
LoggingStateChangeListener(Log) - Constructor for class org.apache.hadoop.service.LoggingStateChangeListener
Log events to the given log
LoggingStateChangeListener() - Constructor for class org.apache.hadoop.service.LoggingStateChangeListener
Log events to the static log for this class
LogsCLI - Class in org.apache.hadoop.yarn.client.cli
 
LogsCLI() - Constructor for class org.apache.hadoop.yarn.client.cli.LogsCLI
 
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.azure.WasbFsck
 
main(String[]) - Static method in class org.apache.hadoop.fs.s3.MigrationTool
 
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.tools.DistCp
Main function of the DistCp program.
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
 
main(String[]) - Static method in class org.apache.hadoop.yarn.client.cli.LogsCLI
 
make(OPERAND, STATE) - Method in class org.apache.hadoop.yarn.state.StateMachineFactory
 
make(OPERAND) - Method in class org.apache.hadoop.yarn.state.StateMachineFactory
 
makeAbsolute(Path) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
Get the absolute version of the path (fully qualified).
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.Counter
Returns the compact stringified version of the counter in the format [(actual-name)(display-name)(value)]
makeEscapedCompactString() - Method in class org.apache.hadoop.mapred.Counters.Group
 
makeEscapedCompactString() - Method in class org.apache.hadoop.mapred.Counters
Represent the counter in a textual format that can be converted back to its object form
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[], 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.
makeSplit(Path, long, long, String[], 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(String, String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
Create a single entry map
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_JOB_MAP_MEMORY_MB_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.
MAPRED_JOB_REDUCE_MEMORY_MB_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.
MAPRED_LOCAL_DIR_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Property name for the configuration property mapreduce.cluster.local.dir
MAPRED_MAP_TASK_ENV - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the environment of the child map tasks.
MAPRED_MAP_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the java command line options for the map tasks.
MAPRED_MAP_TASK_LOG_LEVEL - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the logging Level for the map task.
MAPRED_MAP_TASK_ULIMIT - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.
Configuration key to set the maximum virtual memory available to the map tasks (in kilo-bytes). This has been deprecated and will no longer have any effect.
MAPRED_REDUCE_TASK_ENV - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the environment of the child reduce tasks.
MAPRED_REDUCE_TASK_JAVA_OPTS - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the java command line options for the reduce tasks.
MAPRED_REDUCE_TASK_LOG_LEVEL - Static variable in class org.apache.hadoop.mapred.JobConf
Configuration key to set the logging Level for the reduce task.
MAPRED_REDUCE_TASK_ULIMIT - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.
Configuration key to set the maximum virtual memory available to the reduce tasks (in kilo-bytes). This has been deprecated and will no longer have any effect.
MAPRED_TASK_DEFAULT_MAXVMEM_PROPERTY - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated. 
MAPRED_TASK_ENV - Static variable in class org.apache.hadoop.mapred.JobConf
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.
MAPREDUCE_CLIENT_RETRY_POLICY_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.mapred.JobClient
 
MAPREDUCE_CLIENT_RETRY_POLICY_ENABLED_KEY - Static variable in class org.apache.hadoop.mapred.JobClient
 
MAPREDUCE_CLIENT_RETRY_POLICY_SPEC_DEFAULT - Static variable in class org.apache.hadoop.mapred.JobClient
 
MAPREDUCE_CLIENT_RETRY_POLICY_SPEC_KEY - Static variable in class org.apache.hadoop.mapred.JobClient
 
MAPREDUCE_RECOVER_JOB - Static variable in class org.apache.hadoop.mapred.JobConf
Deprecated.
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_APP_ATTEMPTS_ENV - Static variable in interface org.apache.hadoop.yarn.api.ApplicationConstants
The environment variable for MAX_APP_ATTEMPTS.
MAX_COUNTER_LIMIT - Static variable in class org.apache.hadoop.mapred.Counters
 
MAX_GROUP_LIMIT - Static variable in class org.apache.hadoop.mapred.Counters
 
MAX_NUM_UNIQUE_VALUES - Static variable in class org.apache.hadoop.mapreduce.lib.aggregate.UniqValueCount
 
MAX_PATH_LINKS - Static variable in interface org.apache.hadoop.fs.FsConstants
 
MAX_PERMISSION_LENGTH - Static variable in class org.apache.hadoop.fs.permission.FsPermission
Maximum acceptable length of a permission string to parse
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
 
mergePaths(Path, Path) - Static method in class org.apache.hadoop.fs.Path
Merge 2 paths such that the second path is appended relative to the first.
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
METRIC_TAG_ACCOUNT_NAME - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
 
METRIC_TAG_CONTAINTER_NAME - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
 
METRIC_TAG_FILESYSTEM_ID - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
 
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, FsPermission) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
mkdirs(Path, FsPermission, boolean) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
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
 
mkdirs(Path, FsPermission) - Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
 
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
 
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
 
mknode(String, boolean) - Method in interface org.apache.hadoop.registry.client.api.RegistryOperations
Create a path.
mknode(String, boolean) - Method in class org.apache.hadoop.registry.client.impl.zk.RegistryOperationsService
 
mkOneDir(File) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
mkOneDirWithMode(Path, File, FsPermission) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
 
modifyAclEntries(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Modifies ACL entries of files and directories.
modifyAclEntries(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.FileContext
Modifies ACL entries of files and directories.
modifyAclEntries(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.FileSystem
Modifies ACL entries of files and directories.
modifyAclEntries(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
modifyAclEntries(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
modifyAclEntries(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
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.
monitorHealth() - Method in interface org.apache.hadoop.ha.HAServiceProtocol
Monitor the health of service.
monitorHealth(HAServiceProtocol, HAServiceProtocol.StateChangeRequestInfo) - Static method in class org.apache.hadoop.ha.HAServiceProtocolHelper
 
moveApplicationAcrossQueues(MoveApplicationAcrossQueuesRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationClientProtocol
Move an application to a new queue.
moveApplicationAcrossQueues(ApplicationId, String) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
Attempts to move the given application to the given queue.
MoveApplicationAcrossQueuesRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request sent by the client to the ResourceManager to move a submitted application to a different queue.
MoveApplicationAcrossQueuesRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.MoveApplicationAcrossQueuesRequest
 
MoveApplicationAcrossQueuesResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to the client moving a submitted application to a different queue.
MoveApplicationAcrossQueuesResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.MoveApplicationAcrossQueuesResponse
 
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.
moveToDoneExecutor - Variable in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
 
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
 
MultipleArcTransition<OPERAND,EVENT,STATE extends Enum<STATE>> - Interface in org.apache.hadoop.yarn.state
Hook for Transition.
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 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
 
MutableQuantiles - Class in org.apache.hadoop.metrics2.lib
Watches a stream of long values, maintaining online estimates of specific quantiles with provably low error bounds.
MutableQuantiles(String, String, String, String, int) - Constructor for class org.apache.hadoop.metrics2.lib.MutableQuantiles
Instantiates a new MutableQuantiles for a metric that rolls itself over on the specified time interval.
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
 
NativeAzureFileSystem - Class in org.apache.hadoop.fs.azure
A FileSystem for reading and writing files stored on Windows Azure.
NativeAzureFileSystem() - Constructor for class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
NativeAzureFileSystem(NativeFileSystemStore) - Constructor for class org.apache.hadoop.fs.azure.NativeAzureFileSystem
 
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_DEPENDENCY_SCRIPT_FILE_NAME_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
 
NET_TOPOLOGY_IMPL_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
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
NET_TOPOLOGY_TABLE_MAPPING_FILE_KEY - Static variable in class org.apache.hadoop.fs.CommonConfigurationKeysPublic
newContainerId(ApplicationAttemptId, long) - Static method in class org.apache.hadoop.yarn.api.records.ContainerId
 
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
newInstance(int, float, List<ResourceRequest>, List<ContainerId>, ResourceBlacklistRequest) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
newInstance(int, float, List<ResourceRequest>, List<ContainerId>, ResourceBlacklistRequest, List<ContainerResourceIncreaseRequest>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
 
newInstance(int, List<ContainerStatus>, List<Container>, List<NodeReport>, Resource, AMCommand, int, PreemptionMessage, List<NMToken>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
 
newInstance(int, List<ContainerStatus>, List<Container>, List<NodeReport>, Resource, AMCommand, int, PreemptionMessage, List<NMToken>, List<ContainerResourceIncrease>, List<ContainerResourceDecrease>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
 
newInstance(int, List<ContainerStatus>, List<Container>, List<NodeReport>, Resource, AMCommand, int, PreemptionMessage, List<NMToken>, Token, List<ContainerResourceIncrease>, List<ContainerResourceDecrease>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
 
newInstance(FinalApplicationStatus, String, String) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.FinishApplicationMasterRequest
 
newInstance(boolean) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.FinishApplicationMasterResponse
 
newInstance(ApplicationAttemptId) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptReportRequest
 
newInstance(ApplicationAttemptReport) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptReportResponse
 
newInstance(ApplicationId) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptsRequest
 
newInstance(List<ApplicationAttemptReport>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptsResponse
 
newInstance(ApplicationId) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportRequest
 
newInstance(ApplicationReport) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportResponse
 
newInstance() - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
 
newInstance(ApplicationsRequestScope, Set<String>, Set<String>, Set<String>, Set<String>, EnumSet<YarnApplicationState>, LongRange, LongRange, Long) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
The request from clients to get a report of Applications matching the giving application types in the cluster from the ResourceManager.
newInstance(ApplicationsRequestScope) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
The request from clients to get a report of Applications matching the giving application types in the cluster from the ResourceManager.
newInstance(Set<String>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
The request from clients to get a report of Applications matching the giving application types in the cluster from the ResourceManager.
newInstance(EnumSet<YarnApplicationState>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
The request from clients to get a report of Applications matching the giving application states in the cluster from the ResourceManager.
newInstance(Set<String>, EnumSet<YarnApplicationState>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
The request from clients to get a report of Applications matching the giving and application types and application types in the cluster from the ResourceManager.
newInstance(List<ApplicationReport>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsResponse
 
newInstance() - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterMetricsRequest
 
newInstance(YarnClusterMetrics) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterMetricsResponse
 
newInstance() - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodeLabelsRequest
 
newInstance(Set<String>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodeLabelsResponse
 
newInstance(EnumSet<NodeState>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesRequest
 
newInstance() - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesRequest
 
newInstance(List<NodeReport>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesResponse
 
newInstance(ContainerId) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerReportRequest
 
newInstance(ContainerReport) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerReportResponse
 
newInstance(ApplicationAttemptId) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainersRequest
 
newInstance(List<ContainerReport>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainersResponse
 
newInstance(List<ContainerId>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusesRequest
 
newInstance(List<ContainerStatus>, Map<ContainerId, SerializedException>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusesResponse
 
newInstance(String) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenRequest
 
newInstance(Token) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenResponse
 
newInstance() - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationRequest
 
newInstance(ApplicationId, Resource, Resource) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse
 
newInstance(String, boolean, boolean, boolean) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
 
newInstance(QueueInfo) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoResponse
 
newInstance() - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetQueueUserAclsInfoRequest
 
newInstance(List<QueueUserACLInfo>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.GetQueueUserAclsInfoResponse
 
newInstance(ApplicationId) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.KillApplicationRequest
 
newInstance(boolean) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.KillApplicationResponse
 
newInstance(ApplicationId, String) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.MoveApplicationAcrossQueuesRequest
 
newInstance() - Method in class org.apache.hadoop.yarn.api.protocolrecords.MoveApplicationAcrossQueuesResponse
 
newInstance(String, int, String) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
Create a new instance of RegisterApplicationMasterRequest.
newInstance(Resource, Resource, Map<ApplicationAccessType, String>, ByteBuffer, List<Container>, String, List<NMToken>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
 
newInstance(ReservationId) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationDeleteRequest
 
newInstance() - Static method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationDeleteResponse
 
newInstance(ReservationDefinition, String) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationSubmissionRequest
 
newInstance(ReservationId) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationSubmissionResponse
 
newInstance(ReservationDefinition, ReservationId) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationUpdateRequest
 
newInstance() - Static method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationUpdateResponse
 
newInstance(ContainerLaunchContext, Token) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainerRequest
 
newInstance(List<StartContainerRequest>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainersRequest
 
newInstance(Map<String, ByteBuffer>, List<ContainerId>, Map<ContainerId, SerializedException>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainersResponse
 
newInstance(List<ContainerId>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.StopContainersRequest
 
newInstance(List<ContainerId>, Map<ContainerId, SerializedException>) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.StopContainersResponse
 
newInstance(ApplicationSubmissionContext) - Static method in class org.apache.hadoop.yarn.api.protocolrecords.SubmitApplicationRequest
 
newInstance() - Static method in class org.apache.hadoop.yarn.api.protocolrecords.SubmitApplicationResponse
 
newInstance(ApplicationId, int) - Static method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
 
newInstance(ApplicationAttemptId, String, int, String, String, String, YarnApplicationAttemptState, ContainerId) - Static method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
 
newInstance(long, int) - Static method in class org.apache.hadoop.yarn.api.records.ApplicationId
 
newInstance(ApplicationId, ApplicationAttemptId, String, String, String, String, int, Token, YarnApplicationState, String, String, long, long, FinalApplicationStatus, ApplicationResourceUsageReport, String, float, String, Token) - Static method in class org.apache.hadoop.yarn.api.records.ApplicationReport
 
newInstance(int, int, Resource, Resource, Resource, long, long) - Static method in class org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
 
newInstance(ApplicationId, String, String, Priority, ContainerLaunchContext, boolean, boolean, int, Resource, String, boolean, String, String) - Static method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
 
newInstance(ApplicationId, String, String, Priority, ContainerLaunchContext, boolean, boolean, int, Resource, String, boolean) - Static method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
 
newInstance(ApplicationId, String, String, Priority, ContainerLaunchContext, boolean, boolean, int, Resource, String) - Static method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
 
newInstance(ApplicationId, String, String, Priority, ContainerLaunchContext, boolean, boolean, int, Resource) - Static method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
 
newInstance(ApplicationId, String, String, ContainerLaunchContext, boolean, boolean, int, String, boolean, String, ResourceRequest) - Static method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
 
newInstance(ApplicationId, String, String, Priority, ContainerLaunchContext, boolean, boolean, int, Resource, String, boolean, long) - Static method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
 
newInstance(ApplicationId, String, String, Priority, ContainerLaunchContext, boolean, boolean, int, Resource, String, boolean, LogAggregationContext) - Static method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
 
newInstance(ContainerId, NodeId, String, Resource, Priority, Token) - Static method in class org.apache.hadoop.yarn.api.records.Container
 
newInstance(ApplicationAttemptId, int) - Static method in class org.apache.hadoop.yarn.api.records.ContainerId
Deprecated.
newInstance(Map<String, LocalResource>, Map<String, String>, List<String>, Map<String, ByteBuffer>, ByteBuffer, Map<ApplicationAccessType, String>) - Static method in class org.apache.hadoop.yarn.api.records.ContainerLaunchContext
 
newInstance(ContainerId, Resource, NodeId, Priority, long, long, String, String, int, ContainerState, String) - Static method in class org.apache.hadoop.yarn.api.records.ContainerReport
 
newInstance(ContainerId, Resource) - Static method in class org.apache.hadoop.yarn.api.records.ContainerResourceIncreaseRequest
 
newInstance(ContainerId, ContainerState, String, int) - Static method in class org.apache.hadoop.yarn.api.records.ContainerStatus
 
newInstance(URL, LocalResourceType, LocalResourceVisibility, long, long, String) - Static method in class org.apache.hadoop.yarn.api.records.LocalResource
 
newInstance(URL, LocalResourceType, LocalResourceVisibility, long, long, String, boolean) - Static method in class org.apache.hadoop.yarn.api.records.LocalResource
 
newInstance(URL, LocalResourceType, LocalResourceVisibility, long, long) - Static method in class org.apache.hadoop.yarn.api.records.LocalResource
 
newInstance(URL, LocalResourceType, LocalResourceVisibility, long, long, boolean) - Static method in class org.apache.hadoop.yarn.api.records.LocalResource
 
newInstance(String, String) - Static method in class org.apache.hadoop.yarn.api.records.LogAggregationContext
 
newInstance(String, String, String, String) - Static method in class org.apache.hadoop.yarn.api.records.LogAggregationContext
 
newInstance(NodeId, Token) - Static method in class org.apache.hadoop.yarn.api.records.NMToken
 
newInstance(String, int) - Static method in class org.apache.hadoop.yarn.api.records.NodeId
 
newInstance(NodeId, NodeState, String, String, Resource, Resource, int, String, long) - Static method in class org.apache.hadoop.yarn.api.records.NodeReport
 
newInstance(NodeId, NodeState, String, String, Resource, Resource, int, String, long, Set<String>) - Static method in class org.apache.hadoop.yarn.api.records.NodeReport
 
newInstance(ContainerId) - Static method in class org.apache.hadoop.yarn.api.records.PreemptionContainer
 
newInstance(List<PreemptionResourceRequest>, Set<PreemptionContainer>) - Static method in class org.apache.hadoop.yarn.api.records.PreemptionContract
 
newInstance(StrictPreemptionContract, PreemptionContract) - Static method in class org.apache.hadoop.yarn.api.records.PreemptionMessage
 
newInstance(ResourceRequest) - Static method in class org.apache.hadoop.yarn.api.records.PreemptionResourceRequest
 
newInstance(int) - Static method in class org.apache.hadoop.yarn.api.records.Priority
 
newInstance(String, float, float, float, List<QueueInfo>, List<ApplicationReport>, QueueState, Set<String>, String) - Static method in class org.apache.hadoop.yarn.api.records.QueueInfo
 
newInstance(String, List<QueueACL>) - Static method in class org.apache.hadoop.yarn.api.records.QueueUserACLInfo
 
newInstance(long, long, ReservationRequests, String) - Static method in class org.apache.hadoop.yarn.api.records.ReservationDefinition
 
newInstance(long, long) - Static method in class org.apache.hadoop.yarn.api.records.ReservationId
 
newInstance(Resource, int) - Static method in class org.apache.hadoop.yarn.api.records.ReservationRequest
 
newInstance(Resource, int, int, long) - Static method in class org.apache.hadoop.yarn.api.records.ReservationRequest
 
newInstance(List<ReservationRequest>, ReservationRequestInterpreter) - Static method in class org.apache.hadoop.yarn.api.records.ReservationRequests
 
newInstance(int, int) - Static method in class org.apache.hadoop.yarn.api.records.Resource
 
newInstance(List<String>, List<String>) - Static method in class org.apache.hadoop.yarn.api.records.ResourceBlacklistRequest
 
newInstance(Resource, int) - Static method in class org.apache.hadoop.yarn.api.records.ResourceOption
 
newInstance(Priority, String, Resource, int) - Static method in class org.apache.hadoop.yarn.api.records.ResourceRequest
 
newInstance(Priority, String, Resource, int, boolean) - Static method in class org.apache.hadoop.yarn.api.records.ResourceRequest
 
newInstance(Priority, String, Resource, int, boolean, String) - Static method in class org.apache.hadoop.yarn.api.records.ResourceRequest
 
newInstance(Set<PreemptionContainer>) - Static method in class org.apache.hadoop.yarn.api.records.StrictPreemptionContract
 
newInstance(byte[], String, byte[], String) - Static method in class org.apache.hadoop.yarn.api.records.Token
 
newInstance(String, String, int, String) - Static method in class org.apache.hadoop.yarn.api.records.URL
 
newInstance(int) - Static method in class org.apache.hadoop.yarn.api.records.YarnClusterMetrics
 
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
 
newMetricsSourceName() - Static method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
Creates a new metrics source name that's unique within this process.
newQuantiles(String, String, String, String, int) - Method in class org.apache.hadoop.metrics2.lib.MetricsRegistry
Create a mutable metric that estimates quantiles of a stream of values
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 class org.apache.hadoop.mapred.lib.CombineFileRecordReaderWrapper
 
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.
next(AggregatedLogFormat.LogKey) - Method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogReader
Read the next key and return the value-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.CombineFileRecordReaderWrapper
 
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
 
NM_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
address of node manager IPC.
NM_ADMIN_USER_ENV - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Environment variables that will be sent to containers.
NM_AUX_SERVICE_FMT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
NM_AUX_SERVICES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
NM_BIND_HOST - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The actual bind address or the NM.
NM_CLIENT_ASYNC_THREAD_POOL_MAX_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Max number of threads in NMClientAsync to process container management events
NM_CLIENT_MAX_NM_PROXIES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Maximum number of proxy connections to cache for node managers.
NM_CONTAINER_EXECUTOR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
who will execute(launch) the containers.
NM_CONTAINER_EXECUTOR_SCHED_PRIORITY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Adjustment to make to the container os scheduling priority.
NM_CONTAINER_METRICS_ENABLE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Enable/disable container metrics.
NM_CONTAINER_METRICS_PERIOD_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Container metrics flush period.
NM_CONTAINER_MGR_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Number of threads container manager uses.
NM_CONTAINER_MON_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
How often to monitor containers.
NM_CONTAINER_MON_PROCESS_TREE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Class that calculates process tree resource utilization.
NM_CONTAINER_MON_RESOURCE_CALCULATOR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Class that calculates containers current resource utilization.
NM_DEFAULT_DOCKER_CONTAINER_EXECUTOR_EXEC_NAME - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The default docker executor (For DockerContainerExecutor).
NM_DELETE_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Number of threads used in cleanup.
NM_DISK_HEALTH_CHECK_ENABLE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Enable/Disable disks' health checker.
NM_DISK_HEALTH_CHECK_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Frequency of running disks' health checker.
NM_DOCKER_CONTAINER_EXECUTOR_EXEC_NAME - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The name of the docker executor (For DockerContainerExecutor).
NM_DOCKER_CONTAINER_EXECUTOR_IMAGE_NAME - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The Docker image name(For DockerContainerExecutor).
NM_ENV_WHITELIST - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Environment variables that containers may override rather than use NodeManager's default.
NM_HEALTH_CHECK_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Frequency of running node health script.
NM_HEALTH_CHECK_SCRIPT_OPTS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The arguments to pass to the health check script.
NM_HEALTH_CHECK_SCRIPT_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The health check script to run.
NM_HEALTH_CHECK_SCRIPT_TIMEOUT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Health check script time out period.
NM_KEYTAB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Keytab for NM.
NM_LINUX_CONTAINER_CGROUPS_DELETE_DELAY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Delay between attempts to remove linux cgroup.
NM_LINUX_CONTAINER_CGROUPS_DELETE_TIMEOUT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Interval of time the linux container executor should try cleaning up cgroups entry when cleaning up a container.
NM_LINUX_CONTAINER_CGROUPS_HIERARCHY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The path the linux container executor should use for cgroups
NM_LINUX_CONTAINER_CGROUPS_MOUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Whether the linux container executor should mount cgroups if not found
NM_LINUX_CONTAINER_CGROUPS_MOUNT_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Where the linux container executor should mount cgroups if not found
NM_LINUX_CONTAINER_CGROUPS_STRICT_RESOURCE_USAGE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Whether the apps should run in strict resource usage mode(not allowed to use spare CPU)
NM_LINUX_CONTAINER_EXECUTOR_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The path to the Linux container executor.
NM_LINUX_CONTAINER_GROUP - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The UNIX group that the linux-container-executor should run as.
NM_LINUX_CONTAINER_RESOURCES_HANDLER - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The type of resource enforcement to use with the linux container executor.
NM_LOCAL_CACHE_MAX_FILES_PER_DIRECTORY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Number of files in each localized directories Avoid tuning this too low.
NM_LOCAL_DIRS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
List of directories to store localized files in.
NM_LOCALIZER_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Address where the localizer IPC is.
NM_LOCALIZER_CACHE_CLEANUP_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Interval in between cache cleanups.
NM_LOCALIZER_CACHE_TARGET_SIZE_MB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Target size of localizer cache in MB, per nodemanager.
NM_LOCALIZER_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Number of threads to handle localization requests.
NM_LOCALIZER_FETCH_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Number of threads to use for localization fetching.
NM_LOG_AGG_COMPRESSION_TYPE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
T-file compression types used to compress aggregated logs.
NM_LOG_AGGREGATION_ROLL_MONITORING_INTERVAL_SECONDS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Define how often NMs wake up and upload log files
NM_LOG_DELETION_THREADS_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Number of threads used in log cleanup.
NM_LOG_DIRS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Where to store container logs.
NM_LOG_RETAIN_SECONDS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Number of seconds to retain logs on the NodeManager.
NM_MAX_PER_DISK_UTILIZATION_PERCENTAGE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The maximum percentage of disk space that can be used after which a disk is marked as offline.
NM_MIN_HEALTHY_DISKS_FRACTION - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The minimum fraction of number of disks to be healthy for the nodemanager to launch new containers.
NM_MIN_PER_DISK_FREE_SPACE_MB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The minimum space that must be available on a local dir for it to be used.
NM_NONSECURE_MODE_LIMIT_USERS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
If linux-container-executor should limit itself to one user when running in non-secure mode.
NM_NONSECURE_MODE_LOCAL_USER_KEY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The UNIX user that containers will run as when Linux-container-executor is used in nonsecure mode (a use case for this is using cgroups).
NM_NONSECURE_MODE_USER_PATTERN_KEY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The allowed pattern for UNIX user names enforced by Linux-container-executor when used in nonsecure mode (use case for this is using cgroups).
NM_PMEM_CHECK_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Specifies whether physical memory check is enabled.
NM_PMEM_MB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Amount of memory in GB that can be allocated for containers.
NM_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Prefix for all node manager configs.
NM_PRINCIPAL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The kerberos principal for the node manager.
NM_PROCESS_KILL_WAIT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Max time to wait for a process to come up when trying to cleanup container resources
NM_RECOVERY_DIR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
NM_RECOVERY_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
NM_RECOVERY_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
NM_REMOTE_APP_LOG_DIR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Where to aggregate logs to.
NM_REMOTE_APP_LOG_DIR_SUFFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The remote log dir will be created at NM_REMOTE_APP_LOG_DIR/${user}/NM_REMOTE_APP_LOG_DIR_SUFFIX/${appId}
NM_RESOURCE_PERCENTAGE_PHYSICAL_CPU_LIMIT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Percentage of overall CPU which can be allocated for containers.
NM_RESOURCEMANAGER_MINIMUM_VERSION - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
NM_SLEEP_DELAY_BEFORE_SIGKILL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
No.
NM_USER_HOME_DIR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
NM_VCORES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Number of Virtual CPU Cores which can be allocated for containers.
NM_VMEM_CHECK_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Specifies whether physical memory check is enabled.
NM_VMEM_PMEM_RATIO - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Conversion ratio for physical memory to virtual memory.
NM_WEBAPP_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
NM Webapp address.
NM_WEBAPP_HTTPS_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
NM Webapp https address.
NM_WEBAPP_SPNEGO_KEYTAB_FILE_KEY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The kerberos keytab to be used for spnego filter for NM.
NM_WEBAPP_SPNEGO_USER_NAME_KEY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The kerberos principal to be used for spnego filter for NM.
NM_WINDOWS_CONTAINER_CPU_LIMIT_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
NM_WINDOWS_CONTAINER_MEMORY_LIMIT_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Indicates if memory and CPU limits will be set for the Windows Job Object for the containers launched by the default container executor.
NM_WINDOWS_SECURE_CONTAINER_GROUP - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
/* The Windows group that the windows-secure-container-executor should run as.
NMClient - Class in org.apache.hadoop.yarn.client.api
 
NMClient(String) - Constructor for class org.apache.hadoop.yarn.client.api.NMClient
 
NMClientAsync - Class in org.apache.hadoop.yarn.client.api.async
NMClientAsync handles communication with all the NodeManagers and provides asynchronous updates on getting responses from them.
NMClientAsync(NMClientAsync.CallbackHandler) - Constructor for class org.apache.hadoop.yarn.client.api.async.NMClientAsync
 
NMClientAsync(String, NMClientAsync.CallbackHandler) - Constructor for class org.apache.hadoop.yarn.client.api.async.NMClientAsync
 
NMClientAsync(String, NMClient, NMClientAsync.CallbackHandler) - Constructor for class org.apache.hadoop.yarn.client.api.async.NMClientAsync
 
NMProxy - Class in org.apache.hadoop.yarn.client
 
NMProxy() - Constructor for class org.apache.hadoop.yarn.client.NMProxy
 
NMToken - Class in org.apache.hadoop.yarn.api.records
The NMToken is used for authenticating communication with NodeManager
NMToken() - Constructor for class org.apache.hadoop.yarn.api.records.NMToken
 
NMTokenCache - Class in org.apache.hadoop.yarn.client.api
NMTokenCache manages NMTokens required for an Application Master communicating with individual NodeManagers.
NMTokenCache() - Constructor for class org.apache.hadoop.yarn.client.api.NMTokenCache
Creates a NM token cache instance.
NMTokenIdentifier - Class in org.apache.hadoop.yarn.security
 
NMTokenIdentifier(ApplicationAttemptId, NodeId, String, int) - Constructor for class org.apache.hadoop.yarn.security.NMTokenIdentifier
 
NMTokenIdentifier() - Constructor for class org.apache.hadoop.yarn.security.NMTokenIdentifier
Default constructor needed by RPC/Secret manager
NO_DOMAIN - Static variable in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
Error code returned if the entity doesn't have an valid domain ID
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"
NO_START_TIME - Static variable in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
Error code returned when no start time can be found when putting an entity.
NoChildrenForEphemeralsException - Exception in org.apache.hadoop.registry.client.exceptions
This is a manifestation of the Zookeeper restrictions about what nodes may act as parents.
NoChildrenForEphemeralsException(String, Throwable) - Constructor for exception org.apache.hadoop.registry.client.exceptions.NoChildrenForEphemeralsException
 
NoChildrenForEphemeralsException(String, String) - Constructor for exception org.apache.hadoop.registry.client.exceptions.NoChildrenForEphemeralsException
 
NoChildrenForEphemeralsException(String, String, Throwable) - Constructor for exception org.apache.hadoop.registry.client.exceptions.NoChildrenForEphemeralsException
 
NODE_LABELS_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Flag to indicate if the node labels feature enabled, by default it's disabled
NODE_LABELS_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Node-labels configurations
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 - Class in org.apache.hadoop.yarn.api.records
NodeReport is a summary of runtime information of a node in the cluster.
NodeReport() - Constructor for class org.apache.hadoop.yarn.api.records.NodeReport
 
NodeState - Enum in org.apache.hadoop.yarn.api.records
State of a Node.
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
NoRecordException - Exception in org.apache.hadoop.registry.client.exceptions
Raised if there is no ServiceRecord resolved at the end of the specified path.
NoRecordException(String, String) - Constructor for exception org.apache.hadoop.registry.client.exceptions.NoRecordException
 
NoRecordException(String, String, Throwable) - Constructor for exception org.apache.hadoop.registry.client.exceptions.NoRecordException
 
normalizeMemoryConfigValue(long) - Static method in class org.apache.hadoop.mapred.JobConf
Normalize the negative values in configuration
not() - Method in enum org.apache.hadoop.fs.permission.FsAction
NOT operation.
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
 
noteFailure(Exception) - Method in class org.apache.hadoop.service.AbstractService
Failure handling: record the exception that triggered it -if there was not one already.
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
 
numAllocatedContainers - Variable in class org.apache.hadoop.yarn.applications.distributedshell.ApplicationMaster
 
numberOfTokensInCache() - Method in class org.apache.hadoop.yarn.client.api.NMTokenCache
Returns the number of NMTokens present in cache.
numRequestedContainers - Variable in class org.apache.hadoop.yarn.applications.distributedshell.ApplicationMaster
 
numTotalContainers - Variable in class org.apache.hadoop.yarn.applications.distributedshell.ApplicationMaster
 

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
 
onlyKeyExists(String) - Method in class org.apache.hadoop.conf.Configuration
Return existence of the name property, but only for names which have no valid value, usually non-existent or commented out in XML.
OP_PARAM - Static variable in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
 
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.azure.NativeAzureFileSystem
 
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.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
 
openConnection(URL, AuthenticatedURL.Token) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
Returns an authenticated HttpURLConnection, it uses a Delegation Token only if the given auth token is an instance of DelegationTokenAuthenticatedURL.Token and it contains a Delegation Token, otherwise use the configured DelegationTokenAuthenticator to authenticate the connection.
openConnection(URL, DelegationTokenAuthenticatedURL.Token) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
Returns an authenticated HttpURLConnection.
openConnection(URL, DelegationTokenAuthenticatedURL.Token, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
Returns an authenticated HttpURLConnection.
options(Configuration) - Static method in class org.apache.hadoop.crypto.key.KeyProvider
A helper function to create an options object.
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(FsAction) - Method in enum org.apache.hadoop.fs.permission.FsAction
OR operation.
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.ant - package org.apache.hadoop.ant
 
org.apache.hadoop.ant.condition - package org.apache.hadoop.ant.condition
 
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.bkjournal - package org.apache.hadoop.contrib.bkjournal
 
org.apache.hadoop.contrib.utils.join - package org.apache.hadoop.contrib.utils.join
 
org.apache.hadoop.crypto - package org.apache.hadoop.crypto
 
org.apache.hadoop.crypto.key - package org.apache.hadoop.crypto.key
 
org.apache.hadoop.crypto.key.kms - package org.apache.hadoop.crypto.key.kms
 
org.apache.hadoop.crypto.key.kms.server - package org.apache.hadoop.crypto.key.kms.server
 
org.apache.hadoop.crypto.random - package org.apache.hadoop.crypto.random
 
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.azure - package org.apache.hadoop.fs.azure
A distributed implementation of FileSystem for reading and writing files on Azure Block Storage.
org.apache.hadoop.fs.azure.metrics - package org.apache.hadoop.fs.azure.metrics
Infrastructure for a Metrics2 source that provides information on Windows Azure Filesystem for Hadoop instances.
org.apache.hadoop.fs.crypto - package org.apache.hadoop.fs.crypto
 
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.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.s3a - package org.apache.hadoop.fs.s3a
 
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.shell.find - package org.apache.hadoop.fs.shell.find
 
org.apache.hadoop.fs.swift.auth - package org.apache.hadoop.fs.swift.auth
 
org.apache.hadoop.fs.swift.auth.entities - package org.apache.hadoop.fs.swift.auth.entities
 
org.apache.hadoop.fs.swift.exceptions - package org.apache.hadoop.fs.swift.exceptions
 
org.apache.hadoop.fs.swift.http - package org.apache.hadoop.fs.swift.http
 
org.apache.hadoop.fs.swift.snative - package org.apache.hadoop.fs.swift.snative
 
org.apache.hadoop.fs.swift.util - package org.apache.hadoop.fs.swift.util
 
org.apache.hadoop.fs.viewfs - package org.apache.hadoop.fs.viewfs
 
org.apache.hadoop.ha - package org.apache.hadoop.ha
 
org.apache.hadoop.ha.proto - package org.apache.hadoop.ha.proto
 
org.apache.hadoop.ha.protocolPB - package org.apache.hadoop.ha.protocolPB
 
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.ipc.proto - package org.apache.hadoop.ipc.proto
 
org.apache.hadoop.ipc.protobuf - package org.apache.hadoop.ipc.protobuf
 
org.apache.hadoop.ipc.protocolPB - package org.apache.hadoop.ipc.protocolPB
 
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.proto - package org.apache.hadoop.mapred.proto
 
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.counters - package org.apache.hadoop.mapreduce.counters
This package contains the implementations of different types of map-reduce counters.
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.task.annotation - package org.apache.hadoop.mapreduce.task.annotation
 
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.api.protocolrecords - package org.apache.hadoop.mapreduce.v2.api.protocolrecords
 
org.apache.hadoop.mapreduce.v2.app.webapp.dao - package org.apache.hadoop.mapreduce.v2.app.webapp.dao
 
org.apache.hadoop.mapreduce.v2.hs - package org.apache.hadoop.mapreduce.v2.hs
 
org.apache.hadoop.mapreduce.v2.hs.client - package org.apache.hadoop.mapreduce.v2.hs.client
 
org.apache.hadoop.mapreduce.v2.hs.proto - package org.apache.hadoop.mapreduce.v2.hs.proto
 
org.apache.hadoop.mapreduce.v2.hs.protocolPB - package org.apache.hadoop.mapreduce.v2.hs.protocolPB
 
org.apache.hadoop.mapreduce.v2.hs.server - package org.apache.hadoop.mapreduce.v2.hs.server
 
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.maven.plugin.protoc - package org.apache.hadoop.maven.plugin.protoc
 
org.apache.hadoop.maven.plugin.util - package org.apache.hadoop.maven.plugin.util
 
org.apache.hadoop.maven.plugin.versioninfo - package org.apache.hadoop.maven.plugin.versioninfo
 
org.apache.hadoop.metrics - package org.apache.hadoop.metrics
This package defines an API for reporting performance metric information.
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.minikdc - package org.apache.hadoop.minikdc
 
org.apache.hadoop.mount - package org.apache.hadoop.mount
 
org.apache.hadoop.net - package org.apache.hadoop.net
Network-related classes.
org.apache.hadoop.net.unix - package org.apache.hadoop.net.unix
 
org.apache.hadoop.nfs - package org.apache.hadoop.nfs
 
org.apache.hadoop.nfs.nfs3 - package org.apache.hadoop.nfs.nfs3
 
org.apache.hadoop.nfs.nfs3.request - package org.apache.hadoop.nfs.nfs3.request
 
org.apache.hadoop.nfs.nfs3.response - package org.apache.hadoop.nfs.nfs3.response
 
org.apache.hadoop.oncrpc - package org.apache.hadoop.oncrpc
 
org.apache.hadoop.oncrpc.security - package org.apache.hadoop.oncrpc.security
 
org.apache.hadoop.portmap - package org.apache.hadoop.portmap
 
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.registry.cli - package org.apache.hadoop.registry.cli
 
org.apache.hadoop.registry.client.api - package org.apache.hadoop.registry.client.api
YARN Registry Client API.
org.apache.hadoop.registry.client.binding - package org.apache.hadoop.registry.client.binding
Registry binding utility classes.
org.apache.hadoop.registry.client.exceptions - package org.apache.hadoop.registry.client.exceptions
Registry Service Exceptions
org.apache.hadoop.registry.client.impl - package org.apache.hadoop.registry.client.impl
Registry client services
org.apache.hadoop.registry.client.impl.zk - package org.apache.hadoop.registry.client.impl.zk
Core Zookeeper support.
org.apache.hadoop.registry.client.types - package org.apache.hadoop.registry.client.types
This package contains all the data types which can be saved to the registry and/or marshalled to and from JSON.
org.apache.hadoop.registry.client.types.yarn - package org.apache.hadoop.registry.client.types.yarn
 
org.apache.hadoop.registry.server - package org.apache.hadoop.registry.server
Server-side classes for the registry
org.apache.hadoop.registry.server.integration - package org.apache.hadoop.registry.server.integration
This package contains the classes which integrate with the YARN resource manager.
org.apache.hadoop.registry.server.services - package org.apache.hadoop.registry.server.services
Basic services for the YARN registry The RegistryAdminService extends the shared Yarn Registry client with registry setup and (potentially asynchronous) administrative actions.
org.apache.hadoop.security - package org.apache.hadoop.security
 
org.apache.hadoop.security.alias - package org.apache.hadoop.security.alias
 
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.security.proto - package org.apache.hadoop.security.proto
 
org.apache.hadoop.security.protocolPB - package org.apache.hadoop.security.protocolPB
 
org.apache.hadoop.security.ssl - package org.apache.hadoop.security.ssl
 
org.apache.hadoop.security.token.delegation.web - package org.apache.hadoop.security.token.delegation.web
 
org.apache.hadoop.service - package org.apache.hadoop.service
 
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.proto - package org.apache.hadoop.tools.proto
 
org.apache.hadoop.tools.protocolPB - package org.apache.hadoop.tools.protocolPB
 
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.tracing - package org.apache.hadoop.tracing
 
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.curator - package org.apache.hadoop.util.curator
 
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.api.records.timeline - package org.apache.hadoop.yarn.api.records.timeline
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
org.apache.hadoop.yarn.applications.distributedshell - package org.apache.hadoop.yarn.applications.distributedshell
 
org.apache.hadoop.yarn.applications.unmanagedamlauncher - package org.apache.hadoop.yarn.applications.unmanagedamlauncher
 
org.apache.hadoop.yarn.client - package org.apache.hadoop.yarn.client
 
org.apache.hadoop.yarn.client.api - package org.apache.hadoop.yarn.client.api
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
org.apache.hadoop.yarn.client.api.async - package org.apache.hadoop.yarn.client.api.async
 
org.apache.hadoop.yarn.client.api.async.impl - package org.apache.hadoop.yarn.client.api.async.impl
 
org.apache.hadoop.yarn.client.api.impl - package org.apache.hadoop.yarn.client.api.impl
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
org.apache.hadoop.yarn.client.cli - package org.apache.hadoop.yarn.client.cli
 
org.apache.hadoop.yarn.conf - package org.apache.hadoop.yarn.conf
 
org.apache.hadoop.yarn.event - package org.apache.hadoop.yarn.event
 
org.apache.hadoop.yarn.exceptions - package org.apache.hadoop.yarn.exceptions
 
org.apache.hadoop.yarn.logaggregation - package org.apache.hadoop.yarn.logaggregation
 
org.apache.hadoop.yarn.nodelabels - package org.apache.hadoop.yarn.nodelabels
 
org.apache.hadoop.yarn.nodelabels.event - package org.apache.hadoop.yarn.nodelabels.event
 
org.apache.hadoop.yarn.security - package org.apache.hadoop.yarn.security
 
org.apache.hadoop.yarn.security.admin - package org.apache.hadoop.yarn.security.admin
 
org.apache.hadoop.yarn.security.client - package org.apache.hadoop.yarn.security.client
 
org.apache.hadoop.yarn.sharedcache - package org.apache.hadoop.yarn.sharedcache
 
org.apache.hadoop.yarn.sls - package org.apache.hadoop.yarn.sls
 
org.apache.hadoop.yarn.sls.appmaster - package org.apache.hadoop.yarn.sls.appmaster
 
org.apache.hadoop.yarn.sls.conf - package org.apache.hadoop.yarn.sls.conf
 
org.apache.hadoop.yarn.sls.nodemanager - package org.apache.hadoop.yarn.sls.nodemanager
 
org.apache.hadoop.yarn.sls.scheduler - package org.apache.hadoop.yarn.sls.scheduler
 
org.apache.hadoop.yarn.sls.utils - package org.apache.hadoop.yarn.sls.utils
 
org.apache.hadoop.yarn.sls.web - package org.apache.hadoop.yarn.sls.web
 
org.apache.hadoop.yarn.state - package org.apache.hadoop.yarn.state
 
org.apache.hadoop.yarn.util - package org.apache.hadoop.yarn.util
 
org.apache.hadoop.yarn.util.resource - package org.apache.hadoop.yarn.util.resource
 
org.apache.hadoop.yarn.util.timeline - package org.apache.hadoop.yarn.util.timeline
 
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.
OVERWRITE - Static variable in interface org.apache.hadoop.registry.client.api.BindFlags
The entry should be created even if an existing entry is there.

P

PARAMETER_EXPANSION_LEFT - Static variable in interface org.apache.hadoop.yarn.api.ApplicationConstants
The following two constants are used to expand parameter and it will be replaced with real parameter expansion marker ('%' for Windows and '$' for Linux) by NodeManager on container launch.
PARAMETER_EXPANSION_RIGHT - Static variable in interface org.apache.hadoop.yarn.api.ApplicationConstants
User has to use this constant to construct class path if user wants cross-platform practice i.e.
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.
parseAclEntry(String, boolean) - Static method in class org.apache.hadoop.fs.permission.AclEntry
Parses a string representation of an ACL into a AclEntry object.
parseAclSpec(String, boolean) - Static method in class org.apache.hadoop.fs.permission.AclEntry
Parses a string representation of an ACL spec into a list of AclEntry objects.
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
 
parseReservationId(String) - Static method in class org.apache.hadoop.yarn.api.records.ReservationId
Parse the string argument as a ReservationId
parseStorageType(int) - Static method in enum org.apache.hadoop.fs.StorageType
 
parseStorageType(String) - Static method in enum org.apache.hadoop.fs.StorageType
 
PART - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat
 
PartialFileOutputCommitter - Class in org.apache.hadoop.mapreduce.lib.output
An OutputCommitter that commits files specified in job output directory i.e.
PartialFileOutputCommitter(Path, TaskAttemptContext) - Constructor for class org.apache.hadoop.mapreduce.lib.output.PartialFileOutputCommitter
 
PartialFileOutputCommitter(Path, JobContext) - Constructor for class org.apache.hadoop.mapreduce.lib.output.PartialFileOutputCommitter
 
PartialOutputCommitter - Interface in org.apache.hadoop.mapreduce.lib.output
Interface for an OutputCommitter implementing partial commit of task output, as during preemption.
Partitioner<K2,V2> - Interface in org.apache.hadoop.mapred
Partitions the key space.
PARTITIONER - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
Partitioner<KEY,VALUE> - Class in org.apache.hadoop.mapreduce
Partitions the key space.
Partitioner() - Constructor for class org.apache.hadoop.mapreduce.Partitioner
 
PARTITIONER_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.
path - Variable in class org.apache.hadoop.registry.client.types.RegistryPathStatus
Short path in the registry to this entry
PATH_SYSTEM_SERVICES - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
path to system services off the root : "/services/".
PATH_USER_SERVICES - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
path to system services under a user's home path : "/services/".
PATH_USERS - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
path to users off the root: "/users/".
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.
pathToKey(Path) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
Convert the path to a key.
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.
PORT - Static variable in class org.apache.hadoop.mapred.pipes.Submitter
 
PositionedReadable - Interface in org.apache.hadoop.fs
Stream that permits positional reading.
PREEMPTED - Static variable in class org.apache.hadoop.yarn.api.records.ContainerExitStatus
Containers preempted by the framework.
PreemptionContainer - Class in org.apache.hadoop.yarn.api.records
Specific container requested back by the ResourceManager.
PreemptionContainer() - Constructor for class org.apache.hadoop.yarn.api.records.PreemptionContainer
 
PreemptionContract - Class in org.apache.hadoop.yarn.api.records
Description of resources requested back by the ResourceManager.
PreemptionContract() - Constructor for class org.apache.hadoop.yarn.api.records.PreemptionContract
 
PreemptionMessage - Class in org.apache.hadoop.yarn.api.records
A PreemptionMessage is part of the RM-AM protocol, and it is used by the RM to specify resources that the RM wants to reclaim from this ApplicationMaster (AM).
PreemptionMessage() - Constructor for class org.apache.hadoop.yarn.api.records.PreemptionMessage
 
PreemptionResourceRequest - Class in org.apache.hadoop.yarn.api.records
Description of resources requested back by the cluster.
PreemptionResourceRequest() - Constructor for class org.apache.hadoop.yarn.api.records.PreemptionResourceRequest
 
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.
 
previousSnapshot - Variable in class org.apache.hadoop.metrics2.lib.MutableQuantiles
 
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
 
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(PrintStream, String) - Static method in class org.apache.hadoop.util.ReflectionUtils
Print all of the thread's information and stack traces.
Priority - Class in org.apache.hadoop.yarn.api.records
The priority assigned to a ResourceRequest or Application or Container allocation
Priority() - Constructor for class org.apache.hadoop.yarn.api.records.Priority
 
processDeleteOnExit() - Method in class org.apache.hadoop.fs.FileSystem
Delete all files that were marked as delete-on-exit.
PROCFS_USE_SMAPS_BASED_RSS_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
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.
PROTOCOL_FILESYSTEM - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
Addresses are URIs of Hadoop Filesystem paths: "hadoop/filesystem".
PROTOCOL_HADOOP_IPC - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
Hadoop IPC, "classic" or protobuf : "hadoop/IPC".
PROTOCOL_IIOP - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
Corba IIOP: "IIOP".
PROTOCOL_REST - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
REST: "REST".
PROTOCOL_RMI - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
Java RMI: "RMI".
PROTOCOL_SUN_RPC - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
SunOS RPC, as used by NFS and similar: "sunrpc".
PROTOCOL_TCP - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
Custom TCP protocol: "tcp".
PROTOCOL_THRIFT - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
Thrift-based protocols: "thrift".
PROTOCOL_UDP - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
Custom UPC-based protocol : "udp".
PROTOCOL_UNKNOWN - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
Default value —the protocol is unknown : """"
PROTOCOL_WEBUI - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
Web page: "webui".
PROTOCOL_WSAPI - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
Web Services: "WS-*".
PROTOCOL_ZOOKEEPER_BINDING - Static variable in interface org.apache.hadoop.registry.client.types.ProtocolTypes
A zookeeper binding: "zookeeper".
protocolType - Variable in class org.apache.hadoop.registry.client.types.Endpoint
Protocol type.
ProtocolTypes - Interface in org.apache.hadoop.registry.client.types
some common protocol types
PROXY_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The address for the web proxy.
PROXY_KEYTAB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
Keytab for Proxy.
PROXY_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
PROXY_PRINCIPAL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
The kerberos principal for the proxy.
PseudoDelegationTokenAuthenticator - Class in org.apache.hadoop.security.token.delegation.web
The PseudoDelegationTokenAuthenticator provides support for Hadoop's pseudo authentication mechanism that accepts the user name specified as a query string parameter and support for Hadoop Delegation Token operations.
PseudoDelegationTokenAuthenticator() - Constructor for class org.apache.hadoop.security.token.delegation.web.PseudoDelegationTokenAuthenticator
 
publishMetricsNow() - Method in class org.apache.hadoop.metrics2.MetricsSystem
Requests an immediate publish of all metrics from sources to sinks.
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
 
putBlocker(String, String) - Method in class org.apache.hadoop.service.AbstractService
Put a blocker to the blocker map -replacing any with the same name.
putBuffer(ByteBuffer) - Method in interface org.apache.hadoop.io.ByteBufferPool
Release a buffer back to the pool.
putBuffer(ByteBuffer) - Method in class org.apache.hadoop.io.ElasticByteBufferPool
 
putDomain(TimelineDomain) - Method in class org.apache.hadoop.yarn.client.api.TimelineClient
Send the information of a domain to the timeline server.
putEntities(TimelineEntity...) - Method in class org.apache.hadoop.yarn.client.api.TimelineClient
Send the information of a number of conceptual entities to the timeline server.
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
 
putMetrics(MetricsRecord) - Method in class org.apache.hadoop.metrics2.sink.GraphiteSink
 

Q

quantiles - Static variable in class org.apache.hadoop.metrics2.lib.MutableQuantiles
 
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 - Class in org.apache.hadoop.yarn.api.records
QueueInfo is a report of the runtime information of the queue.
QueueInfo() - Constructor for class org.apache.hadoop.yarn.api.records.QueueInfo
 
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 - Class in org.apache.hadoop.yarn.api.records
QueueUserACLInfo provides information QueueACL for the given user.
QueueUserACLInfo() - Constructor for class org.apache.hadoop.yarn.api.records.QueueUserACLInfo
 

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.
rawBytesDownloaded(long) - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Indicate that we just downloaded some data to Azure storage.
rawBytesUploaded(long) - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
Indicate that we just uploaded some data to Azure storage.
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(ByteBuffer) - Method in class org.apache.hadoop.fs.FSDataInputStream
 
read(ByteBufferPool, int, EnumSet<ReadOption>) - Method in class org.apache.hadoop.fs.FSDataInputStream
 
read(ByteBufferPool, int) - Method in class org.apache.hadoop.fs.FSDataInputStream
 
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.
readAcontainerLogs(DataInputStream, Writer, long) - Static method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogReader
Writes all logs for a single container to the provided writer.
readAcontainerLogs(DataInputStream, Writer) - Static method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogReader
Writes all logs for a single container to the provided writer.
readAContainerLogsForALogType(DataInputStream, PrintStream, long) - Static method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogReader
Keep calling this till you get a EOFException for getting logs of all types for a single container.
readAContainerLogsForALogType(DataInputStream, PrintStream) - Static method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogReader
Keep calling this till you get a EOFException for getting logs of all types for a single container.
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.ContentSummary
 
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
 
readFields(DataInput) - Method in class org.apache.hadoop.io.AbstractMapWritable
 
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
 
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
 
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
 
readFields(DataInput) - Method in class org.apache.hadoop.io.Text
deserialize
readFields(DataInput, int) - Method in class org.apache.hadoop.io.Text
 
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.Counters.Counter
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.Counters.Group
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.FileSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.mapred.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.security.authorize.AccessControlList
Deserializes the AccessControlList object
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
 
readFields(DataInput) - Method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogKey
 
readFields(DataInput) - Method in class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
 
readFields(DataInput) - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
 
readFields(DataInput) - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
 
readFields(DataInput) - Method in class org.apache.hadoop.yarn.security.NMTokenIdentifier
 
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 equal 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.
 
readLink(File) - Static method in class org.apache.hadoop.fs.FileUtil
Returns the target of the given symlink.
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.
ReadOption - Enum in org.apache.hadoop.fs
Options that can be used when reading from a FileSystem.
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, int) - Static method in class org.apache.hadoop.io.Text
Read a UTF8 encoded string with a maximum size
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.
readVIntInRange(DataInput, int, int) - Static method in class org.apache.hadoop.io.WritableUtils
Reads an integer from the input 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.
readWithKnownLength(DataInput, int) - Method in class org.apache.hadoop.io.Text
Read a Text object whose length is already known.
READY - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
 
receivedPing(O) - Method in class org.apache.hadoop.yarn.util.AbstractLivelinessMonitor
 
ReconfigurationTaskStatus - Class in org.apache.hadoop.conf
 
ReconfigurationTaskStatus(long, long, Map<ReconfigurationUtil.PropertyChange, Optional<String>>) - Constructor for class org.apache.hadoop.conf.ReconfigurationTaskStatus
 
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.
 
RECORD_TYPE - Static variable in class org.apache.hadoop.registry.client.types.ServiceRecord
A type string which MUST be in the serialized json.
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
 
recoverFilesWithDanglingTempData(Path, Path) - Method in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
Looks under the given root path for any blob that are left "dangling", meaning that they are place-holder blobs that we created while we upload the data to a temporary blob, but for some reason we crashed in the middle of the upload and left them there.
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.
RECOVERY_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
 
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
register(Class<? extends Enum>, EventHandler) - Method in class org.apache.hadoop.yarn.event.AsyncDispatcher
 
register(Class<? extends Enum>, EventHandler) - Method in interface org.apache.hadoop.yarn.event.Dispatcher
 
register(O) - Method in class org.apache.hadoop.yarn.util.AbstractLivelinessMonitor
 
registerApplicationMaster(RegisterApplicationMasterRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationMasterProtocol
The interface used by a new ApplicationMaster to register with the ResourceManager.
registerApplicationMaster(String, int, String) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
Register the application master.
registerApplicationMaster(String, int, String) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
Registers this application master with the resource manager.
RegisterApplicationMasterRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request sent by the ApplicationMaster to ResourceManager on registration.
RegisterApplicationMasterRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
 
RegisterApplicationMasterResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response sent by the ResourceManager to a new ApplicationMaster on registration.
RegisterApplicationMasterResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
 
registerGlobalListener(ServiceStateChangeListener) - Static method in class org.apache.hadoop.service.AbstractService
Register a global listener, which receives notifications from the state change events of all services in the JVM
registerServiceListener(ServiceStateChangeListener) - Method in class org.apache.hadoop.service.AbstractService
 
registerServiceListener(ServiceStateChangeListener) - Method in interface org.apache.hadoop.service.Service
Register a listener to the service state change events.
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
 
REGISTRY_CLIENT_AUTH_ANONYMOUS - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
No authentication; client is anonymous
REGISTRY_CLIENT_AUTH_DIGEST - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Username/password is the authentication mechanism.
REGISTRY_CLIENT_AUTH_KERBEROS - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
Registry client uses Kerberos: authentication is automatic from logged in user
REGISTRY_PREFIX - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
prefix for registry configuration options: "hadoop.registry.".
RegistryBindingSource - Interface in org.apache.hadoop.registry.client.impl.zk
Interface which can be implemented by a registry binding source
RegistryConstants - Interface in org.apache.hadoop.registry.client.api
Constants for the registry, including configuration keys and default values.
RegistryIOException - Exception in org.apache.hadoop.registry.client.exceptions
Base exception for registry operations.
RegistryIOException(String, PathIOException) - Constructor for exception org.apache.hadoop.registry.client.exceptions.RegistryIOException
Build an exception from any other Path IO Exception.
RegistryIOException(String, Throwable) - Constructor for exception org.apache.hadoop.registry.client.exceptions.RegistryIOException
 
RegistryIOException(String, String) - Constructor for exception org.apache.hadoop.registry.client.exceptions.RegistryIOException
 
RegistryIOException(String, String, Throwable) - Constructor for exception org.apache.hadoop.registry.client.exceptions.RegistryIOException
 
RegistryOperations - Interface in org.apache.hadoop.registry.client.api
Registry Operations
RegistryOperationsClient - Class in org.apache.hadoop.registry.client.impl
This is the client service for applications to work with the registry.
RegistryOperationsClient(String) - Constructor for class org.apache.hadoop.registry.client.impl.RegistryOperationsClient
 
RegistryOperationsClient(String, RegistryBindingSource) - Constructor for class org.apache.hadoop.registry.client.impl.RegistryOperationsClient
 
RegistryOperationsService - Class in org.apache.hadoop.registry.client.impl.zk
The Registry operations service.
RegistryOperationsService(String) - Constructor for class org.apache.hadoop.registry.client.impl.zk.RegistryOperationsService
 
RegistryOperationsService() - Constructor for class org.apache.hadoop.registry.client.impl.zk.RegistryOperationsService
 
RegistryOperationsService(String, RegistryBindingSource) - Constructor for class org.apache.hadoop.registry.client.impl.zk.RegistryOperationsService
 
RegistryPathStatus - Class in org.apache.hadoop.registry.client.types
Output of a RegistryOperations.stat() call
RegistryPathStatus(String, long, long, int) - Constructor for class org.apache.hadoop.registry.client.types.RegistryPathStatus
Construct an instance
RegistryTypeUtils - Class in org.apache.hadoop.registry.client.binding
Static methods to work with registry types —primarily endpoints and the list representation of addresses.
RegistryTypeUtils() - Constructor for class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
 
RegistryUtils - Class in org.apache.hadoop.registry.client.binding
Utility methods for working with a registry.
RegistryUtils() - Constructor for class org.apache.hadoop.registry.client.binding.RegistryUtils
 
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(ReleaseSharedCacheResourceRequest) - Method in interface org.apache.hadoop.yarn.api.ClientSCMProtocol
The interface used by clients to release a resource with the SharedCacheManager. This method is called once an application is no longer using a claimed resource in the shared cache.
release(ApplicationId, String) - Method in class org.apache.hadoop.yarn.client.api.SharedCacheClient
The method to release a resource with the SharedCacheManager. This method is called once an application is no longer using a claimed resource in the shared cache.
releaseAssignedContainer(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
Release containers assigned by the Resource Manager.
releaseAssignedContainer(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
Release containers assigned by the Resource Manager.
releaseBuffer(ByteBuffer) - Method in class org.apache.hadoop.fs.FSDataInputStream
 
ReleaseSharedCacheResourceRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
The request from clients to release a resource in the shared cache.
ReleaseSharedCacheResourceRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.ReleaseSharedCacheResourceRequest
 
ReleaseSharedCacheResourceResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
The response to clients from the SharedCacheManager when releasing a resource in the shared cache.
ReleaseSharedCacheResourceResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.ReleaseSharedCacheResourceResponse
 
reloadCachedMappings() - Method in class org.apache.hadoop.net.CachedDNSToSwitchMapping
 
reloadCachedMappings(List<String>) - Method in class org.apache.hadoop.net.CachedDNSToSwitchMapping
 
reloadCachedMappings() - Method in interface org.apache.hadoop.net.DNSToSwitchMapping
Reload all of the cached mappings.
reloadCachedMappings(List<String>) - Method in interface org.apache.hadoop.net.DNSToSwitchMapping
Reload cached mappings on specific nodes.
reloadCachedMappings() - Method in class org.apache.hadoop.net.TableMapping
 
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
removeAcl(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Removes all but the base ACL entries of files and directories.
removeAcl(Path) - Method in class org.apache.hadoop.fs.FileContext
Removes all but the base ACL entries of files and directories.
removeAcl(Path) - Method in class org.apache.hadoop.fs.FileSystem
Removes all but the base ACL entries of files and directories.
removeAcl(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
removeAcl(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
removeAcl(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
removeAclEntries(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Removes ACL entries from files and directories.
removeAclEntries(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.FileContext
Removes ACL entries from files and directories.
removeAclEntries(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.FileSystem
Removes ACL entries from files and directories.
removeAclEntries(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
removeAclEntries(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
removeAclEntries(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
removeBlocker(String) - Method in class org.apache.hadoop.service.AbstractService
Remove a blocker from the blocker map - this is a no-op if the blocker is not present
removeContainerRequest(T) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
Remove previous container request.
removeContainerRequest(T) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
Remove previous container request.
removeDefaultAcl(Path) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Removes all default ACL entries from files and directories.
removeDefaultAcl(Path) - Method in class org.apache.hadoop.fs.FileContext
Removes all default ACL entries from files and directories.
removeDefaultAcl(Path) - Method in class org.apache.hadoop.fs.FileSystem
Removes all default ACL entries from files and directories.
removeDefaultAcl(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
removeDefaultAcl(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
removeDefaultAcl(Path) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
removeGroup(String) - Method in class org.apache.hadoop.security.authorize.AccessControlList
Remove group from the names of groups allowed for this service.
removeMBeanName(ObjectName) - Static method in enum org.apache.hadoop.metrics2.lib.DefaultMetricsSystem
 
RemoveScheme - Interface in org.apache.hadoop.util.bloom
Defines the different remove scheme for retouched Bloom filters.
removeService(Service) - Method in class org.apache.hadoop.registry.server.services.AddingCompositeService
 
removeService(Service) - Method in class org.apache.hadoop.service.CompositeService
 
removeSpanReceiver(long) - Method in interface org.apache.hadoop.tracing.TraceAdminProtocol
Remove a trace span receiver.
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.
removeToken(String) - Method in class org.apache.hadoop.yarn.client.api.NMTokenCache
Removes NMToken for specified node manager
removeUser(String) - Method in class org.apache.hadoop.security.authorize.AccessControlList
Remove user from the names of users allowed for this service.
removeXAttr(Path, String) - Method in class org.apache.hadoop.fs.AbstractFileSystem
Remove an xattr of a file or directory.
removeXAttr(Path, String) - Method in class org.apache.hadoop.fs.FileContext
Remove an xattr of a file or directory.
removeXAttr(Path, String) - Method in class org.apache.hadoop.fs.FileSystem
Remove an xattr of a file or directory.
removeXAttr(Path, String) - Method in class org.apache.hadoop.fs.FilterFileSystem
 
removeXAttr(Path, String) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
 
removeXAttr(Path, String) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
 
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.azure.NativeAzureFileSystem
 
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.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
     
    renameSnapshot(Path, String, String) - Method in class org.apache.hadoop.fs.FileSystem
    Rename a snapshot
    renameSnapshot(Path, String, String) - Method in class org.apache.hadoop.fs.FilterFileSystem
     
    RENEW_DELEGATION_TOKEN_JSON - Static variable in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
     
    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(URL, DelegationTokenAuthenticatedURL.Token) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
    Renews a delegation token from the server end-point using the configured Authenticator for authentication.
    renewDelegationToken(URL, DelegationTokenAuthenticatedURL.Token, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
    Renews a delegation token from the server end-point using the configured Authenticator for authentication.
    renewDelegationToken(URL, AuthenticatedURL.Token, Token<AbstractDelegationTokenIdentifier>) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
    Renews a delegation token from the server end-point using the configured Authenticator for authentication.
    renewDelegationToken(URL, AuthenticatedURL.Token, Token<AbstractDelegationTokenIdentifier>, String) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
    Renews a delegation token from the server end-point using the configured Authenticator for authentication.
    renewDelegationToken(Token<TimelineDelegationTokenIdentifier>) - Method in class org.apache.hadoop.yarn.client.api.TimelineClient
    Renew a timeline 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.
    RenewDelegationTokenResponse - Interface in org.apache.hadoop.mapreduce.v2.api.protocolrecords
    The response to a renewDelegationToken call to the ResourceManager.
    RENEWER_PARAM - Static variable in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
     
    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.
    requireAddressType(String, Endpoint) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
    Require a specific address type on an endpoint
    requiresLayout() - Method in class org.apache.hadoop.log.metrics.EventCounter
     
    ReservationDefinition - Class in org.apache.hadoop.yarn.api.records
    ReservationDefinition captures the set of resource and time constraints the user cares about regarding a reservation.
    ReservationDefinition() - Constructor for class org.apache.hadoop.yarn.api.records.ReservationDefinition
     
    ReservationDeleteRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
    ReservationDeleteRequest captures the set of requirements the user has to delete an existing reservation.
    ReservationDeleteRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.ReservationDeleteRequest
     
    ReservationDeleteResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
    ReservationDeleteResponse contains the answer of the admission control system in the ResourceManager to a reservation delete operation.
    ReservationDeleteResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.ReservationDeleteResponse
     
    ReservationId - Class in org.apache.hadoop.yarn.api.records
    ReservationId represents the globally unique identifier for a reservation.
    ReservationId() - Constructor for class org.apache.hadoop.yarn.api.records.ReservationId
     
    ReservationRequest - Class in org.apache.hadoop.yarn.api.records
    ReservationRequest represents the request made by an application to the ResourceManager to reserve Resources.
    ReservationRequest() - Constructor for class org.apache.hadoop.yarn.api.records.ReservationRequest
     
    ReservationRequest.ReservationRequestComparator - Class in org.apache.hadoop.yarn.api.records
     
    ReservationRequest.ReservationRequestComparator() - Constructor for class org.apache.hadoop.yarn.api.records.ReservationRequest.ReservationRequestComparator
     
    ReservationRequestInterpreter - Enum in org.apache.hadoop.yarn.api.records
    Enumeration of various types of dependencies among multiple ReservationRequests within one ReservationDefinition (from least constraining to most constraining).
    ReservationRequests - Class in org.apache.hadoop.yarn.api.records
    ReservationRequests captures the set of resource and constraints the user cares about regarding a reservation.
    ReservationRequests() - Constructor for class org.apache.hadoop.yarn.api.records.ReservationRequests
     
    ReservationSubmissionRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
    ReservationSubmissionRequest captures the set of requirements the user has to create a reservation.
    ReservationSubmissionRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.ReservationSubmissionRequest
     
    ReservationSubmissionResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
    ReservationSubmissionResponse contains the answer of the admission control system in the ResourceManager to a reservation create operation.
    ReservationSubmissionResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.ReservationSubmissionResponse
     
    ReservationUpdateRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
    ReservationUpdateRequest captures the set of requirements the user has to update an existing reservation.
    ReservationUpdateRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.ReservationUpdateRequest
     
    ReservationUpdateResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
    ReservationUpdateResponse contains the answer of the admission control system in the ResourceManager to a reservation update operation.
    ReservationUpdateResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.ReservationUpdateResponse
     
    reserveIdStrPrefix - Static variable in class org.apache.hadoop.yarn.api.records.ReservationId
     
    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
     
    resetTimer() - Method in class org.apache.hadoop.yarn.util.AbstractLivelinessMonitor
     
    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).
    resolve(String) - Method in interface org.apache.hadoop.registry.client.api.RegistryOperations
    Resolve the record at a path
    resolve(String) - Method in class org.apache.hadoop.registry.client.impl.zk.RegistryOperationsService
     
    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.
    resolveLink(Path) - Method in class org.apache.hadoop.fs.FileSystem
    resolveLink(Path) - Method in class org.apache.hadoop.fs.FilterFileSystem
     
    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
     
    ResourceBlacklistRequest - Class in org.apache.hadoop.yarn.api.records
    ResourceBlacklistRequest encapsulates the list of resource-names which should be added or removed from the blacklist of resources for the application.
    ResourceBlacklistRequest() - Constructor for class org.apache.hadoop.yarn.api.records.ResourceBlacklistRequest
     
    ResourceCalculatorProcessTree - Class in org.apache.hadoop.yarn.util
    Interface class to obtain process resource usage NOTE: This class should not be used by external users, but only by external developers to extend and include their own process-tree implementation, especially for platforms other than Linux and Windows.
    ResourceCalculatorProcessTree(String) - Constructor for class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
    Create process-tree instance with specified root process.
    RESOURCEMANAGER_CONNECT_MAX_WAIT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Max time to wait to establish a connection to RM
    RESOURCEMANAGER_CONNECT_RETRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Time interval between each attempt to connect to RM
    ResourceOption - Class in org.apache.hadoop.yarn.api.records
     
    ResourceOption() - Constructor for class org.apache.hadoop.yarn.api.records.ResourceOption
     
    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
     
    ResourceRequest.ResourceRequestComparator - Class in org.apache.hadoop.yarn.api.records
     
    ResourceRequest.ResourceRequestComparator() - Constructor for class org.apache.hadoop.yarn.api.records.ResourceRequest.ResourceRequestComparator
     
    restEndpoint(String, URI...) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
    Create a REST endpoint from a list of URIs
    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
    retrieveAddressesUriType(Endpoint) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
    Get a single URI endpoint
    retrieveAddressURLs(Endpoint) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
    Get the address URLs.
    retrievePassword(ClientToAMTokenIdentifier) - Method in class org.apache.hadoop.yarn.security.client.BaseClientToAMTokenSecretManager
     
    retrievePassword(ClientToAMTokenIdentifier) - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenSecretManager
     
    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.
     
    RM_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The address of the applications manager interface in the RM.
    RM_ADMIN_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The address of the RM admin interface.
    RM_ADMIN_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Number of threads used to handle RM admin interface.
    RM_AM_EXPIRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The expiry interval for application master reporting.
    RM_AM_MAX_ATTEMPTS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The maximum number of application attempts.
    RM_AMLAUNCHER_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Number of threads used to launch/cleanup AM.
    RM_AMRM_TOKEN_MASTER_KEY_ROLLING_INTERVAL_SECS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_BIND_HOST - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The actual bind address for the RM.
    RM_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The number of threads used to handle applications manager requests.
    RM_CLUSTER_ID - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_CONFIGURATION_FILES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_CONFIGURATION_PROVIDER_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_CONTAINER_ALLOC_EXPIRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    How long to wait until a container is considered dead.
    RM_CONTAINER_TOKEN_MASTER_KEY_ROLLING_INTERVAL_SECS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_DELAYED_DELEGATION_TOKEN_REMOVAL_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Interval at which the delayed token removal thread runs
    RM_DELEGATION_KEY_UPDATE_INTERVAL_DEFAULT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_DELEGATION_KEY_UPDATE_INTERVAL_KEY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_DELEGATION_TOKEN_MAX_LIFETIME_DEFAULT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_DELEGATION_TOKEN_MAX_LIFETIME_KEY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_DELEGATION_TOKEN_RENEW_INTERVAL_DEFAULT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_DELEGATION_TOKEN_RENEW_INTERVAL_KEY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_DELEGATION_TOKEN_RENEWER_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Delegation Token renewer thread count
    RM_HA_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_HA_ID - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_HA_IDS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_HA_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    HA related configs
    RM_HISTORY_WRITER_MULTI_THREADED_DISPATCHER_POOL_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Number of worker threads that write the history data.
    RM_HOSTNAME - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_KEYTAB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The keytab for the resource manager.
    RM_LEVELDB_STORE_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_MAX_COMPLETED_APPLICATIONS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The maximum number of completed applications RM keeps.
    RM_METRICS_RUNTIME_BUCKETS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Buckets (in minutes) for the number of apps running in each queue.
    RM_NM_EXPIRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    How long to wait until a node manager is considered dead.
    RM_NM_HEARTBEAT_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    RM set next Heartbeat interval for NM
    RM_NMTOKEN_MASTER_KEY_ROLLING_INTERVAL_SECS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_NODEMANAGER_CONNECT_RETIRES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Retry times to connect with NM.
    RM_NODEMANAGER_MINIMUM_VERSION - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_NODES_EXCLUDE_FILE_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Path to file with nodes to exclude.
    RM_NODES_INCLUDE_FILE_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Path to file with nodes to include.
    RM_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_PRINCIPAL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The Kerberos principal for the resource manager.
    RM_PROXY_USER_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    RM proxy users' prefix
    RM_PROXY_USER_PRIVILEGES_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_RESERVATION_SYSTEM_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The class to use as the Reservation System.
    RM_RESERVATION_SYSTEM_ENABLE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Whether the RM should enable Reservation System
    RM_RESERVATION_SYSTEM_PLAN_FOLLOWER - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The PlanFollower for the Reservation System.
    RM_RESERVATION_SYSTEM_PLAN_FOLLOWER_TIME_STEP - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The step size of the Reservation System.
    RM_RESOURCE_TRACKER_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_RESOURCE_TRACKER_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Number of threads to handle resource tracker calls.
    RM_SCHEDULER - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The class to use as the resource scheduler.
    RM_SCHEDULER_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The address of the scheduler interface.
    RM_SCHEDULER_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Number of threads to handle scheduler interface.
    RM_SCHEDULER_ENABLE_MONITORS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Enable periodic monitor threads.
    RM_SCHEDULER_INCLUDE_PORT_IN_NODE_NAME - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    If the port should be included or not in the node name.
    RM_SCHEDULER_MAXIMUM_ALLOCATION_MB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Maximum request grant-able by the RM scheduler.
    RM_SCHEDULER_MAXIMUM_ALLOCATION_VCORES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_SCHEDULER_MINIMUM_ALLOCATION_MB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Miniumum request grant-able by the RM scheduler.
    RM_SCHEDULER_MINIMUM_ALLOCATION_VCORES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_SCHEDULER_MONITOR_POLICIES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    List of SchedulingEditPolicy classes affecting the scheduler.
    RM_STATE_STORE_MAX_COMPLETED_APPLICATIONS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The maximum number of completed applications RM state store keeps, by default equals to DEFAULT_RM_MAX_COMPLETED_APPLICATIONS
    RM_STORE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The class to use as the persistent store.
    RM_SYSTEM_METRICS_PUBLISHER_DISPATCHER_POOL_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_SYSTEM_METRICS_PUBLISHER_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The setting that controls whether yarn system metrics is published on the timeline server or not by RM.
    RM_WEBAPP_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The address of the RM web application.
    RM_WEBAPP_DELEGATION_TOKEN_AUTH_FILTER - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Flag to enable override of the default kerberos authentication filter with the RM authentication filter to allow authentication using delegation tokens(fallback to kerberos if the tokens are missing).
    RM_WEBAPP_HTTPS_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The https address of the RM web application.
    RM_WEBAPP_SPNEGO_KEYTAB_FILE_KEY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The kerberos keytab to be used for spnego filter for RM.
    RM_WEBAPP_SPNEGO_USER_NAME_KEY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The kerberos principal to be used for spnego filter for RM.
    RM_WEBAPP_UI_ACTIONS_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Enable Resource Manager webapp ui actions
    RM_WORK_PRESERVING_RECOVERY_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_WORK_PRESERVING_RECOVERY_SCHEDULING_WAIT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_ZK_ACL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_ZK_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_ZK_AUTH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_ZK_NUM_RETRIES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_ZK_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Zookeeper interaction configs
    RM_ZK_RETRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    RM_ZK_TIMEOUT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    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
    RMDelegationTokenSelector - Class in org.apache.hadoop.yarn.security.client
     
    RMDelegationTokenSelector() - Constructor for class org.apache.hadoop.yarn.security.client.RMDelegationTokenSelector
     
    RMProxy<T> - Class in org.apache.hadoop.yarn.client
     
    RMProxy() - Constructor for class org.apache.hadoop.yarn.client.RMProxy
     
    rollNewVersion(String, byte[]) - Method in class org.apache.hadoop.crypto.key.KeyProvider
    Roll a new version of the given key.
    rollNewVersion(String) - Method in class org.apache.hadoop.crypto.key.KeyProvider
    Roll a new version of the given key generating the material for it.
    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.azure.WasbFsck
     
    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 class org.apache.hadoop.tools.DistCp
    Implementation of Tool::run().
    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
    run(String[]) - Method in class org.apache.hadoop.yarn.client.cli.LogsCLI
     
    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
     
    scanDirectory(Path, FileContext, PathFilter) - Static method in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
     
    scanDirectoryForHistoryFiles(Path, FileContext) - Method in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
     
    SchedulerSecurityInfo - Class in org.apache.hadoop.yarn.security
     
    SchedulerSecurityInfo() - Constructor for class org.apache.hadoop.yarn.security.SchedulerSecurityInfo
     
    SCM_ADMIN_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The address of the SCM admin interface.
    SCM_ADMIN_CLIENT_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Number of threads used to handle SCM admin interface.
    SCM_APP_CHECKER_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    SCM_CLEANER_INITIAL_DELAY_MINS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Initial delay before the first cleaner task is scheduled.
    SCM_CLEANER_PERIOD_MINS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The frequency at which a cleaner task runs.
    SCM_CLEANER_RESOURCE_SLEEP_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The time to sleep between processing each shared cache resource.
    SCM_CLIENT_SERVER_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The address of the client interface in the SCM.
    SCM_CLIENT_SERVER_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The number of threads used to handle shared cache manager requests.
    SCM_STORE_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    SCM_STORE_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    SCM_UPLOADER_SERVER_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The address of the node manager interface in the SCM.
    SCM_UPLOADER_SERVER_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The number of SCM threads used to handle notify requests from the node manager.
    SCM_WEBAPP_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The address of the SCM web application.
    SCRIPT_PATH - Static variable in class org.apache.hadoop.yarn.applications.distributedshell.Client
     
    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(DNSToSwitchMapping) - Constructor for class org.apache.hadoop.net.ScriptBasedMapping
    Create an instance from the given raw mapping
    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.
    selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - Method in class org.apache.hadoop.yarn.security.AMRMTokenSelector
     
    selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - Method in class org.apache.hadoop.yarn.security.client.RMDelegationTokenSelector
     
    selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - Method in class org.apache.hadoop.yarn.security.client.TimelineDelegationTokenSelector
     
    selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - Method in class org.apache.hadoop.yarn.security.ContainerTokenSelector
     
    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
    serverErrorEncountered() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
    Indicate that we just encountered a server-caused error.
    ServerProxy - Class in org.apache.hadoop.yarn.client
     
    ServerProxy() - Constructor for class org.apache.hadoop.yarn.client.ServerProxy
     
    Servers - Class in org.apache.hadoop.metrics2.util
    Helpers to handle server addresses
    Service - Interface in org.apache.hadoop.service
    Service LifeCycle.
    serviceclassPath(String, String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
    Create a service classpath
    ServiceFailedException - Exception in org.apache.hadoop.ha
    Exception thrown to indicate that an operation performed to modify the state of a service or application failed.
    ServiceFailedException(String) - Constructor for exception org.apache.hadoop.ha.ServiceFailedException
     
    ServiceFailedException(String, Throwable) - Constructor for exception org.apache.hadoop.ha.ServiceFailedException
     
    serviceInit(Configuration) - Method in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
     
    serviceInit(Configuration) - Method in class org.apache.hadoop.service.AbstractService
    All initialization code needed by a service.
    serviceInit(Configuration) - Method in class org.apache.hadoop.service.CompositeService
     
    serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.event.AsyncDispatcher
     
    ServiceOperations - Class in org.apache.hadoop.service
    This class contains a set of methods to work with services, especially to walk them through their lifecycle.
    servicePath(String, String, String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
    Create a path to a service under a user and service class
    ServiceRecord - Class in org.apache.hadoop.registry.client.types
    JSON-marshallable description of a single component.
    ServiceRecord() - Constructor for class org.apache.hadoop.registry.client.types.ServiceRecord
    Create a service record with no ID, description or registration time.
    ServiceRecord(ServiceRecord) - Constructor for class org.apache.hadoop.registry.client.types.ServiceRecord
    Deep cloning constructor
    serviceStart() - Method in class org.apache.hadoop.service.AbstractService
    Actions called during the INITED to STARTED transition.
    serviceStart() - Method in class org.apache.hadoop.service.CompositeService
     
    serviceStart() - Method in class org.apache.hadoop.yarn.event.AsyncDispatcher
     
    serviceStart() - Method in class org.apache.hadoop.yarn.util.AbstractLivelinessMonitor
     
    ServiceStateChangeListener - Interface in org.apache.hadoop.service
    Interface to notify state changes of a service.
    ServiceStateException - Exception in org.apache.hadoop.service
    Exception that is raised on state change operations.
    ServiceStateException(String) - Constructor for exception org.apache.hadoop.service.ServiceStateException
     
    ServiceStateException(String, Throwable) - Constructor for exception org.apache.hadoop.service.ServiceStateException
     
    ServiceStateException(Throwable) - Constructor for exception org.apache.hadoop.service.ServiceStateException
     
    ServiceStateModel - Class in org.apache.hadoop.service
    Implements the service state model.
    ServiceStateModel(String) - Constructor for class org.apache.hadoop.service.ServiceStateModel
    Create the service state model in the Service.STATE.NOTINITED state.
    ServiceStateModel(String, Service.STATE) - Constructor for class org.apache.hadoop.service.ServiceStateModel
    Create a service state model instance in the chosen state
    serviceStop() - Method in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
     
    serviceStop() - Method in class org.apache.hadoop.service.AbstractService
    Actions called during the transition to the STOPPED state.
    serviceStop() - Method in class org.apache.hadoop.service.CompositeService
     
    serviceStop() - Method in class org.apache.hadoop.yarn.event.AsyncDispatcher
     
    serviceStop() - Method in class org.apache.hadoop.yarn.util.AbstractLivelinessMonitor
     
    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.
    set(String, Object) - Method in class org.apache.hadoop.registry.client.types.ServiceRecord
    Handle unknown attributes by storing them in the ServiceRecord.attributes map
    setAccessibleNodeLabels(Set<String>) - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
    Set the accessible node labels of the queue.
    setAccountName(String) - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
    Sets the account name to tag all the metrics with.
    setAcl(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.AbstractFileSystem
    Fully replaces ACL of files and directories, discarding all existing entries.
    setAcl(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.FileContext
    Fully replaces ACL of files and directories, discarding all existing entries.
    setAcl(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.FileSystem
    Fully replaces ACL of files and directories, discarding all existing entries.
    setAcl(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.FilterFileSystem
     
    setAcl(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    setAcl(Path, List<AclEntry>) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    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 class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
    Set the list of newly allocated Container by the ResourceManager.
    setAllocatedResource(Resource) - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
     
    setAllowNullValueProperties(boolean) - Method in class org.apache.hadoop.conf.Configuration
    Set Configuration to allow keys without values during setup.
    setAllServicesMetaData(Map<String, ByteBuffer>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainersResponse
    Set to the list of auxiliary services which have been started on the NodeManager.
    setAMCommand(AMCommand) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
     
    setAMContainerId(ContainerId) - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
     
    setAMContainerResourceRequest(ResourceRequest) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set ResourceRequest of AM container
    setAMContainerSpec(ContainerLaunchContext) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the ContainerLaunchContext to describe the Container with which the ApplicationMaster is launched.
    setAMRMToken(Token) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
     
    setAMRMToken(Token) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setAppId(ApplicationId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReleaseSharedCacheResourceRequest
    Set the ApplicationId of the resource to be released.
    setAppId(ApplicationId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.UseSharedCacheResourceRequest
    Set the ApplicationId of the resource to be used.
    setApplicationACLs(Map<ApplicationAccessType, String>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
    Set the ApplicationACLs for the application.
    setApplicationACLs(Map<ApplicationAccessType, String>) - Method in class org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Set the ApplicationACLs for the application.
    setApplicationAttemptId(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptReportRequest
    Set the ApplicationAttemptId of an application attempt
    setApplicationAttemptId(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainersRequest
    Set the ApplicationAttemptId of an application attempt
    setApplicationAttemptId(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
     
    setApplicationAttemptId(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.api.records.ContainerId
     
    setApplicationAttemptList(List<ApplicationAttemptReport>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptsResponse
    Get a list of ApplicationReport of an application.
    setApplicationAttemptReport(ApplicationAttemptReport) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptReportResponse
    Get the ApplicationAttemptReport for the application attempt.
    setApplicationId(ApplicationId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptsRequest
    Set the ApplicationId of an application
    setApplicationId(ApplicationId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportRequest
    Set the ApplicationId of the application
    setApplicationId(ApplicationId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse
     
    setApplicationId(ApplicationId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.KillApplicationRequest
     
    setApplicationId(ApplicationId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.MoveApplicationAcrossQueuesRequest
    Set the ApplicationId of the application to be moved.
    setApplicationId(ApplicationId) - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptId
     
    setApplicationId(ApplicationId) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setApplicationId(ApplicationId) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the ApplicationId of the submitted application.
    setApplicationList(List<ApplicationReport>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsResponse
     
    setApplicationName(String) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the application name.
    setApplicationReport(ApplicationReport) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportResponse
     
    setApplicationResourceUsageReport(ApplicationResourceUsageReport) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
    Store the structure containing the job resources for this application
    setApplications(List<ApplicationReport>) - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
     
    setApplicationStates(EnumSet<YarnApplicationState>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
    Set the application states to filter applications on
    setApplicationStates(Set<String>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
    Set the application states to filter applications on
    setApplicationSubmissionContext(ApplicationSubmissionContext) - Method in class org.apache.hadoop.yarn.api.protocolrecords.SubmitApplicationRequest
    Set the ApplicationSubmissionContext for the application.
    setApplicationTags(Set<String>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
    Set the list of tags to filter applications on
    setApplicationTags(Set<String>) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setApplicationTags(Set<String>) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set tags for the application.
    setApplicationType(String) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setApplicationType(String) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the application type
    setApplicationTypes(Set<String>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
    Set the application types to filter applications on
    setArchiveTimestamps(Configuration, String) - Static method in class org.apache.hadoop.filecache.DistributedCache
    Deprecated.
    setArrival(long) - Method in class org.apache.hadoop.yarn.api.records.ReservationDefinition
    Set the arrival time or the earliest time from which the resource(s) can be allocated.
    setAskList(List<ResourceRequest>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
    Set list of ResourceRequest to update the ResourceManager about the application's resource requirements.
    setAssignedJobID(JobID) - Method in class org.apache.hadoop.mapred.jobcontrol.Job
    Deprecated.
    setAssignedJobID should not be called. JOBID is set by the framework.
    setAssignedNode(NodeId) - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
     
    setAttemptFailuresValidityInterval(long) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the attemptFailuresValidityInterval in milliseconds for the application
    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 class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
     
    setBlacklistAdditions(List<String>) - Method in class org.apache.hadoop.yarn.api.records.ResourceBlacklistRequest
    Set list of resource-names which should be added to the application blacklist.
    setBlacklistRemovals(List<String>) - Method in class org.apache.hadoop.yarn.api.records.ResourceBlacklistRequest
    Set list of resource-names which should be removed from the application blacklist.
    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
    setCachedHosts(String[]) - Method in class org.apache.hadoop.fs.BlockLocation
    Set the hosts hosting a cached replica of this block
    setCacheFiles(URI[]) - Method in class org.apache.hadoop.mapreduce.Job
    Set the given set of files
    setCallbackHandler(NMClientAsync.CallbackHandler) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
     
    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 class 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 class org.apache.hadoop.yarn.api.records.ContainerResourceIncreaseRequest
     
    setCapability(Resource) - Method in class org.apache.hadoop.yarn.api.records.NodeReport
     
    setCapability(Resource) - Method in class org.apache.hadoop.yarn.api.records.ReservationRequest
    Set the Resource capability of the request
    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 class 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 class 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
    setClient(NMClient) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
     
    setClientToAMToken(Token) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setClientToAMTokenMasterKey(ByteBuffer) - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
    Set ClientToAMToken master key.
    setClusterMetrics(YarnClusterMetrics) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterMetricsResponse
     
    setClusterTimestamp(long) - Method in class org.apache.hadoop.yarn.api.records.ApplicationId
     
    setClusterTimestamp(long) - Method in class org.apache.hadoop.yarn.api.records.ReservationId
     
    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.
    setCombinerKeyGroupingComparator(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the user defined RawComparator comparator for grouping keys in the input to the combiner.
    setCombinerKeyGroupingComparatorClass(Class<? extends RawComparator>) - Method in class org.apache.hadoop.mapreduce.Job
    Define the comparator that controls which keys are grouped together for a single call to combiner, Reducer.reduce(Object, Iterable, org.apache.hadoop.mapreduce.Reducer.Context)
    setCommands(List<String>) - Method in class org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Add the list of commands for launching the container.
    setCompletedContainersStatuses(List<ContainerStatus>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
     
    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.
    setConcurrency(int) - Method in class org.apache.hadoop.yarn.api.records.ReservationRequest
    Set the number of containers that need to be scheduled concurrently.
    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
     
    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.io.WritableComparator
     
    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.mapred.join.WrappedRecordReader
     
    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(Configuration) - Method in class org.apache.hadoop.net.TableMapping
     
    setConf(Configuration) - Method in class org.apache.hadoop.security.authorize.DefaultImpersonationProvider
     
    setConf(Object, Configuration) - Static method in class org.apache.hadoop.util.ReflectionUtils
    Check and set 'configuration' if necessary.
    setConfig(Configuration) - Method in class org.apache.hadoop.service.AbstractService
    Set the configuration for this service.
    setConnectionConfigurator(ConnectionConfigurator) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
     
    setContainerExitStatus(int) - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
     
    setContainerId(ContainerId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerReportRequest
    Set the ContainerId of the container
    setContainerId(long) - Method in class org.apache.hadoop.yarn.api.records.ContainerId
     
    setContainerId(ContainerId) - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
     
    setContainerId(ContainerId) - Method in class org.apache.hadoop.yarn.api.records.ContainerResourceIncreaseRequest
     
    setContainerId(ContainerId) - Method in class org.apache.hadoop.yarn.api.records.ContainerStatus
     
    setContainerIds(List<ContainerId>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusesRequest
    Set a list of ContainerIds of containers for which to obtain the ContainerStatus
    setContainerIds(List<ContainerId>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.StopContainersRequest
    Set the ContainerIds of the containers to be stopped.
    setContainerLaunchContext(ContainerLaunchContext) - Method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainerRequest
    Set the ContainerLaunchContext for the container to be started by the NodeManager
    setContainerList(List<ContainerReport>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainersResponse
    Set a list of ContainerReport for all the containers of an application attempt.
    setContainerLogDir(String) - Method in class org.apache.hadoop.yarn.ContainerLogAppender
     
    setContainerLogDir(String) - Method in class org.apache.hadoop.yarn.ContainerRollingLogAppender
     
    setContainerLogFile(String) - Method in class org.apache.hadoop.yarn.ContainerLogAppender
     
    setContainerLogFile(String) - Method in class org.apache.hadoop.yarn.ContainerRollingLogAppender
     
    setContainerName(String) - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
    Sets the container name to tag all the metrics with.
    setContainerReport(ContainerReport) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerReportResponse
     
    setContainers(Set<PreemptionContainer>) - Method in class org.apache.hadoop.yarn.api.records.PreemptionContract
     
    setContainers(Set<PreemptionContainer>) - Method in class org.apache.hadoop.yarn.api.records.StrictPreemptionContract
     
    setContainersFromPreviousAttempts(List<Container>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
    Set the list of running containers as viewed by ResourceManager from previous application attempts.
    setContainerState(ContainerState) - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
     
    setContainerStatuses(List<ContainerStatus>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusesResponse
    Set the ContainerStatuses of the requested containers.
    setContainerToken(Token) - Method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainerRequest
     
    setContainerToken(Token) - Method in class org.apache.hadoop.yarn.api.records.Container
     
    setContent(Object) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDelegationTokenResponse
     
    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
    setContract(PreemptionContract) - Method in class org.apache.hadoop.yarn.api.records.PreemptionMessage
     
    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.
    setCreatedTime(Long) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
    Set the created time of the domain
    setCreationTime(long) - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
     
    setCredentials(Credentials) - Method in class org.apache.hadoop.mapred.JobConf
     
    setCurrentApplicationAttemptId(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setCurrentCapacity(float) - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
     
    setDeadline(long) - Method in class org.apache.hadoop.yarn.api.records.ReservationDefinition
    Set the deadline or the latest time by when the resource(s) must be allocated.
    setDebugStream(PrintStream) - Method in class org.apache.hadoop.record.compiler.generated.RccTokenManager
    Deprecated.
     
    setDecreasedContainers(List<ContainerResourceDecrease>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
    Set the list of newly decreased containers by NodeManager
    setDefaultCompressionType(Configuration, SequenceFile.CompressionType) - Static method in class org.apache.hadoop.io.SequenceFile
    Set the default compression type for sequence files.
    setDefaultDelegationTokenAuthenticator(Class<? extends DelegationTokenAuthenticator>) - Static method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
    Sets the default DelegationTokenAuthenticator class to use when an DelegationTokenAuthenticatedURL instance is created without specifying one.
    setDefaultNodeLabelExpression(String) - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
     
    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(Token) - Method in interface org.apache.hadoop.mapreduce.v2.api.protocolrecords.CancelDelegationTokenRequest
     
    setDelegationToken(Token) - Method in interface org.apache.hadoop.mapreduce.v2.api.protocolrecords.RenewDelegationTokenRequest
     
    setDelegationToken(Token<AbstractDelegationTokenIdentifier>) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL.Token
     
    setDeprecatedProperties() - Method in class org.apache.hadoop.conf.Configuration
    Sets all deprecated properties that are not currently set but have a corresponding new property that is set.
    setDescription(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
    Set the domain description
    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 class org.apache.hadoop.yarn.api.protocolrecords.FinishApplicationMasterRequest
    Set diagnostic information on application failure.
    setDiagnostics(String) - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
     
    setDiagnostics(String) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setDiagnostics(String) - Method in class org.apache.hadoop.yarn.api.records.ContainerStatus
     
    setDiagnosticsInfo(String) - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
     
    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 class org.apache.hadoop.mapred.Counters.Counter
     
    setDisplayName(String) - Method in class org.apache.hadoop.mapred.Counters.Group
     
    setDisplayName(String) - Method in interface org.apache.hadoop.mapreduce.Counter
    Deprecated.
    (and no-op by default)
    setDisplayName(String) - Method in interface org.apache.hadoop.mapreduce.counters.CounterGroupBase
    Set the display name of the group
    setDomainId(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
    Set the ID of the domain that the entity is to be put
    setDomains(List<TimelineDomain>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomains
    Set the domain list to the given list of domains
    setDouble(String, double) - Method in class org.apache.hadoop.conf.Configuration
    Set the value of the name property to a double.
    setDrainEventsOnStop() - Method in class org.apache.hadoop.yarn.event.AsyncDispatcher
     
    setDropBehind(Boolean) - Method in interface org.apache.hadoop.fs.CanSetDropBehind
    Configure whether the stream should drop the cache.
    setDropBehind(Boolean) - Method in class org.apache.hadoop.fs.FSDataInputStream
     
    setDropBehind(Boolean) - Method in class org.apache.hadoop.fs.FSDataOutputStream
     
    setDuration(long) - Method in class org.apache.hadoop.yarn.api.records.ReservationRequest
    Set the duration in milliseconds for which the resource is required.
    setEncryptedSpillKey(byte[], Credentials) - Static method in class org.apache.hadoop.mapreduce.security.TokenCache
     
    setEnd(long) - Method in class org.apache.hadoop.io.compress.SplitCompressionInputStream
     
    setEntities(List<TimelineEntity>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntities
    Set the entity list to the given list of entities
    setEntityId(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
    Set the entity Id
    setEntityId(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents.EventsOfOneEntity
    Set the entity Id
    setEntityId(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
    Set the entity Id
    setEntityType(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
    Set the entity type
    setEntityType(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents.EventsOfOneEntity
    Set the entity type
    setEntityType(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
    Set the entity type
    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 class org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Add environment variables for the container.
    setErrorCode(int) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
    Set the error code to the given error code
    setErrors(List<TimelinePutResponse.TimelinePutError>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse
    Set the list to the given list of TimelinePutResponse.TimelinePutError instances
    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.
    setEventInfo(Map<String, Object>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
    Set the information map to the given map of the information of the event
    setEvents(List<TimelineEvent>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
    Set the event list to the given list of events related to the entity
    setEvents(List<TimelineEvent>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents.EventsOfOneEntity
    Set the event list to the given list of events
    setEvents(List<TimelineEvents.EventsOfOneEntity>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents
    Set the list to the given list of TimelineEvents.EventsOfOneEntity instances
    setEventType(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
    Set the event type
    setExcludePattern(String) - Method in class org.apache.hadoop.yarn.api.records.LogAggregationContext
    Set exclude pattern.
    setExecutable(File, boolean) - Static method in class org.apache.hadoop.fs.FileUtil
    Platform independent implementation for File.setExecutable(boolean) File#setExecutable does not work as expected on Windows.
    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 class org.apache.hadoop.yarn.api.records.ContainerStatus
     
    setExpireInterval(int) - Method in class org.apache.hadoop.yarn.util.AbstractLivelinessMonitor
     
    setExtended(boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableStat
    Set whether to display the extended stats (stdev, min/max etc.) or not
    setFactory(Class, WritableFactory) - Static method in class org.apache.hadoop.io.WritableFactories
    Define a factory for a class.
    setFailedRequests(Map<ContainerId, SerializedException>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetContainerStatusesResponse
    Set the containerId-to-exception map in which the exception indicates error from per container for failed requests
    setFailedRequests(Map<ContainerId, SerializedException>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainersResponse
    Set the containerId-to-exception map in which the exception indicates error from per container for failed requests
    setFailedRequests(Map<ContainerId, SerializedException>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.StopContainersResponse
    Set the containerId-to-exception map in which the exception indicates error from per container for failed requests
    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 class org.apache.hadoop.yarn.api.records.URL
    Set the file of the URL.
    setFileTimestamps(Configuration, String) - Static method in class org.apache.hadoop.filecache.DistributedCache
    Deprecated.
    setFilterClass(Configuration, Class) - Static method in class org.apache.hadoop.mapred.SequenceFileInputFilter
    set the filter class
    setFilterClass(Job, Class<?>) - Static method in class org.apache.hadoop.mapreduce.lib.input.SequenceFileInputFilter
    set the filter class
    setFinalApplicationStatus(FinalApplicationStatus) - Method in class org.apache.hadoop.yarn.api.protocolrecords.FinishApplicationMasterRequest
    Set the final state of the ApplicationMaster
    setFinalApplicationStatus(FinalApplicationStatus) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setFinishRange(LongRange) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
    Set the range of finish times to filter applications on
    setFinishRange(long, long) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
    Set the range of finish times to filter applications on
    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 class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setFinishTime(long) - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
     
    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 class org.apache.hadoop.yarn.api.records.NodeReport
     
    setHeartbeatInterval(int) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
     
    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 class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
    Set the host on which the ApplicationMaster is running.
    setHost(String) - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
     
    setHost(String) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setHost(String) - Method in class org.apache.hadoop.yarn.api.records.NodeId
     
    setHost(String) - Method in class org.apache.hadoop.yarn.api.records.URL
    Set the host of the URL.
    setHosts(String[]) - Method in class org.apache.hadoop.fs.BlockLocation
    Set the hosts hosting this block
    setHttpAddress(String) - Method in class 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 class org.apache.hadoop.yarn.api.records.Container
     
    setId(ContainerId) - Method in class org.apache.hadoop.yarn.api.records.PreemptionContainer
     
    setId(long) - Method in class org.apache.hadoop.yarn.api.records.ReservationId
     
    setId(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
    Set the domain ID
    setIdentifier(ByteBuffer) - Method in class org.apache.hadoop.yarn.api.records.Token
     
    setIfUnset(String, String) - Method in class org.apache.hadoop.conf.Configuration
    Sets a property if it is currently unset.
    setIncludeApplications(boolean) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
    Should we get fetch information about active applications?
    setIncludeChildQueues(boolean) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
    Should we fetch information about child queues?
    setIncludePattern(String) - Method in class org.apache.hadoop.yarn.api.records.LogAggregationContext
    Set include pattern.
    setIncreasedContainers(List<ContainerResourceIncrease>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
    Set the list of newly increased containers by ResourceManager
    setIncreaseRequests(List<ContainerResourceIncreaseRequest>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
    Set the ContainerResourceIncreaseRequest to inform the ResourceManager about some container's resources need to be increased
    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.
    setInterpreter(ReservationRequestInterpreter) - Method in class org.apache.hadoop.yarn.api.records.ReservationRequests
    Set the ReservationRequestInterpreter, representing how the list of resources should be allocated, this captures temporal ordering and other constraints.
    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.
    setIsKillCompleted(boolean) - Method in class org.apache.hadoop.yarn.api.protocolrecords.KillApplicationResponse
    Set the flag which indicates that the process of killing application is completed or not.
    setIsUnregistered(boolean) - Method in class org.apache.hadoop.yarn.api.protocolrecords.FinishApplicationMasterResponse
    Set the flag which indicates that the application has successfully unregistered with the RM and the application can safely stop.
    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
    setKeepContainersAcrossApplicationAttempts(boolean) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the flag which indicates whether to keep containers across application attempts.
    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 class org.apache.hadoop.yarn.api.records.Token
     
    setLanguage(String) - Method in class org.apache.hadoop.record.compiler.ant.RccTask
    Deprecated.
    Sets the output language option
    setLastHealthReportTime(long) - Method in class org.apache.hadoop.yarn.api.records.NodeReport
     
    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
    setLimit(long) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
    Limit the number applications to return
    setLocalArchives(Configuration, String) - Static method in class org.apache.hadoop.filecache.DistributedCache
    Deprecated.
    setLocalFiles(Configuration, String) - Static method in class org.apache.hadoop.filecache.DistributedCache
    Deprecated.
    setLocalResources(Map<String, LocalResource>) - Method in class org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Set LocalResource required by the container.
    setLogAggregationContext(LogAggregationContext) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set LogAggregationContext for the application
    setLogUrl(String) - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
     
    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
    setMapredJobID(String) - Method in class org.apache.hadoop.mapred.jobcontrol.Job
    Deprecated.
    setMapRunnerClass(Class<? extends MapRunnable>) - Method in class org.apache.hadoop.mapred.JobConf
    Expert: Set the MapRunnable class for the job.
    setMapSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapred.JobConf
    Turn speculative execution on or off for this job for map tasks.
    setMapSpeculativeExecution(boolean) - Method in class org.apache.hadoop.mapreduce.Job
    Turn speculative execution on or off for this job for map tasks.
    setMasterKey(byte[]) - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenSecretManager
     
    setMaxAppAttempts(int) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the number of max attempts of the application to be submitted.
    setMaxHistoryAge(long) - Method in class org.apache.hadoop.mapreduce.v2.hs.HistoryFileManager
     
    setMaximumCapacity(float) - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
     
    setMaximumResourceCapability(Resource) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse
     
    setMaximumResourceCapability(Resource) - Method in class 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
     
    setMemorySeconds(long) - Method in class org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
    Set the aggregated amount of memory (in megabytes) the application has allocated times the number of seconds the application has been running.
    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
     
    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.
    setMockFileSystemForTesting(FileSystem) - Method in class org.apache.hadoop.fs.azure.WasbFsck
    For testing purposes, set the file system to use here instead of relying on getting it from the FileSystem class based on the URI.
    setModifiedTime(Long) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
    Set the modified time of the domain
    setMonitorInterval(int) - Method in class org.apache.hadoop.yarn.util.AbstractLivelinessMonitor
     
    setName(String) - Method in class org.apache.hadoop.record.meta.RecordTypeInfo
    Deprecated.
    set the name of the record
    setName(String) - Method in class 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 class org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
     
    setNextExpirationTime(long) - Method in interface org.apache.hadoop.mapreduce.v2.api.protocolrecords.RenewDelegationTokenResponse
     
    setNMToken(String, Token) - Static method in class org.apache.hadoop.yarn.client.api.NMTokenCache
    Sets the NMToken for node address only in the singleton obtained from NMTokenCache.getSingleton().
    setNMTokenCache(NMTokenCache) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
    Set the NM token cache for the AMRMClient.
    setNMTokenCache(NMTokenCache) - Method in class org.apache.hadoop.yarn.client.api.NMClient
    Set the NM Token cache of the NMClient.
    setNMTokens(List<NMToken>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
     
    setNMTokensFromPreviousAttempts(List<NMToken>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
    Set the list of NMTokens for communicating with the NMs where the the containers of previous application attempts are running.
    setNodeHttpAddress(String) - Method in class org.apache.hadoop.yarn.api.records.Container
     
    setNodeHttpAddress(String) - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
     
    setNodeId(NodeId) - Method in class org.apache.hadoop.yarn.api.records.Container
     
    setNodeId(NodeId) - Method in class org.apache.hadoop.yarn.api.records.NMToken
     
    setNodeId(NodeId) - Method in class org.apache.hadoop.yarn.api.records.NodeReport
     
    setNodeLabelExpression(String) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set node-label-expression for this app
    setNodeLabelExpression(String) - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
    Set node label expression of this resource request.
    setNodeLabels(Set<String>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodeLabelsResponse
     
    setNodeLabels(Set<String>) - Method in class org.apache.hadoop.yarn.api.records.NodeReport
     
    setNodeReports(List<NodeReport>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesResponse
     
    setNodeState(NodeState) - Method in class org.apache.hadoop.yarn.api.records.NodeReport
     
    setNodeStates(EnumSet<NodeState>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesRequest
    The state to filter the cluster nodes with.
    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 class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
     
    setNumContainers(int) - Method in class org.apache.hadoop.yarn.api.records.NodeReport
     
    setNumContainers(int) - Method in class org.apache.hadoop.yarn.api.records.ReservationRequest
    Set the number of containers required with the given specifications
    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 class 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 class 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 class 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 class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
     
    setOriginalTrackingUrl(String) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setOtherInfo(Map<String, Object>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
    Set the other info map to the given map of other information
    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.
    setOverCommitTimeout(int) - Method in class org.apache.hadoop.yarn.api.records.ResourceOption
     
    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.azure.NativeAzureFileSystem
     
    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(File, String, String) - Static method in class org.apache.hadoop.fs.FileUtil
    Set the ownership on a file / directory.
    setOwner(Path, String, String) - Method in class org.apache.hadoop.fs.FilterFileSystem
     
    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
     
    setOwner(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
    Set the domain owner.
    setPartitionerClass(Class<? extends Partitioner>) - Method in class org.apache.hadoop.mapred.JobConf
    Set the Partitioner class used to partition Mapper-outputs to be sent to the Reducers.
    setPartitionerClass(Class<? extends Partitioner>) - Method in class org.apache.hadoop.mapreduce.Job
    Set the Partitioner for the job.
    setPartitionFile(JobConf, Path) - Static method in class org.apache.hadoop.mapred.lib.TotalOrderPartitioner
    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 class org.apache.hadoop.yarn.api.records.Token
     
    setPath(Path) - Method in class org.apache.hadoop.fs.FileStatus
     
    setPath(String) - Method in class org.apache.hadoop.yarn.api.protocolrecords.UseSharedCacheResourceResponse
    Set the Path corresponding to a resource in the shared cache.
    setPattern(String, Pattern) - Method in class org.apache.hadoop.conf.Configuration
    Set the given property to Pattern.
    setPattern(String) - Method in class 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.azure.NativeAzureFileSystem
     
    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(File, FsPermission) - Static method in class org.apache.hadoop.fs.FileUtil
    Set permissions to the required value.
    setPermission(Path, FsPermission) - Method in class org.apache.hadoop.fs.FilterFileSystem
     
    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 class org.apache.hadoop.yarn.api.records.URL
    Set the port of the URL
    setPreemptionMessage(PreemptionMessage) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
     
    setPrimaryFilters(Map<String, Set<Object>>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
    Set the primary filter map to the given map of primary filters
    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 class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the Priority of the application.
    setPriority(Priority) - Method in class org.apache.hadoop.yarn.api.records.Container
     
    setPriority(Priority) - Method in class org.apache.hadoop.yarn.api.records.ContainerReport
     
    setPriority(int) - Method in class org.apache.hadoop.yarn.api.records.Priority
    Set the assigned priority
    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 class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
    Set the current progress of application
    setProgress(float) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    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 class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
    Set the queue that the application was placed in.
    setQueue(String) - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationSubmissionRequest
    Set the name of the Plan that corresponds to the name of the QueueInfo in the scheduler to which the reservation will be submitted to
    setQueue(String) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setQueue(String) - Method in class 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 class 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 class org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest
    Set the queue name for which to get queue information
    setQueueName(String) - Method in class org.apache.hadoop.yarn.api.records.QueueInfo
     
    setQueueName(String) - Method in class org.apache.hadoop.yarn.api.records.QueueUserACLInfo
     
    setQueues(Set<String>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
    Set the queue to filter applications on
    setQueueState(String) - Method in class org.apache.hadoop.mapred.JobQueueInfo
    Set the state of the queue
    setQueueState(QueueState) - Method in class 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 class org.apache.hadoop.yarn.api.records.NodeReport
     
    setReadable(File, boolean) - Static method in class org.apache.hadoop.fs.FileUtil
    Platform independent implementation for File.setReadable(boolean) File#setReadable does not work as expected on Windows.
    setReadahead(Long) - Method in interface org.apache.hadoop.fs.CanSetReadahead
    Set the readahead on this stream.
    setReadahead(Long) - Method in class org.apache.hadoop.fs.FSDataInputStream
     
    setReaders(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
    Set the reader (and/or reader group) list string
    setRecordLength(Configuration, int) - Static method in class org.apache.hadoop.mapred.FixedLengthInputFormat
    Set the length of each record
    setRecordLength(Configuration, int) - Static method in class org.apache.hadoop.mapreduce.lib.input.FixedLengthInputFormat
    Set the length of each record
    setRecursive(boolean) - Method in class 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.
    setRelatedEntities(Map<String, Set<String>>) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
    Set the related entity map to the given map of related entities
    setRelaxLocality(boolean) - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
    For a request at a network hierarchy level, set whether locality can be relaxed to that level and beyond.
    setReleaseList(List<ContainerId>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
    Set the list of ContainerId of containers being released by the ApplicationMaster
    setRenewer(String) - Method in interface org.apache.hadoop.mapreduce.v2.api.protocolrecords.GetDelegationTokenRequest
     
    setRenewer(String) - Method in class 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.viewfs.ViewFileSystem
     
    setReplication(Path, short) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    setReservationDefinition(ReservationDefinition) - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationSubmissionRequest
    Set the ReservationDefinition representing the user constraints for this reservation
    setReservationDefinition(ReservationDefinition) - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationUpdateRequest
    Set the ReservationDefinition representing the updated user constraints for this reservation
    setReservationId(ReservationId) - Method in class org.apache.hadoop.mapreduce.Job
    Set the reservation to which the job is submitted to
    setReservationId(ReservationId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationDeleteRequest
    Set the ReservationId, that correspond to a valid resource allocation in the scheduler (between start and end time of this reservation)
    setReservationId(ReservationId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationSubmissionResponse
    Set the ReservationId, that correspond to a valid resource allocation in the scheduler (between start and end time of this reservation)
    setReservationId(ReservationId) - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReservationUpdateRequest
    Set the ReservationId, that correspond to a valid resource allocation in the scheduler (between start and end time of this reservation)
    setReservationID(ReservationId) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the reservation id, that correspond to a valid resource allocation in the scheduler (between start and end time of the corresponding reservation)
    setReservationName(String) - Method in class org.apache.hadoop.yarn.api.records.ReservationDefinition
    Set the name for this reservation.
    setReservationRequests(ReservationRequests) - Method in class org.apache.hadoop.yarn.api.records.ReservationDefinition
    Set the list of ReservationRequests representing the resources required by the application
    setReservationResources(List<ReservationRequest>) - Method in class org.apache.hadoop.yarn.api.records.ReservationRequests
    Set the list of ReservationRequest representing the resources required by the application
    setReservedMem(int) - Method in class org.apache.hadoop.mapreduce.JobStatus
     
    setReservedResources(Resource) - Method in class org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
     
    setResource(Resource) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
    Set the resource required by the ApplicationMaster for this application.
    setResource(Resource) - Method in class org.apache.hadoop.yarn.api.records.Container
     
    setResource(URL) - Method in class org.apache.hadoop.yarn.api.records.LocalResource
    Set location of the resource to be localized.
    setResource(Resource) - Method in class org.apache.hadoop.yarn.api.records.ResourceOption
     
    setResourceBlacklistRequest(ResourceBlacklistRequest) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
    Set the ResourceBlacklistRequest to inform the ResourceManager about the blacklist additions and removals per the ApplicationMaster.
    setResourceKey(String) - Method in class org.apache.hadoop.yarn.api.protocolrecords.ReleaseSharedCacheResourceRequest
    Set the key of the resource to be released.
    setResourceKey(String) - Method in class org.apache.hadoop.yarn.api.protocolrecords.UseSharedCacheResourceRequest
    Set the key of the resource to be used.
    setResourceName(String) - Method in class org.apache.hadoop.yarn.api.records.ResourceRequest
    Set the resource name (e.g.
    setResourceRequest(List<PreemptionResourceRequest>) - Method in class org.apache.hadoop.yarn.api.records.PreemptionContract
     
    setResourceRequest(ResourceRequest) - Method in class org.apache.hadoop.yarn.api.records.PreemptionResourceRequest
     
    setResponseId(int) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest
    Set the response id used to track duplicate responses.
    setResponseId(int) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
     
    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(Token) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenResponse
     
    setRolledLogsExcludePattern(String) - Method in class org.apache.hadoop.yarn.api.records.LogAggregationContext
    Set exclude pattern for in a rolling fashion.
    setRolledLogsIncludePattern(String) - Method in class org.apache.hadoop.yarn.api.records.LogAggregationContext
    Set include pattern in a rolling fashion.
    setRpcPort(int) - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
    Set the RPC port on which the ApplicationMaster is responding.
    setRpcPort(int) - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
     
    setRpcPort(int) - Method in class 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.
    setSchedulerResourceTypes(EnumSet<YarnServiceProtos.SchedulerResourceTypes>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse
    Set the resource types used by the scheduler.
    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 class org.apache.hadoop.yarn.api.records.URL
    Set the scheme of the URL
    setScope(ApplicationsRequestScope) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
    Set the ApplicationsRequestScope of applications to filter.
    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 class org.apache.hadoop.yarn.api.records.Token
     
    setServiceData(Map<String, ByteBuffer>) - Method in class org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Set application-specific binary service data.
    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
    setShouldBeUploadedToSharedCache(boolean) - Method in class org.apache.hadoop.yarn.api.records.LocalResource
    Inform NM whether upload to SCM is needed.
    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 class 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
     
    setStartContainerRequests(List<StartContainerRequest>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainersRequest
    Set a list of StartContainerRequest to start containers.
    setStartRange(LongRange) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
    Set the range of start times to filter applications on
    setStartRange(long, long) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
    Set the range of start times to filter applications on
    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 class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setStartTime(Long) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
    Set the start time of the entity
    setState(int) - Method in class org.apache.hadoop.mapred.jobcontrol.Job
    Deprecated.
    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 class 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.
    setStrictContract(StrictPreemptionContract) - Method in class org.apache.hadoop.yarn.api.records.PreemptionMessage
     
    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.
    setSuccessfullyStartedContainers(List<ContainerId>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.StartContainersResponse
     
    setSuccessfullyStoppedContainers(List<ContainerId>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.StopContainersResponse
    Set the list of containerIds of successfully stopped containers.
    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.
    setTargetQueue(String) - Method in class org.apache.hadoop.yarn.api.protocolrecords.MoveApplicationAcrossQueuesRequest
    Get the queue to place the application in.
    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
    setTaskID(TaskAttemptID) - 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.
    setTimeDuration(String, long, TimeUnit) - Method in class org.apache.hadoop.conf.Configuration
    Set the value of name to the given time duration.
    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
     
    setTimes(Path, long, long) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
    Sets the Path's last modified time only to the given valid time.
    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 class org.apache.hadoop.yarn.api.records.LocalResource
    Set the timestamp of the resource to be localized, used for verification.
    setTimestamp(long) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
    Set the timestamp of the event
    setToken(Token) - Method in class org.apache.hadoop.yarn.api.records.NMToken
     
    setToken(String, Token) - Method in class org.apache.hadoop.yarn.client.api.NMTokenCache
    Sets the NMToken for node address
    setTokens(ByteBuffer) - Method in class org.apache.hadoop.yarn.api.records.ContainerLaunchContext
    Set security tokens needed by this container.
    setTopologyPaths(String[]) - Method in class org.apache.hadoop.fs.BlockLocation
    Set the network topology paths of the hosts
    setTotalLogFileSize(long) - Method in class org.apache.hadoop.yarn.ContainerLogAppender
     
    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 class org.apache.hadoop.yarn.api.protocolrecords.FinishApplicationMasterRequest
    Set the final tracking URLfor the ApplicationMaster.
    setTrackingUrl(String) - Method in class org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest
    Set the tracking URLfor the ApplicationMaster while it is running.
    setTrackingUrl(String) - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
     
    setTrackingUrl(String) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setType(LocalResourceType) - Method in class org.apache.hadoop.yarn.api.records.LocalResource
    Set the LocalResourceType of the resource to be localized.
    setType(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDelegationTokenResponse
     
    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)
    setUnmanagedAM(boolean) - Method in class org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext
     
    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.
    setUpdatedNodes(List<NodeReport>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse
     
    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 class org.apache.hadoop.yarn.api.records.NodeReport
     
    setUsedMem(int) - Method in class org.apache.hadoop.mapreduce.JobStatus
     
    setUsedResources(Resource) - Method in class 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.
    setUseQueryStringForDelegationToken(boolean) - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
    Deprecated.
    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 class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    setUserAcls(List<QueueACL>) - Method in class org.apache.hadoop.yarn.api.records.QueueUserACLInfo
     
    setUserAclsInfoList(List<QueueUserACLInfo>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetQueueUserAclsInfoResponse
     
    setUserInfo(String) - Method in class org.apache.hadoop.yarn.api.records.URL
    Set the user info of the URL.
    setUsername(String) - Method in class org.apache.hadoop.mapred.JobStatus
     
    setUsername(String) - Method in class org.apache.hadoop.mapreduce.JobStatus
     
    setUsers(Set<String>) - Method in class org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest
    Set the users to filter applications on
    setValue(long) - Method in class org.apache.hadoop.mapred.Counters.Counter
     
    setValue(long) - Method in interface org.apache.hadoop.mapreduce.Counter
    Set this counter by the given value
    setVcoreSeconds(long) - Method in class org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport
    Set the aggregated number of vcores that the application has allocated times the number of seconds the application has been running.
    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
     
    setVerifyChecksum(boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    setVerifyChecksum(boolean) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    setVirtualCores(int) - Method in class org.apache.hadoop.yarn.api.records.Resource
    Set number of virtual cpu cores of the resource.
    setVisibility(LocalResourceVisibility) - Method in class 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.azure.NativeAzureFileSystem
    Set the working directory to the given directory.
    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.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.
    setWorkOutputPath(JobConf, Path) - Static method in class org.apache.hadoop.mapred.FileOutputFormat
    Set the Path of the task's temporary output directory for the map-reduce job.
    setWritable(File, boolean) - Static method in class org.apache.hadoop.fs.FileUtil
    Platform independent implementation for File.setWritable(boolean) File#setWritable does not work as expected on Windows.
    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
     
    setWriters(String) - Method in class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
    Set the writer (and/or writer group) list string
    setXAttr(Path, String, byte[]) - Method in class org.apache.hadoop.fs.AbstractFileSystem
    Set an xattr of a file or directory.
    setXAttr(Path, String, byte[], EnumSet<XAttrSetFlag>) - Method in class org.apache.hadoop.fs.AbstractFileSystem
    Set an xattr of a file or directory.
    setXAttr(Path, String, byte[]) - Method in class org.apache.hadoop.fs.FileContext
    Set an xattr of a file or directory.
    setXAttr(Path, String, byte[], EnumSet<XAttrSetFlag>) - Method in class org.apache.hadoop.fs.FileContext
    Set an xattr of a file or directory.
    setXAttr(Path, String, byte[]) - Method in class org.apache.hadoop.fs.FileSystem
    Set an xattr of a file or directory.
    setXAttr(Path, String, byte[], EnumSet<XAttrSetFlag>) - Method in class org.apache.hadoop.fs.FileSystem
    Set an xattr of a file or directory.
    setXAttr(Path, String, byte[]) - Method in class org.apache.hadoop.fs.FilterFileSystem
     
    setXAttr(Path, String, byte[], EnumSet<XAttrSetFlag>) - Method in class org.apache.hadoop.fs.FilterFileSystem
     
    setXAttr(Path, String, byte[], EnumSet<XAttrSetFlag>) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    setXAttr(Path, String, byte[], EnumSet<XAttrSetFlag>) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    setYarnApplicationAttemptState(YarnApplicationAttemptState) - Method in class org.apache.hadoop.yarn.api.records.ApplicationAttemptReport
     
    setYarnApplicationState(YarnApplicationState) - Method in class org.apache.hadoop.yarn.api.records.ApplicationReport
     
    SHARED_CACHE_CHECKSUM_ALGO_IMPL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    the checksum algorithm implementation
    SHARED_CACHE_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    whether the shared cache is enabled/disabled
    SHARED_CACHE_NESTED_LEVEL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The config key for the level of nested directories before getting to the checksum directory.
    SHARED_CACHE_NM_UPLOADER_REPLICATION_FACTOR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The replication factor for the node manager uploader for the shared cache.
    SHARED_CACHE_NM_UPLOADER_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    SHARED_CACHE_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    SHARED_CACHE_ROOT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The config key for the shared cache root directory.
    SharedCacheChecksum - Interface in org.apache.hadoop.yarn.sharedcache
     
    SharedCacheChecksumFactory - Class in org.apache.hadoop.yarn.sharedcache
     
    SharedCacheChecksumFactory() - Constructor for class org.apache.hadoop.yarn.sharedcache.SharedCacheChecksumFactory
     
    SharedCacheClient - Class in org.apache.hadoop.yarn.client.api
    This is the client for YARN's shared cache.
    SharedCacheClient(String) - Constructor for class org.apache.hadoop.yarn.client.api.SharedCacheClient
     
    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.
     
    SingleArcTransition<OPERAND,EVENT> - Interface in org.apache.hadoop.yarn.state
    Hook for Transition.
    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.Group
     
    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.
    size - Variable in class org.apache.hadoop.registry.client.types.RegistryPathStatus
    Entry size in bytes, as returned by the storage infrastructure.
    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
    SKIP_AZURE_METRICS_PROPERTY_NAME - Static variable in class org.apache.hadoop.fs.azure.NativeAzureFileSystem
     
    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.MutableQuantiles
     
    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
     
    SpanReceiverInfo - Class in org.apache.hadoop.tracing
     
    SpanReceiverInfoBuilder - Class in org.apache.hadoop.tracing
     
    SpanReceiverInfoBuilder(String) - Constructor for class org.apache.hadoop.tracing.SpanReceiverInfoBuilder
     
    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
     
    SplitLocationInfo - Class in org.apache.hadoop.mapred
     
    SplitLocationInfo(String, boolean) - Constructor for class org.apache.hadoop.mapred.SplitLocationInfo
     
    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.service.AbstractService
    Start the service.
    start() - Method in interface org.apache.hadoop.service.Service
    Start the service.
    startContainer(Container, ContainerLaunchContext) - Method in class org.apache.hadoop.yarn.client.api.NMClient
    Start an allocated container.
    startContainerAsync(Container, ContainerLaunchContext) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
     
    StartContainerRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
    The request sent by the ApplicationMaster to the NodeManager to start a container.
    StartContainerRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.StartContainerRequest
     
    startContainers(StartContainersRequest) - Method in interface org.apache.hadoop.yarn.api.ContainerManagementProtocol
    The ApplicationMaster provides a list of StartContainerRequests to a NodeManager to start Containers allocated to it using this interface.
    StartContainersRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
    The request which contains a list of StartContainerRequest sent by the ApplicationMaster to the NodeManager to start containers.
    StartContainersRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.StartContainersRequest
     
    StartContainersResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
    The response sent by the NodeManager to the ApplicationMaster when asked to start an allocated container.
    StartContainersResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.StartContainersResponse
     
    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.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.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.
     
    stat(String) - Method in interface org.apache.hadoop.registry.client.api.RegistryOperations
    Get the status of a path
    stat(String) - Method in class org.apache.hadoop.registry.client.impl.zk.RegistryOperationsService
     
    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.
    statChildren(RegistryOperations, String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryUtils
    List children of a directory and retrieve their RegistryPathStatus values.
    state - Variable in class org.apache.hadoop.service.LifecycleEvent
    new state
    stateChanged(Service) - Method in class org.apache.hadoop.service.LoggingStateChangeListener
    Callback for a state change event: log it
    stateChanged(Service) - Method in interface org.apache.hadoop.service.ServiceStateChangeListener
    Callback to notify of a state change.
    StateMachine<STATE extends Enum<STATE>,EVENTTYPE extends Enum<EVENTTYPE>,EVENT> - Interface in org.apache.hadoop.yarn.state
     
    StateMachineFactory<OPERAND,STATE extends Enum<STATE>,EVENTTYPE extends Enum<EVENTTYPE>,EVENT> - Class in org.apache.hadoop.yarn.state
    State machine topology.
    StateMachineFactory(STATE) - Constructor for class org.apache.hadoop.yarn.state.StateMachineFactory
    Constructor This is the only constructor in the API.
    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.
    STDERR - Static variable in interface org.apache.hadoop.yarn.api.ApplicationConstants
     
    STDOUT - Static variable in interface org.apache.hadoop.yarn.api.ApplicationConstants
     
    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.service.AbstractService
    Stop the service.
    stop() - Method in interface org.apache.hadoop.service.Service
    Stop the service.
    stop(Service) - Static method in class org.apache.hadoop.service.ServiceOperations
    Stop a service.
    STOP_ONLY_STARTED_SERVICES - Static variable in class org.apache.hadoop.service.CompositeService
    Policy on shutdown: attempt to close everything (purest) or only try to close started services (which assumes that the service implementations may not handle the stop() operation except when started.
    stopContainer(ContainerId, NodeId) - Method in class org.apache.hadoop.yarn.client.api.NMClient
    Stop an started container.
    stopContainerAsync(ContainerId, NodeId) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
     
    stopContainers(StopContainersRequest) - Method in interface org.apache.hadoop.yarn.api.ContainerManagementProtocol
    The ApplicationMaster requests a NodeManager to stop a list of Containers allocated to it using this interface.
    StopContainersRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
    The request sent by the ApplicationMaster to the NodeManager to stop containers.
    StopContainersRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.StopContainersRequest
     
    StopContainersResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
    The response sent by the NodeManager to the ApplicationMaster when asked to stop allocated containers.
    StopContainersResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.StopContainersResponse
     
    stopMetricsMBeans() - Method in interface org.apache.hadoop.metrics2.MetricsSystemMXBean
    Stop metrics MBeans.
    stopMonitoring() - Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
    Stops monitoring.
    stopMonitoring() - Method in class org.apache.hadoop.metrics.spi.CompositeContext
     
    stopped() - Method in class org.apache.hadoop.conf.ReconfigurationTaskStatus
    Return true if the latest reconfiguration task has finished and there is no another active task running.
    stopQuietly(Service) - Static method in class org.apache.hadoop.service.ServiceOperations
    Stop a service; if it is null do nothing.
    stopQuietly(Log, Service) - Static method in class org.apache.hadoop.service.ServiceOperations
    Stop a service; if it is null do nothing.
    StorageType - Enum in org.apache.hadoop.fs
    Defines the types of supported storage media.
    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
     
    StrictPreemptionContract - Class in org.apache.hadoop.yarn.api.records
    Enumeration of particular allocations to be reclaimed.
    StrictPreemptionContract() - Constructor for class org.apache.hadoop.yarn.api.records.StrictPreemptionContract
     
    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.ApplicationClientProtocol
    The interface used by clients to submit a new application to the ResourceManager.
    submitApplication(ApplicationSubmissionContext) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
    Submit a new application to YARN. It is a blocking call - it will not return ApplicationId until the submitted application is submitted successfully and accepted by the ResourceManager.
    SubmitApplicationRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
    The request sent by a client to submit an application to the ResourceManager.
    SubmitApplicationRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.SubmitApplicationRequest
     
    SubmitApplicationResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
    The response sent by the ResourceManager to a client on application submission.
    SubmitApplicationResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.SubmitApplicationResponse
     
    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.
    submitJobInternal(JobConf) - Method in class org.apache.hadoop.mapred.JobClient
     
    submitReservation(ReservationSubmissionRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationClientProtocol
    The interface used by clients to submit a new reservation to the ResourceManager.
    submitReservation(ReservationSubmissionRequest) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
    The interface used by clients to submit a new reservation to the ResourceManager.
    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
     
    SUBPATH_COMPONENTS - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
    path under a service record to point to components of that service: "/components/".
    SUBSTITUTE_TOKEN - Static variable in class org.apache.hadoop.mapreduce.lib.db.DataDrivenDBInputFormat
    If users are providing their own query, the following string is expected to appear in the WHERE clause, which will be substituted with a pair of conditions on the input to allow input splits to parallelise the import.
    SUCCEEDED - Static variable in class org.apache.hadoop.mapred.JobStatus
     
    SUCCEEDED_FILE_NAME - Static variable in class org.apache.hadoop.mapred.FileOutputCommitter
     
    SUCCEEDED_FILE_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
     
    SUCCESS - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
     
    SUCCESS - Static variable in class org.apache.hadoop.yarn.api.records.ContainerExitStatus
     
    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.
    supplyBindingInformation() - Method in interface org.apache.hadoop.registry.client.impl.zk.RegistryBindingSource
    Supply the binding information for this registry
    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.FileSystem
    supportsSymlinks() - Method in class org.apache.hadoop.fs.FilterFileSystem
     
    supportsSymlinks() - Method in class org.apache.hadoop.fs.LocalFileSystem
     
    supportsSymlinks() - Method in class org.apache.hadoop.fs.RawLocalFileSystem
     
    supportsSymlinks() - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    supportTypeQuota() - Method in enum org.apache.hadoop.fs.StorageType
     
    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.
     
    SYMBOL - Variable in enum org.apache.hadoop.fs.permission.FsAction
    Symbolic representation
    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.
    SYMLINK_NO_PRIVILEGE - Static variable in class org.apache.hadoop.fs.FileUtil
     
    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.
    SYSTEM_CLASSES_DEFAULT - Static variable in class org.apache.hadoop.util.ApplicationClassLoader
    Default value of the system classes if the user did not override them.
    SYSTEM_FILTER_CONFLICT - Static variable in class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
    Error code returned if the user specifies the timeline system reserved filter key
    SystemClock - Class in org.apache.hadoop.yarn.util
    Implementation of Clock that gives the current time from the system clock in milliseconds.
    SystemClock() - Constructor for class org.apache.hadoop.yarn.util.SystemClock
     

    T

    TableMapping - Class in org.apache.hadoop.net
    Simple DNSToSwitchMapping implementation that reads a 2 column text file.
    TableMapping() - Constructor for class org.apache.hadoop.net.TableMapping
     
    tableName - Variable in class org.apache.hadoop.mapreduce.lib.db.DBInputFormat
     
    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(String, int, boolean, int, int) - Constructor for class org.apache.hadoop.mapreduce.TaskAttemptID
    Deprecated.
    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(JobID, boolean, int) - Constructor for class org.apache.hadoop.mapreduce.TaskID
    Deprecated.
    TaskID(String, int, boolean, int) - Constructor for class org.apache.hadoop.mapreduce.TaskID
    Deprecated.
    TaskID() - Constructor for class org.apache.hadoop.mapreduce.TaskID
     
    TaskInputOutputContext<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Interface in org.apache.hadoop.mapreduce
    A context object that allows input and output from the task.
    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
    TEMP_DIR_NAME - Static variable in class org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
    Deprecated.
    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
     
    time - Variable in class org.apache.hadoop.registry.client.types.RegistryPathStatus
    Timestamp
    time - Variable in class org.apache.hadoop.service.LifecycleEvent
    Local time in milliseconds when the event occurred
    TIMELINE_DELEGATION_KEY_UPDATE_INTERVAL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    TIMELINE_DELEGATION_TOKEN_MAX_LIFETIME - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    TIMELINE_DELEGATION_TOKEN_RENEW_INTERVAL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    TIMELINE_SERVICE_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    host:port address for timeline service RPC APIs.
    TIMELINE_SERVICE_BIND_HOST - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The listening endpoint for the timeline service application.
    TIMELINE_SERVICE_CLIENT_BEST_EFFORT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline client policy for whether connections are fatal
    TIMELINE_SERVICE_CLIENT_MAX_RETRIES - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline client call, max retries (-1 means no limit)
    TIMELINE_SERVICE_CLIENT_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline client settings
    TIMELINE_SERVICE_CLIENT_RETRY_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline client call, retry interval
    TIMELINE_SERVICE_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The setting that controls whether timeline service is enabled or not.
    TIMELINE_SERVICE_HANDLER_THREAD_COUNT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The number of threads to handle client RPC API requests.
    TIMELINE_SERVICE_HTTP_CROSS_ORIGIN_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Enables cross origin support for timeline server.
    TIMELINE_SERVICE_HTTP_CROSS_ORIGIN_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Default value for cross origin support for timeline server.
    TIMELINE_SERVICE_KEYTAB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The Kerberos keytab for the timeline server.
    TIMELINE_SERVICE_LEVELDB_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline service leveldb path
    TIMELINE_SERVICE_LEVELDB_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    TIMELINE_SERVICE_LEVELDB_READ_CACHE_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline service leveldb read cache (uncompressed blocks)
    TIMELINE_SERVICE_LEVELDB_START_TIME_READ_CACHE_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline service leveldb start time read cache (number of entities)
    TIMELINE_SERVICE_LEVELDB_START_TIME_WRITE_CACHE_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline service leveldb start time write cache (number of entities)
    TIMELINE_SERVICE_LEVELDB_STATE_STORE_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline service state store leveldb path
    TIMELINE_SERVICE_LEVELDB_STATE_STORE_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    TIMELINE_SERVICE_LEVELDB_TTL_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline service leveldb interval to wait between deletion rounds
    TIMELINE_SERVICE_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    TIMELINE_SERVICE_PRINCIPAL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The Kerberos principal for the timeline server.
    TIMELINE_SERVICE_RECOVERY_ENABLED - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Flag to enable recovery of timeline service
    TIMELINE_SERVICE_STATE_STORE_CLASS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline service state store class
    TIMELINE_SERVICE_STORE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline service store class
    TIMELINE_SERVICE_TTL_ENABLE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline service enable data age off
    TIMELINE_SERVICE_TTL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Timeline service length of time to retain data
    TIMELINE_SERVICE_WEBAPP_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The address of the timeline service web application.
    TIMELINE_SERVICE_WEBAPP_HTTPS_ADDRESS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The https address of the timeline service web application.
    TimelineClient - Class in org.apache.hadoop.yarn.client.api
    A client library that can be used to post some information in terms of a number of conceptual entities.
    TimelineClient(String) - Constructor for class org.apache.hadoop.yarn.client.api.TimelineClient
     
    TimelineDelegationTokenIdentifier - Class in org.apache.hadoop.yarn.security.client
     
    TimelineDelegationTokenIdentifier() - Constructor for class org.apache.hadoop.yarn.security.client.TimelineDelegationTokenIdentifier
     
    TimelineDelegationTokenIdentifier(Text, Text, Text) - Constructor for class org.apache.hadoop.yarn.security.client.TimelineDelegationTokenIdentifier
    Create a new timeline delegation token identifier
    TimelineDelegationTokenResponse - Class in org.apache.hadoop.yarn.api.records.timeline
    The response of delegation token related request
    TimelineDelegationTokenResponse() - Constructor for class org.apache.hadoop.yarn.api.records.timeline.TimelineDelegationTokenResponse
     
    TimelineDelegationTokenSelector - Class in org.apache.hadoop.yarn.security.client
     
    TimelineDelegationTokenSelector() - Constructor for class org.apache.hadoop.yarn.security.client.TimelineDelegationTokenSelector
     
    TimelineDomain - Class in org.apache.hadoop.yarn.api.records.timeline
    This class contains the information about a timeline domain, which is used to a user to host a number of timeline entities, isolating them from others'.
    TimelineDomain() - Constructor for class org.apache.hadoop.yarn.api.records.timeline.TimelineDomain
     
    TimelineDomains - Class in org.apache.hadoop.yarn.api.records.timeline
    The class that hosts a list of timeline domains.
    TimelineDomains() - Constructor for class org.apache.hadoop.yarn.api.records.timeline.TimelineDomains
     
    TimelineEntities - Class in org.apache.hadoop.yarn.api.records.timeline
    The class that hosts a list of timeline entities.
    TimelineEntities() - Constructor for class org.apache.hadoop.yarn.api.records.timeline.TimelineEntities
     
    TimelineEntity - Class in org.apache.hadoop.yarn.api.records.timeline
    The class that contains the the meta information of some conceptual entity and its related events.
    TimelineEntity() - Constructor for class org.apache.hadoop.yarn.api.records.timeline.TimelineEntity
     
    TimelineEvent - Class in org.apache.hadoop.yarn.api.records.timeline
    The class that contains the information of an event that is related to some conceptual entity of an application.
    TimelineEvent() - Constructor for class org.apache.hadoop.yarn.api.records.timeline.TimelineEvent
     
    TimelineEvents - Class in org.apache.hadoop.yarn.api.records.timeline
    The class that hosts a list of events, which are categorized according to their related entities.
    TimelineEvents() - Constructor for class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents
     
    TimelineEvents.EventsOfOneEntity - Class in org.apache.hadoop.yarn.api.records.timeline
    The class that hosts a list of events that are only related to one entity.
    TimelineEvents.EventsOfOneEntity() - Constructor for class org.apache.hadoop.yarn.api.records.timeline.TimelineEvents.EventsOfOneEntity
     
    TimelinePutResponse - Class in org.apache.hadoop.yarn.api.records.timeline
    A class that holds a list of put errors.
    TimelinePutResponse() - Constructor for class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse
     
    TimelinePutResponse.TimelinePutError - Class in org.apache.hadoop.yarn.api.records.timeline
    A class that holds the error code for one entity.
    TimelinePutResponse.TimelinePutError() - Constructor for class org.apache.hadoop.yarn.api.records.timeline.TimelinePutResponse.TimelinePutError
     
    TimelineUtils - Class in org.apache.hadoop.yarn.util.timeline
    The helper class for the timeline module.
    TimelineUtils() - Constructor for class org.apache.hadoop.yarn.util.timeline.TimelineUtils
     
    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
    toExtendedShort() - Method in class org.apache.hadoop.fs.permission.FsPermission
    Encodes the object to a short.
    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 - Class in org.apache.hadoop.yarn.api.records
    Token is the security entity used by the framework to verify authenticity of any resource.
    Token() - Constructor for class org.apache.hadoop.yarn.api.records.Token
     
    TOKEN_PARAM - Static variable in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticator
     
    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 <token,freq> 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(boolean, 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.HdfsVolumeId
     
    toString() - Method in class org.apache.hadoop.fs.Path
     
    toString() - Method in class org.apache.hadoop.fs.permission.AclEntry
     
    toString() - Method in class org.apache.hadoop.fs.permission.AclStatus
     
    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.registry.client.types.Endpoint
     
    toString() - Method in class org.apache.hadoop.registry.client.types.RegistryPathStatus
     
    toString() - Method in class org.apache.hadoop.registry.client.types.ServiceRecord
     
    toString() - Method in class org.apache.hadoop.security.authorize.AccessControlList
    Returns descriptive way of users and groups that are part of this ACL.
    toString() - Method in class org.apache.hadoop.service.AbstractService
     
    toString() - Method in class org.apache.hadoop.service.ServiceStateModel
    return the state text as the toString() value
    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.Priority
     
    toString() - Method in class org.apache.hadoop.yarn.api.records.ReservationId
     
    toString() - Method in class org.apache.hadoop.yarn.api.records.Resource
     
    toString() - Method in class org.apache.hadoop.yarn.api.records.ResourceOption
     
    toString() - Method in class org.apache.hadoop.yarn.event.AbstractEvent
     
    toString() - Method in interface org.apache.hadoop.yarn.event.Event
     
    toString() - Method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogKey
     
    toString() - Method in class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
     
    toString() - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
     
    toString() - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
     
    toString() - Method in class org.apache.hadoop.yarn.security.NMTokenIdentifier
     
    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.
    TraceAdminProtocol - Interface in org.apache.hadoop.tracing
    Protocol interface that provides tracing.
    TraceAdminProtocolPB - Interface in org.apache.hadoop.tracing
     
    transition(OPERAND, EVENT) - Method in interface org.apache.hadoop.yarn.state.MultipleArcTransition
    Transition hook.
    transition(OPERAND, EVENT) - Method in interface org.apache.hadoop.yarn.state.SingleArcTransition
    Transition hook.
    transitionToActive(HAServiceProtocol.StateChangeRequestInfo) - Method in interface org.apache.hadoop.ha.HAServiceProtocol
    Request service to transition to active state.
    transitionToActive(HAServiceProtocol, HAServiceProtocol.StateChangeRequestInfo) - Static method in class org.apache.hadoop.ha.HAServiceProtocolHelper
     
    transitionToStandby(HAServiceProtocol.StateChangeRequestInfo) - Method in interface org.apache.hadoop.ha.HAServiceProtocol
    Request service to transition to standby state.
    transitionToStandby(HAServiceProtocol, HAServiceProtocol.StateChangeRequestInfo) - Static method in class org.apache.hadoop.ha.HAServiceProtocolHelper
     
    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(Path, long) - Method in class org.apache.hadoop.fs.AbstractFileSystem
    The specification of this method matches that of FileContext.truncate(Path, long) except that Path f must be for this file system.
    truncate(Path, long) - Method in class org.apache.hadoop.fs.ChecksumFileSystem
     
    truncate(Path, long) - Method in class org.apache.hadoop.fs.FileContext
    Truncate the file in the indicated path to the indicated size.
    truncate(Path, long) - Method in class org.apache.hadoop.fs.FileSystem
    Truncate the file in the indicated path to the indicated size.
    truncate(Path, long) - Method in class org.apache.hadoop.fs.FilterFileSystem
     
    truncate(Path, long) - Method in class org.apache.hadoop.fs.RawLocalFileSystem
     
    truncate(Path, long) - Method in class org.apache.hadoop.fs.viewfs.ViewFileSystem
     
    truncate(Path, long) - Method in class org.apache.hadoop.fs.viewfs.ViewFs
     
    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.
    tryFence(HAServiceTarget, String) - Method in interface org.apache.hadoop.ha.FenceMethod
    Attempt to fence the target node.
    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 - Variable in class org.apache.hadoop.registry.client.types.ServiceRecord
    The type field.
    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
     
    UNAVAILABLE - Static variable in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
     
    unbuffer() - Method in class org.apache.hadoop.fs.FSDataInputStream
     
    uncaughtException(Thread, Throwable) - Method in class org.apache.hadoop.yarn.YarnUncaughtExceptionHandler
     
    UNDEFINED - Static variable in class org.apache.hadoop.yarn.api.records.Priority
     
    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
     
    unregister(O) - Method in class org.apache.hadoop.yarn.util.AbstractLivelinessMonitor
     
    unregisterApplicationMaster(FinalApplicationStatus, String, String) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
    Unregister the application master.
    unregisterApplicationMaster(FinalApplicationStatus, String, String) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
    Unregister the application master.
    unregisterGlobalListener(ServiceStateChangeListener) - Static method in class org.apache.hadoop.service.AbstractService
    unregister a global listener.
    unregisterServiceListener(ServiceStateChangeListener) - Method in class org.apache.hadoop.service.AbstractService
     
    unregisterServiceListener(ServiceStateChangeListener) - Method in interface org.apache.hadoop.service.Service
    Unregister a previously registered listener of the service state change events.
    unregisterSource(String) - Method in class org.apache.hadoop.metrics2.MetricsSystem
    Unregister a metrics source
    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
     
    updateBlacklist(List<String>, List<String>) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
    Update application's blacklist with addition or removal resources.
    updateBlacklist(List<String>, List<String>) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
    Update application's blacklist with addition or removal resources.
    updateBytesReadInLastSecond(long) - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
    Sets the current gauge value for how many bytes were read in the last second.
    updateBytesWrittenInLastSecond(long) - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
    Sets the current gauge value for how many bytes were written in the last second.
    updateConnectAddr(String, String, 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.
    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.
    updateConnectAddr(String, InetSocketAddress) - Method in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    UpdateLineColumn(char) - Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
    Deprecated.
     
    updateProcessTree() - Method in class org.apache.hadoop.yarn.util.ResourceCalculatorProcessTree
    Update the process-tree with latest state.
    updateReservation(ReservationUpdateRequest) - Method in interface org.apache.hadoop.yarn.api.ApplicationClientProtocol
    The interface used by clients to update an existing Reservation.
    updateReservation(ReservationUpdateRequest) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
    The interface used by clients to update an existing Reservation.
    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.
    uri(String) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
    Create a URI
    URL - Class in org.apache.hadoop.yarn.api.records
    URL represents a serializable URL.
    URL() - Constructor for class org.apache.hadoop.yarn.api.records.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
    urlEndpoint(String, String, URI...) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
    Create a URL endpoint from a list of URIs
    usage() - Static method in class org.apache.hadoop.record.compiler.generated.Rcc
    Deprecated.
     
    use(UseSharedCacheResourceRequest) - Method in interface org.apache.hadoop.yarn.api.ClientSCMProtocol
    The interface used by clients to claim a resource with the SharedCacheManager. The client uses a checksum to identify the resource and an ApplicationId to identify which application will be using the resource.
    use(ApplicationId, String) - Method in class org.apache.hadoop.yarn.client.api.SharedCacheClient
    The method to claim a resource with the SharedCacheManager. The client uses a checksum to identify the resource and an ApplicationId to identify which application will be using the resource.
    USED_GENERIC_PARSER - Static variable in class org.apache.hadoop.mapreduce.Job
     
    useHttps(Configuration) - Static method in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    useQueryStringForDelegationToken() - Method in class org.apache.hadoop.security.token.delegation.web.DelegationTokenAuthenticatedURL
    Returns if delegation token is transmitted as a HTTP header.
    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
     
    UserGroupInformation.AuthenticationMethod - Enum in org.apache.hadoop.security
    existing types of authentications' methods
    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
    UseSharedCacheResourceRequest - Class in org.apache.hadoop.yarn.api.protocolrecords
    The request from clients to the SharedCacheManager that claims a resource in the shared cache.
    UseSharedCacheResourceRequest() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.UseSharedCacheResourceRequest
     
    UseSharedCacheResourceResponse - Class in org.apache.hadoop.yarn.api.protocolrecords
    The response from the SharedCacheManager to the client that indicates whether a requested resource exists in the cache.
    UseSharedCacheResourceResponse() - Constructor for class org.apache.hadoop.yarn.api.protocolrecords.UseSharedCacheResourceResponse
     
    useStatIfAvailable() - Static method in class org.apache.hadoop.fs.RawLocalFileSystem
     
    USTRING_TKN - Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
    Deprecated.
     
    UTCClock - Class in org.apache.hadoop.yarn.util
    Implementation of Clock that gives the current UTC time in milliseconds.
    UTCClock() - Constructor for class org.apache.hadoop.yarn.util.UTCClock
     
    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
    validate(String, boolean, EnumSet<XAttrSetFlag>) - Static method in enum org.apache.hadoop.fs.XAttrSetFlag
     
    validate() - Method in class org.apache.hadoop.registry.client.types.Endpoint
    Validate the record by checking for null fields and other invalid conditions
    validateEndpoint(String, Endpoint) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
    Validate the endpoint by checking for null fields and other invalid conditions
    validateForAppend(EnumSet<CreateFlag>) - Static method in enum org.apache.hadoop.fs.CreateFlag
    Validate the CreateFlag for the append operation.
    validatePath(String) - Method in class org.apache.hadoop.registry.client.impl.zk.RegistryOperationsService
    Validate a path
    validateServiceRecord(String, ServiceRecord) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
    Validate the record by checking for null fields and other invalid conditions
    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.CacheFlag
    Returns the enum constant of this type with the specified name.
    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 enum org.apache.hadoop.fs.permission.AclEntryScope
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.fs.permission.AclEntryType
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.fs.permission.FsAction
    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.fs.ReadOption
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.fs.StorageType
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.fs.XAttrCodec
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.fs.XAttrSetFlag
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapred.JobPriority
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.mapred.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.security.UserGroupInformation.AuthenticationMethod
    Returns the enum constant of this type with the specified name.
    valueOf(SaslRpcServer.AuthMethod) - Static method in enum org.apache.hadoop.security.UserGroupInformation.AuthenticationMethod
     
    valueOf(String) - Static method in enum org.apache.hadoop.yarn.api.protocolrecords.ApplicationsRequestScope
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.yarn.api.records.AMCommand
    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.ContainerState
    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.NodeState
    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.ReservationRequestInterpreter
    Returns the enum constant of this type with the specified name.
    valueOf(String) - Static method in enum org.apache.hadoop.yarn.api.records.YarnApplicationAttemptState
    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.CacheFlag
    Returns an array containing the constants of this enum type, in the order they are declared.
    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() - Static method in enum org.apache.hadoop.fs.permission.AclEntryScope
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.fs.permission.AclEntryType
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.fs.permission.FsAction
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.fs.ReadOption
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.fs.StorageType
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.fs.XAttrCodec
    Returns an array containing the constants of this enum type, in the order they are declared.
    values() - Static method in enum org.apache.hadoop.fs.XAttrSetFlag
    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.security.UserGroupInformation.AuthenticationMethod
    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.protocolrecords.ApplicationsRequestScope
    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.AMCommand
    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.ContainerState
    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.NodeState
    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.ReservationRequestInterpreter
    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.YarnApplicationAttemptState
    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
     
    versionID - Static variable in interface org.apache.hadoop.ha.HAServiceProtocol
    Initial version of the protocol
    versionID - Static variable in interface org.apache.hadoop.tracing.TraceAdminProtocol
     
    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
     
    VolumeId - Interface in org.apache.hadoop.fs
    Opaque interface that identifies a disk location.

    W

    waitFor(Supplier<Boolean>) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
    Wait for check to return true for each 1000 ms.
    waitFor(Supplier<Boolean>, int) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
    Wait for check to return true for each checkEveryMillis ms.
    waitFor(Supplier<Boolean>, int, int) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
    Wait for check to return true for each checkEveryMillis ms.
    waitFor(Supplier<Boolean>) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
    Wait for check to return true for each 1000 ms.
    waitFor(Supplier<Boolean>, int) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
    Wait for check to return true for each checkEveryMillis ms.
    waitFor(Supplier<Boolean>, int, int) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
    Wait for check to return true for each checkEveryMillis ms.
    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.
    waitForJobCompletion(Job) - Method in class org.apache.hadoop.tools.DistCp
    Wait for the given job to complete.
    waitForServiceToStop(long) - Method in class org.apache.hadoop.service.AbstractService
     
    waitForServiceToStop(long) - Method in interface org.apache.hadoop.service.Service
    Block waiting for the service to stop; uses the termination notification object to do so.
    WAITING - Static variable in class org.apache.hadoop.mapred.jobcontrol.Job
     
    Wasb - Class in org.apache.hadoop.fs.azure
    WASB implementation of AbstractFileSystem.
    WASB_BYTES_READ - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_BYTES_WRITTEN - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_CLIENT_ERRORS - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_DIRECTORIES_CREATED - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_DIRECTORIES_DELETED - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_DOWNLOAD_LATENCY - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_DOWNLOAD_RATE - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_FILES_CREATED - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_FILES_DELETED - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_RAW_BYTES_DOWNLOADED - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_RAW_BYTES_UPLOADED - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_SERVER_ERRORS - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_UPLOAD_LATENCY - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_UPLOAD_RATE - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WASB_WEB_RESPONSES - Static variable in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
     
    WasbFsck - Class in org.apache.hadoop.fs.azure
    An fsck tool implementation for WASB that does various admin/cleanup/recovery tasks on the WASB file system.
    WasbFsck(Configuration) - Constructor for class org.apache.hadoop.fs.azure.WasbFsck
     
    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.
    webEndpoint(String, URI...) - Static method in class org.apache.hadoop.registry.client.binding.RegistryTypeUtils
    Create a Web UI endpoint from a list of URIs
    webResponse() - Method in class org.apache.hadoop.fs.azure.metrics.AzureFileSystemInstrumentation
    Indicate that we just got a web response from Azure Storage.
    WILDCARD_ACL_VALUE - Static variable in class org.apache.hadoop.security.authorize.AccessControlList
     
    WINDOWS - Static variable in class org.apache.hadoop.fs.Path
     
    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.
     
    WORKFLOW_ADJACENCY_PREFIX_PATTERN - Static variable in class org.apache.hadoop.mapred.JobConf
    Deprecated.
    WORKFLOW_ADJACENCY_PREFIX_STRING - Static variable in class org.apache.hadoop.mapred.JobConf
    Deprecated.
    WORKFLOW_ID - Static variable in class org.apache.hadoop.mapred.JobConf
    Deprecated.
    WORKFLOW_NAME - Static variable in class org.apache.hadoop.mapred.JobConf
    Deprecated.
    WORKFLOW_NODE_NAME - Static variable in class org.apache.hadoop.mapred.JobConf
    Deprecated.
    WORKFLOW_TAGS - Static variable in class org.apache.hadoop.mapred.JobConf
    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
     
    wrappedReadForCompressedData(InputStream, byte[], int, int) - Static method in class org.apache.hadoop.io.IOUtils
    Utility wrapper for reading from InputStream.
    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
     
    WritableComparator(Class<? extends WritableComparable>, Configuration, 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.ContentSummary
     
    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
     
    write(DataOutput) - Method in class org.apache.hadoop.io.AbstractMapWritable
     
    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
     
    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
     
    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
     
    write(DataOutput) - Method in class org.apache.hadoop.io.Text
    serialize write this object to out length uses zero-compressed encoding
    write(DataOutput, int) - Method in class org.apache.hadoop.io.Text
     
    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.Counters.Counter
     
    write(DataOutput) - Method in class org.apache.hadoop.mapred.Counters.Group
     
    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.security.authorize.AccessControlList
    Serializes the AccessControlList object
    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
     
    write(DataOutput) - Method in class org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.LogKey
     
    write(DataOutput) - Method in class org.apache.hadoop.yarn.security.AMRMTokenIdentifier
     
    write(DataOutput) - Method in class org.apache.hadoop.yarn.security.client.ClientToAMTokenIdentifier
     
    write(DataOutput) - Method in class org.apache.hadoop.yarn.security.ContainerTokenIdentifier
     
    write(DataOutput) - Method in class org.apache.hadoop.yarn.security.NMTokenIdentifier
     
    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.
     
    writeFully(WritableByteChannel, ByteBuffer) - Static method in class org.apache.hadoop.io.IOUtils
    Write a ByteBuffer to a WritableByteChannel, handling short writes.
    writeFully(FileChannel, ByteBuffer, long) - Static method in class org.apache.hadoop.io.IOUtils
    Write a ByteBuffer to a FileChannel at a given offset, handling short writes.
    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, int) - Static method in class org.apache.hadoop.io.Text
    Write a UTF8 encoded string with a maximum size 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 using UTF-8 encoding.
    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

    XAttrCodec - Enum in org.apache.hadoop.fs
    The value of XAttr is byte[], this class is to covert byte[] to some kind of string representation or convert back.
    XAttrSetFlag - Enum in org.apache.hadoop.fs
     
    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

    YARN_ACL_ENABLE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Are acls enabled.
    YARN_ADMIN_ACL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    ACL of who can be admin of YARN cluster.
    YARN_APP_CONTAINER_LOG_BACKUPS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_APP_CONTAINER_LOG_DIR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The log directory for the containers
    YARN_APP_CONTAINER_LOG_SIZE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_APPLICATION_CLASSPATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    CLASSPATH for YARN applications.
    YARN_AUTHORIZATION_PROVIDER - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_CLIENT_APP_SUBMISSION_POLL_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Deprecated.
    YARN_CLIENT_APPLICATION_CLIENT_PROTOCOL_POLL_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The interval that the yarn client library uses to poll the completion status of the asynchronous API of application client protocol.
    YARN_CLIENT_APPLICATION_CLIENT_PROTOCOL_POLL_TIMEOUT_MS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    The duration that the yarn client library waits, cumulatively across polls, for an expected state change to occur.
    YARN_HTTP_POLICY_DEFAULT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_HTTP_POLICY_KEY - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_INTERMEDIATE_DATA_ENCRYPTION - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Enable/disable intermediate-data encryption at YARN level.
    YARN_LOG_SERVER_URL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_MC_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_MINICLUSTER_CONTROL_RESOURCE_MONITORING - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Whether users are explicitly trying to control resource monitoring configuration for the MiniYARNCluster.
    YARN_MINICLUSTER_FIXED_PORTS - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Whether to use fixed ports with the minicluster.
    YARN_MINICLUSTER_NM_PMEM_MB - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Allow changing the memory for the NodeManager in the MiniYARNCluster
    YARN_MINICLUSTER_USE_RPC - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Whether the NM should use RPC to connect to the RM.
    YARN_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_SECURITY_SERVICE_AUTHORIZATION_APPLICATIONCLIENT_PROTOCOL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_SECURITY_SERVICE_AUTHORIZATION_APPLICATIONHISTORY_PROTOCOL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_SECURITY_SERVICE_AUTHORIZATION_APPLICATIONMASTER_PROTOCOL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_SECURITY_SERVICE_AUTHORIZATION_CONTAINER_MANAGEMENT_PROTOCOL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_SECURITY_SERVICE_AUTHORIZATION_RESOURCE_LOCALIZER - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_SECURITY_SERVICE_AUTHORIZATION_RESOURCEMANAGER_ADMINISTRATION_PROTOCOL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_SECURITY_SERVICE_AUTHORIZATION_RESOURCETRACKER_PROTOCOL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    YARN Service Level Authorization
    YARN_SITE_CONFIGURATION_FILE - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_SSL_CLIENT_HTTPS_NEED_AUTH_DEFAULT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_SSL_SERVER_RESOURCE_DEFAULT - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YARN_TRACKING_URL_GENERATOR - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YarnApplicationAttemptState - Enum in org.apache.hadoop.yarn.api.records
    Enumeration of various states of a RMAppAttempt.
    YarnApplicationState - Enum in org.apache.hadoop.yarn.api.records
    Enumeration of various states of an ApplicationMaster.
    YarnClient - Class in org.apache.hadoop.yarn.client.api
     
    YarnClient(String) - Constructor for class org.apache.hadoop.yarn.client.api.YarnClient
     
    YarnClientApplication - Class in org.apache.hadoop.yarn.client.api
     
    YarnClientApplication(GetNewApplicationResponse, ApplicationSubmissionContext) - Constructor for class org.apache.hadoop.yarn.client.api.YarnClientApplication
     
    YarnClusterMetrics - Class in org.apache.hadoop.yarn.api.records
    YarnClusterMetrics represents cluster metrics.
    YarnClusterMetrics() - Constructor for class org.apache.hadoop.yarn.api.records.YarnClusterMetrics
     
    YarnConfiguration - Class in org.apache.hadoop.yarn.conf
     
    YarnConfiguration() - Constructor for class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YarnConfiguration(Configuration) - Constructor for class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    YarnException - Exception in org.apache.hadoop.yarn.exceptions
    YarnException indicates exceptions from yarn servers.
    YarnException() - Constructor for exception org.apache.hadoop.yarn.exceptions.YarnException
     
    YarnException(String) - Constructor for exception org.apache.hadoop.yarn.exceptions.YarnException
     
    YarnException(Throwable) - Constructor for exception org.apache.hadoop.yarn.exceptions.YarnException
     
    YarnException(String, Throwable) - Constructor for exception org.apache.hadoop.yarn.exceptions.YarnException
     
    YarnUncaughtExceptionHandler - Class in org.apache.hadoop.yarn
    This class is intended to be installed by calling Thread.setDefaultUncaughtExceptionHandler(UncaughtExceptionHandler) In the main entry point.
    YarnUncaughtExceptionHandler() - Constructor for class org.apache.hadoop.yarn.YarnUncaughtExceptionHandler
     

    Z

    ZK_PREFIX - Static variable in interface org.apache.hadoop.registry.client.api.RegistryConstants
    Prefix for zookeeper-specific options: "hadoop.registry.zk."
    ZK_RM_STATE_STORE_PARENT_PATH - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Parent znode path under which ZKRMStateStore will create znodes
    ZK_RM_STATE_STORE_ROOT_NODE_ACL - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
    Root node ACLs for fencing
    ZK_STATE_STORE_PREFIX - Static variable in class org.apache.hadoop.yarn.conf.YarnConfiguration
     
    ZKFCProtocolPB - Interface in org.apache.hadoop.ha.protocolPB
     
    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 Z 

    Copyright © 2015 Apache Software Foundation. All rights reserved.