Modifier and Type | Class and Description |
---|---|
class |
ConfServlet
A servlet to print out the running configuration data.
|
Modifier and Type | Method and Description |
---|---|
String[] |
Configuration.getPropertySources(String name)
Gets information about why a property was set.
|
Modifier and Type | Class and Description |
---|---|
class |
BlockStorageLocation
Wrapper for
BlockLocation that also adds VolumeId volume
location information for each replica. |
class |
BufferedFSInputStream
A class optimizes reading from FSInputStream by bufferring
|
class |
CommonConfigurationKeys
This class contains constants for configuration keys used
in the common code.
|
class |
DelegateToFileSystem
Implementation of AbstractFileSystem based on the existing implementation of
FileSystem . |
class |
FSInputChecker
This is a generic input stream for verifying checksums for
data before it is read by a user.
|
class |
FSInputStream
FSInputStream is a generic old InputStream with a little bit
of RAF-style seek ability.
|
class |
FSOutputSummer
This is a generic output stream for generating checksums for
data before it is written to the underlying stream
|
class |
FsShellPermissions
This class is the home for file permissions related commands.
|
class |
FsUrlStreamHandlerFactory
Factory for URL stream handlers.
|
class |
HdfsBlockLocation
Wrapper for
BlockLocation that also includes a LocatedBlock ,
allowing more detailed queries to the datanode about a block. |
class |
HdfsVolumeId
HDFS-specific volume identifier which implements
VolumeId . |
class |
LocalDirAllocator
An implementation of a round-robin scheme for disk allocation for creating
files.
|
class |
LocalFileSystemConfigKeys
This class contains constants for configuration keys used
in the local file system, raw local fs and checksum fs.
|
class |
MD5MD5CRC32FileChecksum
MD5 of MD5 of CRC32.
|
interface |
VolumeId
Opaque interface that identifies a disk location.
|
Modifier and Type | Method and Description |
---|---|
AbstractFileSystem |
FileContext.getDefaultFileSystem() |
Modifier and Type | Class and Description |
---|---|
class |
FtpConfigKeys
This class contains constants for configuration keys used
in the ftp file system.
|
class |
FTPInputStream |
Modifier and Type | Class and Description |
---|---|
class |
LocalConfigKeys
This class contains constants for configuration keys used
in the local file system, raw local fs and checksum fs.
|
Modifier and Type | Class and Description |
---|---|
class |
ChmodParser
Parse a permission mode passed in from a chmod command and apply that
mode against an existing file.
|
class |
FsAction
File system actions, e.g.
|
class |
PermissionStatus
Store permission related information.
|
Modifier and Type | Class and Description |
---|---|
class |
Block
Holds metadata about a block of data being stored in a
FileSystemStore . |
interface |
FileSystemStore
|
class |
INode
Holds file metadata including type (regular file, or directory),
and the list of blocks that are pointers to the data.
|
class |
MigrationTool
This class is a tool for migrating data from an older to a newer version
of an S3 filesystem.
|
class |
S3Credentials
Extracts AWS credentials from the filesystem URI or configuration.
|
class |
S3FileSystemConfigKeys
This class contains constants for configuration keys used
in the s3 file system.
|
Modifier and Type | Class and Description |
---|---|
class |
S3NativeFileSystemConfigKeys
This class contains constants for configuration keys used
in the s3 file system.
|
Modifier and Type | Class and Description |
---|---|
class |
CommandFactory
class to search for and register commands
|
class |
PathData
Encapsulates a Path (path), its FileStatus (stat), and its FileSystem (fs).
|
Modifier and Type | Interface and Description |
---|---|
interface |
FenceMethod
A fencing method is a method by which one node can forcibly prevent
another node from making continued progress.
|
Modifier and Type | Class and Description |
---|---|
class |
DistributedFileSystem
Implementation of the abstract FileSystem for the DFS system.
|
Modifier and Type | Method and Description |
---|---|
BlockStorageLocation[] |
DistributedFileSystem.getFileBlockStorageLocations(List<BlockLocation> blocks)
Used to query storage location information for a list of blocks.
|
Modifier and Type | Class and Description |
---|---|
class |
HdfsBlocksMetadata
Augments an array of blocks on a datanode with additional information about
where the block is stored.
|
Modifier and Type | Class and Description |
---|---|
class |
FSEditLogOp
Helper classes for reading the ops from an InputStream.
|
class |
FSEditLogOpCodes
Op codes for edits file
|
Modifier and Type | Class and Description |
---|---|
class |
BinaryEditsVisitor
BinaryEditsVisitor implements a binary EditsVisitor
|
class |
OfflineEditsViewer
This class implements an offline edits viewer, tool that
can be used to view edit logs.
|
interface |
OfflineEditsVisitor
An implementation of OfflineEditsVisitor can traverse the structure of an
Hadoop edits log and respond to each of the structures within the file.
|
class |
OfflineEditsVisitorFactory
EditsVisitorFactory for different implementations of EditsVisitor
|
class |
StatisticsEditsVisitor
StatisticsEditsVisitor implements text version of EditsVisitor
that aggregates counts of op codes processed
|
class |
XmlEditsVisitor
An XmlEditsVisitor walks over an EditLog structure and writes out
an equivalent XML document that contains the EditLog's components.
|
Modifier and Type | Class and Description |
---|---|
class |
DepthCounter
Utility class for tracking descent into the structure of the
Visitor class (ImageVisitor, EditsVisitor etc.)
|
Modifier and Type | Class and Description |
---|---|
class |
CyclicIteration<K,V>
Provide an cyclic
Iterator for a NavigableMap . |
class |
XMLUtils
General xml utilities.
|
Modifier and Type | Class and Description |
---|---|
class |
URLUtils
Utilities for handling URLs
|
Modifier and Type | Class and Description |
---|---|
class |
HttpConfig
Singleton to get access to Http related configuration.
|
Modifier and Type | Class and Description |
---|---|
class |
BoundedByteArrayOutputStream
A byte array backed output stream with a limit.
|
class |
DataInputBuffer
A reusable
DataInput implementation that reads from an in-memory
buffer. |
class |
DataOutputBuffer
A reusable
DataOutput implementation that writes to an in-memory
buffer. |
class |
DataOutputOutputStream
OutputStream implementation that wraps a DataOutput.
|
class |
InputBuffer
A reusable
InputStream implementation that reads from an in-memory
buffer. |
class |
OutputBuffer
A reusable
OutputStream implementation that writes to an in-memory
buffer. |
Modifier and Type | Class and Description |
---|---|
class |
ByteArray
Adaptor class to wrap byte-array backed objects (including java byte array)
as RawComparable objects.
|
Modifier and Type | Class and Description |
---|---|
class |
NativeIO
JNI wrappers for various native IO-related calls not available in Java.
|
Modifier and Type | Class and Description |
---|---|
class |
JavaSerialization
An experimental
Serialization for Java Serializable classes. |
class |
JavaSerializationComparator<T extends Serializable & Comparable<T>>
A
RawComparator that uses a JavaSerialization
Deserializer to deserialize objects that are then compared via
their Comparable interfaces. |
Modifier and Type | Class and Description |
---|---|
static class |
LogLevel.Servlet
A servlet implementation
|
Modifier and Type | Class and Description |
---|---|
class |
BackupStore<K,V>
BackupStore is an utility class that is used to support
the mark-reset functionality of values iterator |
class |
IFile
IFile is the simple |
static class |
IFile.Reader<K,V>
IFile.Reader to read intermediate map-outputs. |
static class |
IFile.Writer<K,V>
IFile.Writer to write out intermediate map-outputs. |
class |
IFileInputStream
A checksum input stream, used for IFiles.
|
class |
IFileOutputStream
A Checksum output stream.
|
class |
IndexRecord |
class |
JobContextImpl |
class |
JobEndNotifier |
class |
JobInProgress |
class |
JobProfile
A JobProfile is a MapReduce primitive.
|
class |
JvmTask
Task abstraction that can be serialized, implements the writable interface.
|
class |
LineRecordReader
Treats keys as offset in file and value as line.
|
class |
LocalJobRunner
Implements MapReduce locally, in-process, for debugging.
|
interface |
MapOutputCollector<K,V> |
static class |
MapOutputCollector.Context |
class |
MapOutputFile
Manipulate the working area for the transient store for maps and reduces.
|
class |
MapTask
A Map task.
|
static class |
MapTask.MapOutputBuffer<K,V> |
class |
MapTaskCompletionEventsUpdate
A class that represents the communication between the tasktracker and child
tasks w.r.t the map task completion events.
|
class |
Master |
class |
Merger
Merger is an utility class used by the Map and Reduce tasks for merging
both their memory and disk segments
|
static class |
Merger.Segment<K,V> |
interface |
MRConstants
Some handy constants
|
class |
MROutputFiles
Manipulate the working area for the transient store for maps and reduces.
|
class |
PeriodicStatsAccumulator
This abstract class that represents a bucketed series of
measurements of a quantity being measured in a running task
attempt.
|
class |
ProgressSplitsBlock |
interface |
RawKeyValueIterator
RawKeyValueIterator is an iterator used to iterate over
the raw keys and values during sort/merge of intermediate data. |
class |
ReduceTask
A Reduce task.
|
interface |
ShuffleConsumerPlugin<K,V>
ShuffleConsumerPlugin for serving Reducers.
|
static class |
ShuffleConsumerPlugin.Context<K,V> |
class |
SpillRecord |
class |
Task
Base class for tasks.
|
static class |
Task.CombineOutputCollector<K,V>
OutputCollector for the combiner.
|
static class |
Task.CombinerRunner<K,V> |
static class |
Task.CombineValuesIterator<KEY,VALUE>
Iterator to return Combined values
|
protected static class |
Task.NewCombinerRunner<K,V> |
protected static class |
Task.OldCombinerRunner<K,V> |
class |
Task.TaskReporter |
class |
TaskAttemptContextImpl |
class |
TaskLogAppender
A simple log4j-appender for the task child's
map-reduce system logs.
|
class |
TaskStatus
Describes the current status of a task.
|
static class |
TaskStatus.Phase |
static class |
TaskStatus.State |
class |
TIPStatus
The states of a Tasks.
|
class |
YarnOutputFiles
Manipulate the working area for the transient store for maps and reduces.
|
Modifier and Type | Class and Description |
---|---|
class |
DelegatingInputFormat<K,V>
An
InputFormat that delegates behaviour of paths to multiple other
InputFormats. |
class |
DelegatingMapper<K1,V1,K2,V2>
An
Mapper that delegates behaviour of paths to multiple other
mappers. |
Modifier and Type | Class and Description |
---|---|
class |
AMStartedEvent
Event to record start of a task attempt
|
class |
EventReader |
interface |
HistoryEvent
Interface for event wrapper classes.
|
class |
HistoryViewer
HistoryViewer is used to parse and view the JobHistory files
|
class |
JobFinishedEvent
Event to record successful completion of job
|
class |
JobHistoryParser
Default Parser for the JobHistory files.
|
class |
JobInfoChangeEvent
Event to record changes in the submit and launch time of
a job
|
class |
JobInitedEvent
Event to record the initialization of a job
|
class |
JobPriorityChangeEvent
Event to record the change of priority of a job
|
class |
JobStatusChangedEvent
Event to record the change of status for a job
|
class |
JobSubmittedEvent
Event to record the submission of a job
|
class |
JobUnsuccessfulCompletionEvent
Event to record Failed and Killed completion of jobs
|
class |
MapAttemptFinishedEvent
Event to record successful completion of a map attempt
|
class |
NormalizedResourceEvent
Event to record the normalized map/reduce requirements.
|
class |
ReduceAttemptFinishedEvent
Event to record successful completion of a reduce attempt
|
class |
TaskAttemptFinishedEvent
Event to record successful task completion
|
class |
TaskAttemptStartedEvent
Event to record start of a task attempt
|
class |
TaskAttemptUnsuccessfulCompletionEvent
Event to record unsuccessful (Killed/Failed) completion of task attempts
|
class |
TaskFailedEvent
Event to record the failure of a task
|
class |
TaskFinishedEvent
Event to record the successful completion of a task
|
class |
TaskStartedEvent
Event to record the start of a task
|
class |
TaskUpdatedEvent
Event to record updates to a task
|
Modifier and Type | Class and Description |
---|---|
class |
Chain
The Chain class provides all the common functionality for the
ChainMapper and the ChainReducer classes. |
Modifier and Type | Class and Description |
---|---|
class |
DelegatingInputFormat<K,V>
An
InputFormat that delegates behavior of paths to multiple other
InputFormats. |
class |
DelegatingMapper<K1,V1,K2,V2>
An
Mapper that delegates behavior of paths to multiple other
mappers. |
class |
DelegatingRecordReader<K,V>
This is a delegating RecordReader, which delegates the functionality to the
underlying record reader in
TaggedInputSplit |
Modifier and Type | Class and Description |
---|---|
class |
SecureShuffleUtils
utilities for generating kyes, hashes and verifying them for shuffle
|
Modifier and Type | Class and Description |
---|---|
class |
JobTokenIdentifier
The token identifier for job token
|
class |
JobTokenSecretManager
SecretManager for job token.
|
class |
JobTokenSelector
Look through tokens to find the first job token that matches the service
and return it.
|
Modifier and Type | Class and Description |
---|---|
class |
DelegationTokenIdentifier
A delegation token identifier that is specific to MapReduce.
|
class |
DelegationTokenSecretManager
A MapReduce specific delegation token secret manager.
|
class |
DelegationTokenSelector
A delegation token that is specialized for MapReduce
|
Modifier and Type | Class and Description |
---|---|
class |
JobSplit
This class groups the fundamental classes associated with
reading/writing splits.
|
class |
JobSplitWriter
The class that is used by the Job clients to write splits (both the meta
and the raw bytes parts)
|
class |
SplitMetaInfoReader
A utility that reads the split meta info and creates
split meta info objects
|
Modifier and Type | Class and Description |
---|---|
class |
JobContextImpl
A read-only view of the job that is provided to the tasks while they
are running.
|
class |
MapContextImpl<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
The context that is given to the
Mapper . |
class |
ReduceContextImpl<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
The context passed to the
Reducer . |
class |
TaskAttemptContextImpl
The context for task attempts.
|
class |
TaskInputOutputContextImpl<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
A context object that allows input and output from the task.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ExceptionReporter
An interface for reporting exceptions to other threads
|
class |
InMemoryReader<K,V>
IFile.InMemoryReader to read map-outputs present in-memory. |
class |
InMemoryWriter<K,V> |
class |
MapHost |
class |
MapOutput<K,V> |
interface |
MergeManager<K,V>
An interface for a reduce side merge that works with the default Shuffle
implementation.
|
class |
MergeManagerImpl<K,V> |
class |
Shuffle<K,V> |
class |
ShuffleClientMetrics |
interface |
ShuffleScheduler<K,V> |
class |
ShuffleSchedulerImpl<K,V> |
Modifier and Type | Class and Description |
---|---|
class |
ConfigUtil
Place holder for deprecated keys in the framework
|
class |
HostUtil |
class |
ProcessTree
Process tree related operations
|
Modifier and Type | Class and Description |
---|---|
class |
ClientHSPolicyProvider
PolicyProvider for YARN MapReduce protocols. |
class |
MRAMPolicyProvider
PolicyProvider for YARN MapReduce protocols. |
Modifier and Type | Class and Description |
---|---|
class |
HistoryFileManager
This class provides a way to interact with history files in a thread safe
manor.
|
interface |
HistoryStorage
Provides an API to query jobs that have finished.
|
class |
JHSDelegationTokenSecretManager
A MapReduce specific delegation token secret manager.
|
Modifier and Type | Class and Description |
---|---|
class |
JobHistoryUtils |
Modifier and Type | Class and Description |
---|---|
class |
MRApps
Helper class for MR applications
|
Modifier and Type | Class and Description |
---|---|
class |
DNS
A class that provides direct and reverse lookup functionalities, allowing
the querying of specific network interfaces or nameservers.
|
class |
NetUtils |
class |
NetworkTopology
The class represents a cluster of computer with a tree hierarchical
network topology.
|
class |
NetworkTopologyWithNodeGroup
The class extends NetworkTopology to represents a cluster of computer with
a 4-layers hierarchical network topology.
|
interface |
Node
The interface defines a node in a network topology.
|
class |
NodeBase
A base class that implements interface Node
|
class |
SocketInputWrapper
A wrapper stream around a socket which allows setting of its timeout.
|
class |
SocketOutputStream
This implements an output stream that can have a timeout while writing.
|
Modifier and Type | Class and Description |
---|---|
class |
NetgroupCache
Class that caches the netgroups and inverts group-to-user map
to user-to-group map, primarily intented for use with
netgroups (as returned by getent netgrgoup) which only returns
group to user mapping.
|
Modifier and Type | Field and Description |
---|---|
SaslRpcServer.AuthMethod |
SaslRpcServer.authMethod |
Modifier and Type | Method and Description |
---|---|
SaslServer |
SaslRpcServer.create(Server.Connection connection,
SecretManager<TokenIdentifier> secretManager) |
static void |
UserGroupInformation.setLoginUser(UserGroupInformation ugi) |
Constructor and Description |
---|
SaslRpcServer(SaslRpcServer.AuthMethod authMethod) |
Modifier and Type | Class and Description |
---|---|
static class |
Token.PrivateToken<T extends TokenIdentifier>
Indicates whether the token is a clone.
|
Modifier and Type | Class and Description |
---|---|
class |
AsyncDiskService |
class |
Daemon
A thread that has called
Thread.setDaemon(boolean) with true. |
class |
DiskChecker
Class that provides utility functions for checking disk problem
|
class |
ExitUtil
Facilitates hooking process termination for tests and debugging.
|
class |
GenericsUtil
Contains utility methods for dealing with Java Generics.
|
class |
HeapSort
An implementation of the core algorithm of HeapSort.
|
class |
HostsFileReader |
interface |
IndexedSortable
Interface for collections capable of being sorted by
IndexedSorter
algorithms. |
interface |
IndexedSorter
Interface for sort algorithms accepting
IndexedSortable items. |
class |
LineReader
A class that provides a line reader from an input stream.
|
class |
MergeSort
An implementation of the core algorithm of MergeSort.
|
class |
NativeCodeLoader
A helper to load the native hadoop code i.e.
|
class |
NativeLibraryChecker |
class |
PlatformName
A helper class for getting build-info of the java-vm.
|
class |
PrintJarMainClass
A micro-application that prints the main class name out of a jar file.
|
class |
PriorityQueue<T>
A PriorityQueue maintains a partial ordering of its elements such that the
least element can always be found in constant time.
|
class |
ProgramDriver
A driver that is used to run programs added to it
|
class |
Progress
Utility to assist with generation of progress reports.
|
class |
QuickSort
An implementation of the core algorithm of QuickSort.
|
class |
RunJar
Run a Hadoop job jar.
|
interface |
ServicePlugin
Service plug-in interface.
|
class |
ServletUtil |
class |
Shell
A base class for running a Unix command.
|
class |
SignalLogger
This class logs a message whenever we're about to exit on a UNIX signal.
|
class |
StringUtils
General string utils
|
class |
Time
Utility methods for getting the time and computing intervals.
|
class |
UTF8ByteArrayUtils |
class |
VersionInfo
This class returns build information about Hadoop components.
|
class |
XMLUtils
General xml utilities.
|
Modifier and Type | Class and Description |
---|---|
class |
Filter
Defines the general behavior of a filter.
|
class |
Key
The general behavior of a key that must be stored in a filter.
|
Modifier and Type | Class and Description |
---|---|
class |
Hash
This class represents a common API for hashing functions.
|
class |
JenkinsHash
Produces 32-bit hash for hash table lookup.
|
class |
MurmurHash
This is a very fast, non-cryptographic hash suitable for general hash-based
lookup.
|
Modifier and Type | Class and Description |
---|---|
class |
ContainerLogAppender
A simple log4j-appender for container's logs.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ApplicationClientProtocolPB |
interface |
ApplicationMasterProtocolPB |
interface |
ContainerManagementProtocolPB |
Modifier and Type | Method and Description |
---|---|
CancelDelegationTokenResponse |
ApplicationClientProtocol.cancelDelegationToken(CancelDelegationTokenRequest request)
Cancel an existing delegation
Token . |
RenewDelegationTokenResponse |
ApplicationClientProtocol.renewDelegationToken(RenewDelegationTokenRequest request)
Renew an existing delegation
Token . |
Modifier and Type | Class and Description |
---|---|
class |
CancelDelegationTokenRequest
The request issued by the client to the
ResourceManager to cancel a
delegation token. |
class |
CancelDelegationTokenResponse
The response from the
ResourceManager to a cancelDelegationToken
request. |
class |
RenewDelegationTokenRequest
The request issued by the client to renew a delegation token from
the
ResourceManager . |
class |
RenewDelegationTokenResponse
The response to a renewDelegationToken call to the
ResourceManager . |
Modifier and Type | Method and Description |
---|---|
abstract Token |
RenewDelegationTokenRequest.getDelegationToken()
Get the delegation token requested to be renewed by the client.
|
abstract Token |
CancelDelegationTokenRequest.getDelegationToken()
Get the delegation token requested to be cancelled.
|
abstract long |
RenewDelegationTokenResponse.getNextExpirationTime() |
static KillApplicationResponse |
KillApplicationResponse.newInstance() |
static CancelDelegationTokenResponse |
CancelDelegationTokenResponse.newInstance() |
static SubmitApplicationResponse |
SubmitApplicationResponse.newInstance() |
static GetNewApplicationResponse |
GetNewApplicationResponse.newInstance(ApplicationId applicationId,
Resource minCapability,
Resource maxCapability) |
static GetApplicationReportResponse |
GetApplicationReportResponse.newInstance(ApplicationReport ApplicationReport) |
static FinishApplicationMasterResponse |
FinishApplicationMasterResponse.newInstance(boolean isRemovedFromRMStateStore) |
static GetApplicationsResponse |
GetApplicationsResponse.newInstance(List<ApplicationReport> applications) |
static StopContainersResponse |
StopContainersResponse.newInstance(List<ContainerId> succeededRequests,
Map<ContainerId,SerializedException> failedRequests) |
static GetContainerStatusesResponse |
GetContainerStatusesResponse.newInstance(List<ContainerStatus> statuses,
Map<ContainerId,SerializedException> failedRequests) |
static GetClusterNodesResponse |
GetClusterNodesResponse.newInstance(List<NodeReport> nodeReports) |
static GetQueueUserAclsInfoResponse |
GetQueueUserAclsInfoResponse.newInstance(List<QueueUserACLInfo> queueUserAclsList) |
static RenewDelegationTokenResponse |
RenewDelegationTokenResponse.newInstance(long expTime) |
static StartContainersResponse |
StartContainersResponse.newInstance(Map<String,ByteBuffer> servicesMetaData,
List<ContainerId> succeededContainers,
Map<ContainerId,SerializedException> failedContainers) |
static GetQueueInfoResponse |
GetQueueInfoResponse.newInstance(QueueInfo queueInfo) |
static RegisterApplicationMasterResponse |
RegisterApplicationMasterResponse.newInstance(Resource minCapability,
Resource maxCapability,
Map<ApplicationAccessType,String> acls,
ByteBuffer key) |
static RenewDelegationTokenRequest |
RenewDelegationTokenRequest.newInstance(Token dToken) |
static GetDelegationTokenResponse |
GetDelegationTokenResponse.newInstance(Token rmDTToken) |
static CancelDelegationTokenRequest |
CancelDelegationTokenRequest.newInstance(Token dToken) |
static GetClusterMetricsResponse |
GetClusterMetricsResponse.newInstance(YarnClusterMetrics metrics) |
abstract void |
AllocateResponse.setAllocatedContainers(List<Container> containers)
Set the list of newly allocated
Container by the
ResourceManager . |
abstract void |
StartContainersResponse.setAllServicesMetaData(Map<String,ByteBuffer> allServicesMetaData)
Set to the list of auxiliary services which have been started on the
NodeManager . |
abstract void |
AllocateResponse.setAMCommand(AMCommand command) |
abstract void |
RegisterApplicationMasterResponse.setApplicationACLs(Map<ApplicationAccessType,String> acls)
Set the
ApplicationACL s for the application. |
abstract void |
GetNewApplicationResponse.setApplicationId(ApplicationId applicationId) |
abstract void |
GetApplicationsResponse.setApplicationList(List<ApplicationReport> applications) |
abstract void |
GetApplicationReportResponse.setApplicationReport(ApplicationReport ApplicationReport) |
abstract void |
GetApplicationsRequest.setApplicationStates(EnumSet<YarnApplicationState> applicationStates)
Set the application states to filter applications on
|
abstract void |
GetApplicationsRequest.setApplicationTypes(Set<String> applicationTypes)
Set the application types to filter applications on
|
abstract void |
AllocateResponse.setAvailableResources(Resource limit) |
abstract void |
GetClusterMetricsResponse.setClusterMetrics(YarnClusterMetrics metrics) |
abstract void |
AllocateResponse.setCompletedContainersStatuses(List<ContainerStatus> containers) |
abstract void |
GetContainerStatusesResponse.setContainerStatuses(List<ContainerStatus> statuses)
Set the
ContainerStatus es of the requested containers. |
abstract void |
RenewDelegationTokenRequest.setDelegationToken(Token dToken) |
abstract void |
CancelDelegationTokenRequest.setDelegationToken(Token dToken) |
abstract void |
StopContainersResponse.setFailedRequests(Map<ContainerId,SerializedException> failedRequests)
Set the containerId-to-exception map in which the exception indicates error
from per container for failed requests
|
abstract void |
StartContainersResponse.setFailedRequests(Map<ContainerId,SerializedException> failedContainers)
Set the containerId-to-exception map in which the exception indicates error
from per container for failed requests
|
abstract void |
GetContainerStatusesResponse.setFailedRequests(Map<ContainerId,SerializedException> failedContainers)
Set the containerId-to-exception map in which the exception indicates error
from per container for failed requests
|
abstract void |
FinishApplicationMasterResponse.setIsUnregistered(boolean isUnregistered)
Set the flag which indicates that the application has successfully
unregistered with the RM and the application can safely stop.
|
abstract void |
GetNewApplicationResponse.setMaximumResourceCapability(Resource capability) |
abstract void |
RegisterApplicationMasterResponse.setMaximumResourceCapability(Resource capability) |
abstract void |
RenewDelegationTokenResponse.setNextExpirationTime(long expTime) |
abstract void |
AllocateResponse.setNMTokens(List<NMToken> nmTokens) |
abstract void |
GetClusterNodesResponse.setNodeReports(List<NodeReport> nodeReports) |
abstract void |
AllocateResponse.setNumClusterNodes(int numNodes) |
abstract void |
AllocateResponse.setPreemptionMessage(PreemptionMessage request) |
abstract void |
GetQueueInfoResponse.setQueueInfo(QueueInfo queueInfo) |
abstract void |
AllocateResponse.setResponseId(int responseId) |
abstract void |
GetDelegationTokenResponse.setRMDelegationToken(Token rmDTToken) |
abstract void |
StartContainersResponse.setSuccessfullyStartedContainers(List<ContainerId> succeededContainers) |
abstract void |
StopContainersResponse.setSuccessfullyStoppedContainers(List<ContainerId> succeededRequests)
Set the list of containerIds of successfully stopped containers.
|
abstract void |
AllocateResponse.setUpdatedNodes(List<NodeReport> updatedNodes) |
abstract void |
GetQueueUserAclsInfoResponse.setUserAclsInfoList(List<QueueUserACLInfo> queueUserAclsList) |
Modifier and Type | Class and Description |
---|---|
class |
AMCommand
Command sent by the Resource Manager to the Application Master in the
AllocateResponse
|
class |
ContainerExitStatus
Container exit statuses indicating special exit circumstances.
|
class |
NodeState
State of a
Node . |
class |
SerializedException |
Modifier and Type | Field and Description |
---|---|
static String |
ApplicationAttemptId.appAttemptIdStrPrefix |
static String |
ApplicationId.appIdStrPrefix |
Modifier and Type | Method and Description |
---|---|
abstract Throwable |
SerializedException.deSerialize()
Deserialize the exception to a new Throwable.
|
abstract boolean |
ApplicationSubmissionContext.getCancelTokensWhenComplete() |
abstract SerializedException |
SerializedException.getCause()
Get the cause of this exception or null if the cause is nonexistent or
unknown.
|
abstract int |
ContainerStatus.getExitStatus()
Get the exit status for the container.
|
abstract String |
SerializedException.getMessage()
Get the detail message string of this exception.
|
abstract int |
NodeReport.getNumContainers()
Get the number of allocated containers on the node.
|
abstract int |
ApplicationResourceUsageReport.getNumReservedContainers()
Get the number of reserved containers
|
abstract String |
ApplicationReport.getOriginalTrackingUrl()
Get the original not-proxied tracking url for the application.
|
abstract String |
SerializedException.getRemoteTrace()
Get the backtrace of this exception.
|
abstract void |
SerializedException.init(String message)
Constructs a new
SerializedException with the specified detail
message. |
abstract void |
SerializedException.init(String message,
Throwable cause)
Constructs a new
SerializedException with the specified detail
message and cause. |
abstract void |
SerializedException.init(Throwable cause)
Constructs a new
SerializedException with the specified cause. |
static ContainerId |
ContainerId.newInstance(ApplicationAttemptId appAttemptId,
int containerId) |
static ApplicationReport |
ApplicationReport.newInstance(ApplicationId applicationId,
ApplicationAttemptId applicationAttemptId,
String user,
String queue,
String name,
String host,
int rpcPort,
Token clientToAMToken,
YarnApplicationState state,
String diagnostics,
String url,
long startTime,
long finishTime,
FinalApplicationStatus finalStatus,
ApplicationResourceUsageReport appResources,
String origTrackingUrl,
float progress,
String applicationType,
Token amRmToken) |
static ApplicationAttemptId |
ApplicationAttemptId.newInstance(ApplicationId appId,
int attemptId) |
static Token |
Token.newInstance(byte[] identifier,
String kind,
byte[] password,
String service) |
static PreemptionContainer |
PreemptionContainer.newInstance(ContainerId id) |
static ContainerStatus |
ContainerStatus.newInstance(ContainerId containerId,
ContainerState containerState,
String diagnostics,
int exitStatus) |
static Container |
Container.newInstance(ContainerId containerId,
NodeId nodeId,
String nodeHttpAddress,
Resource resource,
Priority priority,
Token containerToken) |
static YarnClusterMetrics |
YarnClusterMetrics.newInstance(int numNodeManagers) |
static ApplicationResourceUsageReport |
ApplicationResourceUsageReport.newInstance(int numUsedContainers,
int numReservedContainers,
Resource usedResources,
Resource reservedResources,
Resource neededResources) |
static PreemptionContract |
PreemptionContract.newInstance(List<PreemptionResourceRequest> req,
Set<PreemptionContainer> containers) |
static ApplicationId |
ApplicationId.newInstance(long clusterTimestamp,
int id) |
static NodeReport |
NodeReport.newInstance(NodeId nodeId,
NodeState nodeState,
String httpAddress,
String rackName,
Resource used,
Resource capability,
int numContainers,
String healthReport,
long lastHealthReportTime) |
static NMToken |
NMToken.newInstance(NodeId nodeId,
Token token) |
static PreemptionResourceRequest |
PreemptionResourceRequest.newInstance(ResourceRequest req) |
static StrictPreemptionContract |
StrictPreemptionContract.newInstance(Set<PreemptionContainer> containers) |
static PreemptionMessage |
PreemptionMessage.newInstance(StrictPreemptionContract set,
PreemptionContract contract) |
static QueueInfo |
QueueInfo.newInstance(String queueName,
float capacity,
float maximumCapacity,
float currentCapacity,
List<QueueInfo> childQueues,
List<ApplicationReport> applications,
QueueState queueState) |
static NodeId |
NodeId.newInstance(String host,
int port) |
static QueueUserACLInfo |
QueueUserACLInfo.newInstance(String queueName,
List<QueueACL> acls) |
static SerializedException |
SerializedException.newInstance(Throwable e) |
protected abstract void |
ContainerId.setApplicationAttemptId(ApplicationAttemptId atId) |
abstract void |
ApplicationReport.setApplicationId(ApplicationId applicationId) |
protected abstract void |
ApplicationAttemptId.setApplicationId(ApplicationId appID) |
abstract void |
ApplicationReport.setApplicationResourceUsageReport(ApplicationResourceUsageReport appResources)
Store the structure containing the job resources for this application
|
abstract void |
QueueInfo.setApplications(List<ApplicationReport> applications) |
abstract void |
ApplicationReport.setApplicationType(String applicationType) |
protected abstract void |
ApplicationAttemptId.setAttemptId(int attemptId) |
abstract void |
ApplicationSubmissionContext.setCancelTokensWhenComplete(boolean cancel)
Set to false if tokens should not be canceled when the app finished else
false.
|
abstract void |
NodeReport.setCapability(Resource capability) |
abstract void |
QueueInfo.setCapacity(float capacity) |
abstract void |
QueueInfo.setChildQueues(List<QueueInfo> childQueues) |
abstract void |
ApplicationReport.setClientToAMToken(Token clientToAMToken) |
protected abstract void |
ApplicationId.setClusterTimestamp(long clusterTimestamp) |
abstract void |
ContainerStatus.setContainerId(ContainerId containerId) |
abstract void |
PreemptionContract.setContainers(Set<PreemptionContainer> containers) |
abstract void |
StrictPreemptionContract.setContainers(Set<PreemptionContainer> containers) |
abstract void |
Container.setContainerToken(Token containerToken) |
abstract void |
PreemptionMessage.setContract(PreemptionContract contract) |
abstract void |
ApplicationReport.setCurrentApplicationAttemptId(ApplicationAttemptId applicationAttemptId) |
abstract void |
QueueInfo.setCurrentCapacity(float currentCapacity) |
abstract void |
ApplicationReport.setDiagnostics(String diagnostics) |
abstract void |
ContainerStatus.setDiagnostics(String diagnostics) |
abstract void |
ContainerStatus.setExitStatus(int exitStatus) |
abstract void |
ApplicationReport.setFinalApplicationStatus(FinalApplicationStatus finishState) |
abstract void |
ApplicationReport.setFinishTime(long finishTime) |
abstract void |
NodeReport.setHealthReport(String healthReport) |
abstract void |
ApplicationReport.setHost(String host) |
protected abstract void |
NodeId.setHost(String host) |
abstract void |
NodeReport.setHttpAddress(String httpAddress) |
abstract void |
Container.setId(ContainerId id) |
abstract void |
PreemptionContainer.setId(ContainerId id) |
protected abstract void |
ApplicationId.setId(int id) |
protected abstract void |
ContainerId.setId(int id) |
abstract void |
Token.setIdentifier(ByteBuffer identifier) |
abstract void |
Token.setKind(String kind) |
abstract void |
NodeReport.setLastHealthReportTime(long lastHealthReport) |
abstract void |
QueueInfo.setMaximumCapacity(float maximumCapacity) |
abstract void |
ApplicationReport.setName(String name) |
abstract void |
ApplicationResourceUsageReport.setNeededResources(Resource needed_resources) |
abstract void |
Container.setNodeHttpAddress(String nodeHttpAddress) |
abstract void |
NodeReport.setNodeId(NodeId nodeId) |
abstract void |
Container.setNodeId(NodeId nodeId) |
abstract void |
NodeReport.setNodeState(NodeState nodeState) |
abstract void |
NodeReport.setNumContainers(int numContainers) |
abstract void |
YarnClusterMetrics.setNumNodeManagers(int numNodeManagers) |
abstract void |
ApplicationResourceUsageReport.setNumReservedContainers(int num_reserved_containers)
Set the number of reserved containers
|
abstract void |
ApplicationResourceUsageReport.setNumUsedContainers(int num_containers)
Set the number of used containers
|
abstract void |
ApplicationReport.setOriginalTrackingUrl(String url) |
abstract void |
Token.setPassword(ByteBuffer password) |
protected abstract void |
NodeId.setPort(int port) |
abstract void |
ApplicationSubmissionContext.setPriority(Priority priority)
Set the
Priority of the application. |
abstract void |
Container.setPriority(Priority priority) |
abstract void |
ApplicationReport.setProgress(float progress) |
abstract void |
ApplicationReport.setQueue(String queue) |
abstract void |
QueueUserACLInfo.setQueueName(String queueName) |
abstract void |
QueueInfo.setQueueName(String queueName) |
abstract void |
QueueInfo.setQueueState(QueueState queueState) |
abstract void |
NodeReport.setRackName(String rackName) |
abstract void |
ApplicationResourceUsageReport.setReservedResources(Resource reserved_resources) |
abstract void |
Container.setResource(Resource resource) |
abstract void |
PreemptionContract.setResourceRequest(List<PreemptionResourceRequest> req) |
abstract void |
PreemptionResourceRequest.setResourceRequest(ResourceRequest req) |
abstract void |
ApplicationReport.setRpcPort(int rpcPort) |
abstract void |
Token.setService(String service) |
abstract void |
ApplicationReport.setStartTime(long startTime) |
abstract void |
ContainerStatus.setState(ContainerState state) |
abstract void |
PreemptionMessage.setStrictContract(StrictPreemptionContract set) |
abstract void |
ApplicationReport.setTrackingUrl(String url) |
abstract void |
NodeReport.setUsed(Resource used) |
abstract void |
ApplicationResourceUsageReport.setUsedResources(Resource resources) |
abstract void |
ApplicationReport.setUser(String user) |
abstract void |
QueueUserACLInfo.setUserAcls(List<QueueACL> acls) |
abstract void |
ApplicationReport.setYarnApplicationState(YarnApplicationState state) |
Modifier and Type | Class and Description |
---|---|
class |
ApplicationAttemptIdPBImpl |
class |
ApplicationIdPBImpl |
class |
ApplicationReportPBImpl |
class |
ApplicationResourceUsageReportPBImpl |
class |
ApplicationSubmissionContextPBImpl |
class |
ContainerIdPBImpl |
class |
ContainerLaunchContextPBImpl |
class |
ContainerPBImpl |
class |
ContainerStatusPBImpl |
class |
LocalResourcePBImpl |
class |
NMTokenPBImpl |
class |
NodeIdPBImpl |
class |
NodeReportPBImpl |
class |
PreemptionContainerPBImpl |
class |
PreemptionContractPBImpl |
class |
PreemptionMessagePBImpl |
class |
PreemptionResourceRequestPBImpl |
class |
PriorityPBImpl |
class |
ProtoBase<T extends com.google.protobuf.Message> |
class |
ProtoUtils |
class |
QueueInfoPBImpl |
class |
QueueUserACLInfoPBImpl |
class |
ResourceBlacklistRequestPBImpl |
class |
ResourcePBImpl |
class |
ResourceRequestPBImpl |
class |
StrictPreemptionContractPBImpl |
class |
TokenPBImpl |
class |
URLPBImpl |
class |
YarnClusterMetricsPBImpl |
Modifier and Type | Class and Description |
---|---|
class |
ApplicationMaster
An ApplicationMaster for executing shell commands on a set of launched
containers using the YARN framework.
|
class |
Client
Client for Distributed Shell application submission to YARN.
|
class |
DSConstants
Constants used in both Client and Application Master
|
Modifier and Type | Class and Description |
---|---|
class |
AMRMClientAsyncImpl<T extends AMRMClient.ContainerRequest> |
class |
NMClientAsyncImpl |
Modifier and Type | Class and Description |
---|---|
class |
AMRMClientImpl<T extends AMRMClient.ContainerRequest> |
class |
NMClientImpl
This class implements
NMClient . |
class |
YarnClientImpl |
Modifier and Type | Class and Description |
---|---|
class |
ApplicationCLI |
class |
NodeCLI |
class |
RMAdminCLI |
class |
YarnCLI |
Modifier and Type | Class and Description |
---|---|
class |
YarnRuntimeException
Base Yarn Exception.
|
Modifier and Type | Interface and Description |
---|---|
interface |
RecordFactory |
Modifier and Type | Class and Description |
---|---|
class |
RecordFactoryProvider |
Modifier and Type | Interface and Description |
---|---|
interface |
ResourceManagerAdministrationProtocolPB |
Constructor and Description |
---|
ApplicationInitializationContext(String user,
ApplicationId applicationId,
ByteBuffer appDataForService) |
ApplicationTerminationContext(ApplicationId applicationId) |
ContainerContext(String user,
ContainerId containerId,
Resource resource) |
ContainerInitializationContext(String user,
ContainerId containerId,
Resource resource) |
ContainerTerminationContext(String user,
ContainerId containerId,
Resource resource) |
Modifier and Type | Method and Description |
---|---|
static RefreshAdminAclsResponse |
RefreshAdminAclsResponse.newInstance() |
static RefreshQueuesResponse |
RefreshQueuesResponse.newInstance() |
static RefreshServiceAclsResponse |
RefreshServiceAclsResponse.newInstance() |
static RefreshUserToGroupsMappingsResponse |
RefreshUserToGroupsMappingsResponse.newInstance() |
static RefreshNodesResponse |
RefreshNodesResponse.newInstance() |
static RefreshSuperUserGroupsConfigurationResponse |
RefreshSuperUserGroupsConfigurationResponse.newInstance() |
Modifier and Type | Class and Description |
---|---|
class |
RefreshAdminAclsRequestPBImpl |
class |
RefreshAdminAclsResponsePBImpl |
class |
RefreshNodesRequestPBImpl |
class |
RefreshNodesResponsePBImpl |
class |
RefreshQueuesRequestPBImpl |
class |
RefreshQueuesResponsePBImpl |
class |
RefreshServiceAclsRequestPBImpl |
class |
RefreshServiceAclsResponsePBImpl |
class |
RefreshSuperUserGroupsConfigurationRequestPBImpl |
class |
RefreshSuperUserGroupsConfigurationResponsePBImpl |
class |
RefreshUserToGroupsMappingsRequestPBImpl |
class |
RefreshUserToGroupsMappingsResponsePBImpl |
Modifier and Type | Method and Description |
---|---|
abstract void |
NodeHealthStatus.setHealthReport(String healthReport) |
abstract void |
NodeHealthStatus.setIsNodeHealthy(boolean isNodeHealthy) |
abstract void |
NodeHealthStatus.setLastHealthReportTime(long lastHealthReport) |
Modifier and Type | Class and Description |
---|---|
class |
NMPolicyProvider
PolicyProvider for YARN NodeManager protocols. |
Modifier and Type | Class and Description |
---|---|
class |
FileSystemRMStateStore |
class |
MemoryRMStateStore |
class |
NullRMStateStore |
class |
RMStateStore |
Modifier and Type | Interface and Description |
---|---|
interface |
ApplicationAttemptStateData |
interface |
ApplicationStateData
Contains all the state data that needs to be stored persistently
for an Application
|
Modifier and Type | Method and Description |
---|---|
ByteBuffer |
ApplicationAttemptStateData.getAppAttemptTokens()
The application attempt tokens that belong to this attempt
|
ApplicationSubmissionContext |
ApplicationStateData.getApplicationSubmissionContext()
The
ApplicationSubmissionContext for the application
ApplicationId can be obtained from the this |
ApplicationAttemptId |
ApplicationAttemptStateData.getAttemptId()
The ApplicationAttemptId for the application attempt
|
Container |
ApplicationAttemptStateData.getMasterContainer() |
long |
ApplicationStateData.getSubmitTime()
The time at which the application was received by the Resource Manager
|
String |
ApplicationStateData.getUser() |
void |
ApplicationStateData.setApplicationSubmissionContext(ApplicationSubmissionContext context) |
void |
ApplicationStateData.setSubmitTime(long submitTime) |
void |
ApplicationStateData.setUser(String user)
The application submitter
|
Modifier and Type | Class and Description |
---|---|
class |
RMNodeImpl
This class is used to keep track of all the applications/containers
running on a node.
|
Modifier and Type | Class and Description |
---|---|
class |
AppSchedulingInfo
This class keeps track of all the consumption of an application.
|
class |
SchedulerApplication
Represents an Application from the viewpoint of the scheduler.
|
class |
SchedulerNode
Represents a YARN Cluster Node from the viewpoint of the scheduler.
|
class |
SchedulerUtils
Utilities shared by schedulers.
|
Modifier and Type | Class and Description |
---|---|
class |
CSAssignment |
class |
LeafQueue |
Modifier and Type | Class and Description |
---|---|
class |
FiCaSchedulerApp
Represents an Application from the viewpoint of the scheduler.
|
Modifier and Type | Class and Description |
---|---|
class |
AllocationConfigurationException
Thrown when the allocation file for
QueueManager is malformed. |
class |
AppSchedulable |
class |
FairScheduler
A scheduler that schedules resources between a set of queues.
|
class |
FifoAppComparator
Order
AppSchedulable objects by priority and then by submit time, as
in the default scheduler in Hadoop. |
class |
FSLeafQueue |
class |
FSParentQueue |
class |
FSQueue |
class |
FSSchedulerApp |
class |
FSSchedulerNode |
class |
NewAppWeightBooster
A
WeightAdjuster implementation that gives a weight boost to new jobs
for a certain amount of time -- by default, a 3x weight boost for 60 seconds. |
class |
QueueManager
Maintains a list of queues as well as scheduling parameters for each queue,
such as guaranteed share allocations, from the fair scheduler config file.
|
class |
Schedulable
A Schedulable represents an entity that can launch tasks, such as a job
or a queue.
|
interface |
WeightAdjuster
A pluggable object for altering the weights of apps in the fair scheduler,
which is used for example by
NewAppWeightBooster to give higher
weight to new jobs so that short jobs finish faster. |
Modifier and Type | Class and Description |
---|---|
class |
DominantResourceFairnessPolicy
Makes scheduling decisions by trying to equalize dominant resource usage.
|
class |
FairSharePolicy
Makes scheduling decisions by trying to equalize shares of memory.
|
class |
FifoPolicy |
Modifier and Type | Class and Description |
---|---|
class |
DelegationTokenRenewer
Service to renew application delegation tokens.
|
class |
RMDelegationTokenSecretManager
A ResourceManager specific delegation token secret manager.
|
Modifier and Type | Class and Description |
---|---|
class |
RMPolicyProvider
PolicyProvider for YARN ResourceManager protocols. |
Modifier and Type | Class and Description |
---|---|
class |
ApplicationClassLoader
A
URLClassLoader for YARN application isolation. |
class |
LinuxResourceCalculatorPlugin
Plugin to calculate resource information on Linux systems.
|
class |
ProcfsBasedProcessTree
A Proc file-system based ProcessTree.
|
class |
Records
Convenient API record utils
|
class |
ResourceCalculatorPlugin
Plugin to calculate resource information on the system.
|
class |
TrackingUriPlugin
Plugin to derive a tracking URL from a Yarn Application ID
|
class |
YarnVersionInfo
This class finds the package info for Yarn.
|
Modifier and Type | Method and Description |
---|---|
static void |
Apps.addToEnvironment(Map<String,String> environment,
String variable,
String value) |
Modifier and Type | Class and Description |
---|---|
class |
DefaultResourceCalculator |
class |
DominantResourceCalculator
A
ResourceCalculator which uses the concept of
dominant resource to compare multi-dimensional resources. |
class |
ResourceCalculator
A set of
Resource comparison and manipulation interfaces. |
class |
Resources |
Copyright © 2013 Apache Software Foundation. All rights reserved.