Package | Description |
---|---|
org.apache.hadoop.mapreduce | |
org.apache.hadoop.mapreduce.v2.api.protocolrecords | |
org.apache.hadoop.yarn.api |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.api.protocolrecords |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.api.records |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
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.api.resource |
API related to resources.
|
org.apache.hadoop.yarn.applications.distributedshell |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.client.api | |
org.apache.hadoop.yarn.client.api.async | |
org.apache.hadoop.yarn.client.api.impl | |
org.apache.hadoop.yarn.exceptions |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.logaggregation |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.logaggregation.filecontroller |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.security |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.security.client |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.service.api.records | |
org.apache.hadoop.yarn.service.client |
Package org.apache.hadoop.yarn.service.client contains classes
for YARN Services Client API.
|
org.apache.hadoop.yarn.util |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.util.timeline |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
Class and Description |
---|
ReservationId
ReservationId represents the globally unique identifier for
a reservation. |
Class and Description |
---|
Token
Token is the security entity used by the framework
to verify authenticity of any resource. |
Class and Description |
---|
ContainerId
ContainerId represents a globally unique identifier
for a Container in the cluster. |
Class and Description |
---|
AMCommand
Command sent by the Resource Manager to the Application Master in the
AllocateResponse
|
ApplicationAccessType
Application access types.
|
ApplicationAttemptId
ApplicationAttemptId denotes the particular attempt
of an ApplicationMaster for a given ApplicationId . |
ApplicationAttemptReport
ApplicationAttemptReport is a report of an application attempt. |
ApplicationId
ApplicationId represents the globally unique
identifier for an application. |
ApplicationReport
ApplicationReport is a report of an application. |
ApplicationSubmissionContext
ApplicationSubmissionContext represents all of the
information needed by the ResourceManager to launch
the ApplicationMaster for an application. |
ApplicationTimeoutType
Application timeout type.
|
CollectorInfo
Collector info containing collector address and collector token passed from
RM to AM in Allocate Response.
|
Container
Container represents an allocated resource in the cluster. |
ContainerId
ContainerId represents a globally unique identifier
for a Container in the cluster. |
ContainerLaunchContext
ContainerLaunchContext represents all of the information
needed by the NodeManager to launch a container. |
ContainerReport
ContainerReport is a report of an container. |
ContainerStatus
ContainerStatus represents the current status of a
Container . |
FinalApplicationStatus
Enumeration of various final states of an
Application . |
LocalizationStatus
Represents the localization status of a resource.
|
LocalResource
LocalResource represents a local resource required to
run a container. |
NMToken
The NMToken is used for authenticating communication with
NodeManager |
NodeAttribute
Node Attribute is a kind of a label which represents one of the
attribute/feature of a Node.
|
NodeAttributeInfo
Node Attribute Info describes a NodeAttribute.
|
NodeAttributeKey
Node AttributeKey uniquely identifies a given Node Attribute.
|
NodeLabel |
NodeReport
NodeReport is a summary of runtime information of a node
in the cluster. |
NodeState
State of a
Node . |
NodeToAttributeValue
Mapping of Attribute Value to a Node.
|
PreemptionMessage
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). |
Priority
The priority assigned to a ResourceRequest or Application or Container
allocation
|
QueueInfo
QueueInfo is a report of the runtime information of the queue.
|
QueueUserACLInfo
QueueUserACLInfo provides information QueueACL for
the given user. |
RejectedSchedulingRequest
This encapsulates a Rejected SchedulingRequest.
|
ReservationAllocationState
ReservationAllocationState represents the reservation that is
made by a user. |
ReservationDefinition
ReservationDefinition captures the set of resource and time
constraints the user cares about regarding a reservation. |
ReservationId
ReservationId represents the globally unique identifier for
a reservation. |
Resource
Resource models a set of computer resources in the
cluster. |
ResourceBlacklistRequest
ResourceBlacklistRequest encapsulates the list of resource-names
which should be added or removed from the blacklist of resources
for the application. |
ResourceRequest
ResourceRequest represents the request made
by an application to the ResourceManager
to obtain various Container allocations. |
SchedulingRequest
SchedulingRequest represents a request made by an application to the
ResourceManager to obtain an allocation. |
SignalContainerCommand
Enumeration of various signal container commands.
|
Token
Token is the security entity used by the framework
to verify authenticity of any resource. |
UpdateContainerError
UpdateContainerError is used by the Scheduler to notify the
ApplicationMaster of an UpdateContainerRequest it cannot satisfy due to
an error in the request. |
UpdateContainerRequest
UpdateContainerRequest represents the request made by an
application to the ResourceManager to update an attribute of a
Container such as its Resource allocation or (@code ExecutionType} |
UpdatedContainer
An object that encapsulates an updated container and the
type of Update.
|
YarnApplicationState
Enumeration of various states of an
ApplicationMaster . |
YarnClusterMetrics
YarnClusterMetrics represents cluster metrics. |
Class and Description |
---|
AMCommand
Command sent by the Resource Manager to the Application Master in the
AllocateResponse
|
ApplicationAccessType
Application access types.
|
ApplicationAttemptId
ApplicationAttemptId denotes the particular attempt
of an ApplicationMaster for a given ApplicationId . |
ApplicationAttemptReport
ApplicationAttemptReport is a report of an application attempt. |
ApplicationId
ApplicationId represents the globally unique
identifier for an application. |
ApplicationReport
ApplicationReport is a report of an application. |
ApplicationResourceUsageReport
Contains various scheduling metrics to be reported by UI and CLI.
|
ApplicationSubmissionContext
ApplicationSubmissionContext represents all of the
information needed by the ResourceManager to launch
the ApplicationMaster for an application. |
ApplicationTimeout
ApplicationTimeout is a report for configured application timeouts. |
ApplicationTimeoutType
Application timeout type.
|
CollectorInfo
Collector info containing collector address and collector token passed from
RM to AM in Allocate Response.
|
Container
Container represents an allocated resource in the cluster. |
ContainerId
ContainerId represents a globally unique identifier
for a Container in the cluster. |
ContainerLaunchContext
ContainerLaunchContext represents all of the information
needed by the NodeManager to launch a container. |
ContainerRetryContext
ContainerRetryContext indicates how container retry after it fails
to run. |
ContainerRetryPolicy
Retry policy for relaunching a
Container . |
ContainerState
State of a
Container . |
ContainerSubState
Container Sub-State.
|
ContainerUpdateType
Encodes the type of Container Update.
|
ExecutionType
Container property encoding execution semantics.
|
ExecutionTypeRequest
An object of this class represents a specification of the execution
guarantee of the Containers associated with a ResourceRequest.
|
FinalApplicationStatus
Enumeration of various final states of an
Application . |
LocalizationState
State of localization.
|
LocalizationStatus
Represents the localization status of a resource.
|
LocalResource
LocalResource represents a local resource required to
run a container. |
LocalResourceType
LocalResourceType specifies the type
of a resource localized by the NodeManager . |
LocalResourceVisibility
LocalResourceVisibility specifies the visibility
of a resource localized by the NodeManager . |
LogAggregationContext
LogAggregationContext represents all of the
information needed by the NodeManager to handle
the logs for an application. |
NodeAttribute
Node Attribute is a kind of a label which represents one of the
attribute/feature of a Node.
|
NodeAttributeInfo
Node Attribute Info describes a NodeAttribute.
|
NodeAttributeKey
Node AttributeKey uniquely identifies a given Node Attribute.
|
NodeAttributeOpCode
Enumeration of various node attribute op codes.
|
NodeAttributeType
Type of a
node Attribute . |
NodeId
NodeId is the unique identifier for a node. |
NodeLabel |
NodeState
State of a
Node . |
NodeToAttributeValue
Mapping of Attribute Value to a Node.
|
PreemptionContainer
Specific container requested back by the
ResourceManager . |
PreemptionContract
Description of resources requested back by the
ResourceManager . |
PreemptionResourceRequest
Description of resources requested back by the cluster.
|
Priority
The priority assigned to a ResourceRequest or Application or Container
allocation
|
QueueACL
QueueACL enumerates the various ACLs for queues. |
QueueInfo
QueueInfo is a report of the runtime information of the queue.
|
QueueState
State of a Queue.
|
QueueStatistics |
RejectedSchedulingRequest
This encapsulates a Rejected SchedulingRequest.
|
RejectionReason
Reason for rejecting a Scheduling Request.
|
ReservationACL
ReservationACL enumerates the various ACLs for reservations. |
ReservationAllocationState
ReservationAllocationState represents the reservation that is
made by a user. |
ReservationDefinition
ReservationDefinition captures the set of resource and time
constraints the user cares about regarding a reservation. |
ReservationId
ReservationId represents the globally unique identifier for
a reservation. |
ReservationRequest
ReservationRequest represents the request made by an application to
the ResourceManager to reserve Resource s. |
ReservationRequestInterpreter
Enumeration of various types of dependencies among multiple
ReservationRequests within one ReservationDefinition (from
least constraining to most constraining). |
ReservationRequests
ReservationRequests captures the set of resource and constraints the
user cares about regarding a reservation. |
Resource
Resource models a set of computer resources in the
cluster. |
ResourceAllocationRequest
ResourceAllocationRequest represents an allocation
made for a reservation for the current state of the plan. |
ResourceBlacklistRequest
ResourceBlacklistRequest encapsulates the list of resource-names
which should be added or removed from the blacklist of resources
for the application. |
ResourceOption |
ResourceRequest
ResourceRequest represents the request made
by an application to the ResourceManager
to obtain various Container allocations. |
ResourceRequest.ResourceRequestBuilder
Class to construct instances of
ResourceRequest with specific
options. |
ResourceSizing
ResourceSizing contains information for the size of a
SchedulingRequest , such as the number of requested allocations and
the resources for each allocation. |
ResourceUtilization
ResourceUtilization models the utilization of a set of computer
resources in the cluster. |
SchedulingRequest
SchedulingRequest represents a request made by an application to the
ResourceManager to obtain an allocation. |
SchedulingRequest.SchedulingRequestBuilder
Class to construct instances of
SchedulingRequest with specific
options. |
ShellContainerCommand
Enumeration of various signal container commands.
|
SignalContainerCommand
Enumeration of various signal container commands.
|
StrictPreemptionContract
Enumeration of particular allocations to be reclaimed.
|
Token
Token is the security entity used by the framework
to verify authenticity of any resource. |
UpdateContainerError
UpdateContainerError is used by the Scheduler to notify the
ApplicationMaster of an UpdateContainerRequest it cannot satisfy due to
an error in the request. |
UpdateContainerRequest
UpdateContainerRequest represents the request made by an
application to the ResourceManager to update an attribute of a
Container such as its Resource allocation or (@code ExecutionType} |
UpdatedContainer
An object that encapsulates an updated container and the
type of Update.
|
URL
URL represents a serializable URL . |
YarnApplicationAttemptState
Enumeration of various states of a
RMAppAttempt . |
YarnApplicationState
Enumeration of various states of an
ApplicationMaster . |
Class and Description |
---|
ApplicationId
ApplicationId represents the globally unique
identifier for an application. |
Class and Description |
---|
NodeAttributeOpCode
Enumeration of various node attribute op codes.
|
Class and Description |
---|
ApplicationAttemptId
ApplicationAttemptId denotes the particular attempt
of an ApplicationMaster for a given ApplicationId . |
ContainerId
ContainerId represents a globally unique identifier
for a Container in the cluster. |
Class and Description |
---|
ApplicationAttemptId
ApplicationAttemptId denotes the particular attempt
of an ApplicationMaster for a given ApplicationId . |
ApplicationAttemptReport
ApplicationAttemptReport is a report of an application attempt. |
ApplicationId
ApplicationId represents the globally unique
identifier for an application. |
ApplicationReport
ApplicationReport is a report of an application. |
ApplicationSubmissionContext
ApplicationSubmissionContext represents all of the
information needed by the ResourceManager to launch
the ApplicationMaster for an application. |
Container
Container represents an allocated resource in the cluster. |
ContainerId
ContainerId represents a globally unique identifier
for a Container in the cluster. |
ContainerLaunchContext
ContainerLaunchContext represents all of the information
needed by the NodeManager to launch a container. |
ContainerReport
ContainerReport is a report of an container. |
ContainerStatus
ContainerStatus represents the current status of a
Container . |
ExecutionType
Container property encoding execution semantics.
|
FinalApplicationStatus
Enumeration of various final states of an
Application . |
LocalizationStatus
Represents the localization status of a resource.
|
LocalResource
LocalResource represents a local resource required to
run a container. |
NodeAttribute
Node Attribute is a kind of a label which represents one of the
attribute/feature of a Node.
|
NodeAttributeInfo
Node Attribute Info describes a NodeAttribute.
|
NodeAttributeKey
Node AttributeKey uniquely identifies a given Node Attribute.
|
NodeId
NodeId is the unique identifier for a node. |
NodeLabel |
NodeReport
NodeReport is a summary of runtime information of a node
in the cluster. |
NodeState
State of a
Node . |
NodeToAttributeValue
Mapping of Attribute Value to a Node.
|
Priority
The priority assigned to a ResourceRequest or Application or Container
allocation
|
QueueInfo
QueueInfo is a report of the runtime information of the queue.
|
QueueUserACLInfo
QueueUserACLInfo provides information QueueACL for
the given user. |
Resource
Resource models a set of computer resources in the
cluster. |
SchedulingRequest
SchedulingRequest represents a request made by an application to the
ResourceManager to obtain an allocation. |
ShellContainerCommand
Enumeration of various signal container commands.
|
SignalContainerCommand
Enumeration of various signal container commands.
|
Token
Token is the security entity used by the framework
to verify authenticity of any resource. |
UpdateContainerRequest
UpdateContainerRequest represents the request made by an
application to the ResourceManager to update an attribute of a
Container such as its Resource allocation or (@code ExecutionType} |
URL
URL represents a serializable URL . |
YarnApplicationState
Enumeration of various states of an
ApplicationMaster . |
YarnClusterMetrics
YarnClusterMetrics represents cluster metrics. |
Class and Description |
---|
Container
Container represents an allocated resource in the cluster. |
ContainerId
ContainerId represents a globally unique identifier
for a Container in the cluster. |
ContainerLaunchContext
ContainerLaunchContext represents all of the information
needed by the NodeManager to launch a container. |
ExecutionType
Container property encoding execution semantics.
|
FinalApplicationStatus
Enumeration of various final states of an
Application . |
NodeId
NodeId is the unique identifier for a node. |
Priority
The priority assigned to a ResourceRequest or Application or Container
allocation
|
Resource
Resource models a set of computer resources in the
cluster. |
SchedulingRequest
SchedulingRequest represents a request made by an application to the
ResourceManager to obtain an allocation. |
UpdateContainerRequest
UpdateContainerRequest represents the request made by an
application to the ResourceManager to update an attribute of a
Container such as its Resource allocation or (@code ExecutionType} |
Class and Description |
---|
ApplicationAttemptId
ApplicationAttemptId denotes the particular attempt
of an ApplicationMaster for a given ApplicationId . |
ApplicationId
ApplicationId represents the globally unique
identifier for an application. |
ContainerId
ContainerId represents a globally unique identifier
for a Container in the cluster. |
Class and Description |
---|
Resource
Resource models a set of computer resources in the
cluster. |
Class and Description |
---|
ApplicationAccessType
Application access types.
|
ContainerId
ContainerId represents a globally unique identifier
for a Container in the cluster. |
Class and Description |
---|
ApplicationAccessType
Application access types.
|
ApplicationAttemptId
ApplicationAttemptId denotes the particular attempt
of an ApplicationMaster for a given ApplicationId . |
ApplicationId
ApplicationId represents the globally unique
identifier for an application. |
NodeId
NodeId is the unique identifier for a node. |
Class and Description |
---|
ApplicationAttemptId
ApplicationAttemptId denotes the particular attempt
of an ApplicationMaster for a given ApplicationId . |
ContainerId
ContainerId represents a globally unique identifier
for a Container in the cluster. |
ExecutionType
Container property encoding execution semantics.
|
LogAggregationContext
LogAggregationContext represents all of the
information needed by the NodeManager to handle
the logs for an application. |
NodeId
NodeId is the unique identifier for a node. |
Priority
The priority assigned to a ResourceRequest or Application or Container
allocation
|
Resource
Resource models a set of computer resources in the
cluster. |
Class and Description |
---|
ApplicationAttemptId
ApplicationAttemptId denotes the particular attempt
of an ApplicationMaster for a given ApplicationId . |
Class and Description |
---|
LocalResourceVisibility
LocalResourceVisibility specifies the visibility
of a resource localized by the NodeManager . |
Class and Description |
---|
ApplicationId
ApplicationId represents the globally unique
identifier for an application. |
ApplicationReport
ApplicationReport is a report of an application. |
LocalResource
LocalResource represents a local resource required to
run a container. |
YarnApplicationState
Enumeration of various states of an
ApplicationMaster . |
Class and Description |
---|
ApplicationAttemptId
ApplicationAttemptId denotes the particular attempt
of an ApplicationMaster for a given ApplicationId . |
ApplicationId
ApplicationId represents the globally unique
identifier for an application. |
ContainerId
ContainerId represents a globally unique identifier
for a Container in the cluster. |
NodeId
NodeId is the unique identifier for a node. |
Token
Token is the security entity used by the framework
to verify authenticity of any resource. |
URL
URL represents a serializable URL . |
Class and Description |
---|
ApplicationId
ApplicationId represents the globally unique
identifier for an application. |
Copyright © 2024 Apache Software Foundation. All rights reserved.