blob: f1564afb0191c507d9a7b81c98b3e9edbdd0265a [file] [log] [blame] [view]
# Scheduler Interface Spec
Authors: The Yunikorn Scheduler Authors
## Objective
To define a standard interface that can be used by different types of resource management systems such as YARN/K8s.
### Goals for minimum viable product (MVP)
- Interface and implementation should be resource manager (RM) agnostic.
- Interface can handle multiple types of resource managers from multiple zones, and different policies can be configured in different zones.
Possible use cases:
- A large cluster needs multiple schedulers to achieve horizontally scalability.
- Multiple resource managers need to run on the same cluster. The managers grow and shrink according to runtime resource usage and policies.
### Non-Goals for minimum viable product (MVP)
- Handle process-specific information: Scheduler Interface only handles decisions for scheduling instead of how containers will be launched.
## Design considerations
Highlights:
- The scheduler should be as stateless as possible. It should try to eliminate any local persistent storage for scheduling decisions.
- When a RM starts, restarts or recovers the RM needs to sync its state with scheduler.
### Architecture
## Generic definitions
Interface and messages generic definition.
The syntax used for the declarations is `proto3`. The definition currently only provides go related info.
```protobuf
syntax = "proto3";
package si.v1;
import "google/protobuf/descriptor.proto";
option go_package = "si";
extend google.protobuf.FieldOptions {
// Indicates that a field MAY contain information that is sensitive
// and MUST be treated as such (e.g. not logged).
bool si_secret = 1059;
}
```
## Scheduler Interfaces
There are two kinds of interfaces, the first one is RPC based communication, the second one is API based.
RPC based, the [gRPC](https://grpc.io/) framework is used, will be useful when scheduler has to be deployed as a remote process.
For example when we need to deploy scheduler support multiple remote clusters.
A second example is when there is a cross language integration, like between Java and Go.
Unless specifically required we strongly recommend the use of the API based interface to avoid the overhead of the RPC serialization and de-serialization.
### RPC Interface
There are three sets of RPCs:
* **Scheduler Service**: RM can communicate with the Scheduler Service and do resource allocation/request update, etc.
* **Admin Service**: Admin can communicate with Scheduler Interface and get configuration updated.
* **Metrics Service**: Used to retrieve state of scheduler by users / RMs.
Currently only the design and implementation for the Scheduler Service is provided.
```protobuf
service Scheduler {
// Register a RM, if it is a reconnect from previous RM the call will
// trigger a cleanup of all in-memory data and resync with RM.
rpc RegisterResourceManager (RegisterResourceManagerRequest)
returns (RegisterResourceManagerResponse) { }
// Update Scheduler status (this includes node status update, allocation request
// updates, etc. And receive updates from scheduler for allocation changes,
// any required status changes, etc.
rpc Update (stream UpdateRequest)
returns (stream UpdateResponse) { }
}
/*
service AdminService {
// Include
// addQueueInfo.
// removeQueueInfo.
// updateQueueInfo.
rpc UpdateConfig (UpdateConfigRequest)
returns (UpdateConfigResponse) {}
}
*/
/*
service MetricsService {
}
*/
```
#### Why bi-directional gRPC
The reason of using bi-directional streaming gRPC is, according to performance benchmark: https://grpc.io/docs/guides/benchmarking.html latency is close to 0.5 ms.
The same performance benchmark shows streaming QPS can be 4x of non-streaming RPC.
Considering scheduler needs both throughput and better latency, we go with streaming API for scheduler related decisions.
### API Interface
The API interface only relies on the message definition and not on other generated code as the RPC Interface does.
Below is an example of the Scheduler Service as defined in the RPC. The SchedulerAPI is bi-directional and can be a-synchronous.
For the asynchronous cases the API requires a callback interface to be implemented in the resource manager.
The callback must be provided to the scheduler as part of the registration.
```golang
package api
import "github.com/apache/incubator-yunikorn-scheduler-interface/lib/go/si"
type SchedulerApi interface {
// Register a new RM, if it is a reconnect from previous RM, cleanup
// all in-memory data and resync with RM.
RegisterResourceManager(request *si.RegisterResourceManagerRequest, callback *ResourceManagerCallback) (*si.RegisterResourceManagerResponse, error)
// Update Scheduler status (including node status update, allocation request
// updates, etc.
Update(request *si.UpdateRequest) error
}
// RM side needs to implement this API
type ResourceManagerCallback interface {
RecvUpdateResponse(response *si.UpdateResponse) error
}
```
### Communications between RM and Scheduler
Lifecycle of RM-Scheduler communication
```
Status of RM in scheduler:
Connection timeout
+-------+ +-------+ loss +-------+ +---------+
|init |+---->|Running|+---->|Paused |+---->| Stopped |
+-------+ +----+--+ +-------+ +---------+
RM register | ^
with scheduler | |
+-----------------------------+
RM voluntarilly
Shutdown
```
#### RM register with scheduler
When a new RM starts, fails, it will register with scheduler. In some cases, scheduler can ask RM to re-register because of connection issues or other internal issues.
```protobuf
message RegisterResourceManagerRequest {
// An ID which can uniquely identify a RM **cluster**. (For example, if a RM cluster has multiple manager instances for HA purpose, they should use the same information when do registration).
// If RM register with the same ID, all previous scheduling state in memory will be cleaned up, and expect RM report full scheduling state after registration.
string rmID = 1;
// Version of RM scheduler interface client.
string version = 2;
// Policy group name:
// This defines which policy to use. Policy should be statically configured. (Think about network security group concept of ec2).
// Different RMs can refer to the same policyGroup if their static configuration is identical.
string policyGroup = 3;
}
// Upon success, scheduler returns RegisterResourceManagerResponse to RM, otherwise RM receives exception.
message RegisterResourceManagerResponse {
// Intentionally empty.
}
```
#### RM and scheduler updates.
Below is overview of how scheduler/RM keep connection and updates.
```protobuf
message UpdateRequest {
// New allocation requests or replace existing allocation request (if allocationID is same)
repeated AllocationAsk asks = 1;
// Allocations can be released.
AllocationReleasesRequest releases = 2;
// New node can be scheduled. If a node is notified to be "unscheduable", it needs to be part of this field as well.
repeated NewNodeInfo newSchedulableNodes = 3;
// Update nodes for existing schedulable nodes.
// May include:
// - Node resource changes. (Like grows/shrinks node resource)
// - Node attribute changes. (Including node-partition concept like YARN, and concept like "local images".
//
// Should not include:
// - Allocation-related changes with the node.
// - Realtime Utilizations.
repeated UpdateNodeInfo updatedNodes = 4;
// UtilizationReports for allocation and nodes.
repeated UtilizationReport utilizationReports = 5;
// ID of RM, this will be used to identify which RM of the request comes from.
string rmID = 6;
// RM should explicitly add application when allocation request also explictly belongs to application.
// This is optional if allocation request doesn't belong to a application. (Independent allocation)
repeated AddApplicationRequest newApplications = 8;
// RM can also remove applications, all allocation/allocation requests associated with the application will be removed
repeated RemoveApplicationRequest removeApplications = 9;
}
message UpdateResponse {
// Scheduler can send action to RM.
enum ActionFromScheduler {
// Nothing needs to do
NOACTION = 0;
// Something is wrong, RM needs to stop the RM, and re-register with scheduler.
RESYNC = 1;
}
// What RM needs to do, scheduler can send control code to RM when something goes wrong.
// Don't use/expand this field for other general purposed actions. (Like kill a remote container process).
ActionFromScheduler action = 1;
// New allocations
repeated Allocation newAllocations = 2;
// Released allocations, this could be either ack from scheduler when RM asks to terminate some allocations. Or
// it could be decision made by scheduler (such as preemption).
repeated AllocationReleaseResponse releasedAllocations = 3;
// Rejected allocation requests
repeated RejectedAllocationAsk rejectedAllocations = 4;
// Suggested node update.
// This could include:
// 1) Schedulable resources on each node. This can be used when we want to run
// two resource management systems side-by-side. For example, YARN/K8s running side by side.
// and update YARN NodeManager / Kubelet resource dynamically.
// 2) Other recommendations.
repeated NodeRecommendation nodeRecommendations = 5;
// Rejected Applications
repeated RejectedApplication rejectedApplications = 6;
// Accepted Applications
repeated AcceptedApplication acceptedApplications = 7;
// Rejected Node Registrations
repeated RejectedNode rejectedNodes = 8;
// Accepted Node Registrations
repeated AcceptedNode acceptedNodes = 9;
}
message RejectedApplication {
// The application ID that was rejected
string applicationID = 1;
// A human-readable reason message
string reason = 2;
}
message AcceptedApplication {
// The application ID that was accepted
string applicationID = 1;
}
message RejectedNode {
// The node ID that was rejected
string nodeID = 1;
// A human-readable reason message
string reason = 2;
}
message AcceptedNode {
// The node ID that was accepted
string nodeID = 1;
}
```
#### Ask for more resources
Lifecycle of AllocationAsk:
```
Rejected by Scheduler
+-------------------------------------------+
| |
| v
+-------+---+ Asked +-----------+Scheduler or,+-----------+
|Initial +------->|Pending |+----+----+->|Rejected |
+-----------+By RM +-+---------+ Asked by RM +-----------+
+
|
v
+-----------+
|Allocated |
+-----------+
```
Lifecycle of Allocations:
```
+--Allocated by
v Scheduler
+-----------+ +------------+
|Allocated |+------ |Completed |
+---+-------+ Stoppe +------------+
| by RM
| +------------+
+--------------->|Preempted |
+ Preempted by +------------+
| Scheduler
|
|
| +------------+
+--------------->|Expired |
Timeout +------------+
(Part of Allocation
ask)
```
Common fields for allocation:
```protobuf
message Priority {
oneof priority {
// Priority of each ask, higher is more important.
// How to deal with Priority is handled by each scheduler implementation.
int32 priorityValue = 1;
// PriorityClass is used for app owners to set named priorities. This is a portable way for
// app owners have a consistent way to setup priority across clusters
string priorityClassName = 2;
}
}
// A sparse map of resource to Quantity.
message Resource {
map<string, Quantity> resources = 1;
}
// Quantity includes a single int64 value
message Quantity {
int64 value = 1;
}
```
Allocation ask:
```protobuf
message AllocationAsk {
// Allocation key is used by both of scheduler and RM to track allocations.
// It doesn't have to be same as RM's internal allocation id (such as Pod name of K8s or ContainerID of YARN).
// Allocations from the same AllocationAsk which are returned to the RM at the same time will have the same allocationKey.
// The request is considered an update of the existing AllocationAsk if an ALlocationAsk with the same allocationKey
// already exists.
string allocationKey = 1;
// The application ID this allocation ask belongs to
string applicationID = 2;
// The partition the application belongs to
string partitionName = 3;
// The amount of resources per ask
Resource resourceAsk = 4;
// Maximum number of allocations
int32 maxAllocations = 5;
// Priority of ask
Priority priority = 6;
// Execution timeout: How long this allocation will be terminated (by scheduler)
// once allocated by scheduler, 0 or negative value means never expire.
int64 executionTimeoutMilliSeconds = 7;
// A set of tags for this spscific AllocationAsk. Allocation level tags are used in placing this specific
// ask on nodes in the cluster. These tags are used in the PlacementConstraints.
// These tags are optional.
map<string, string> tags = 8;
// Placement constraint defines how this allocation should be placed in the cluster.
// if not set, no placement constraint will be applied.
PlacementConstraint placementConstraint = 9;
}
```
Application requests:
```protobuf
message AddApplicationRequest {
// The ID of the application, must be unique
string applicationID = 1;
// The queue this application is requesting. The scheduler will place the application into a
// queue according to policy, taking into account the requested queue as per the policy.
string queueName = 2;
// The partition the application belongs to
string partitionName = 3;
// The user group information of the application owner
UserGroupInformation ugi = 4;
// A set of tags for the application. These tags provide application level generic inforamtion.
// The tags are optional and are used in placing an appliction or scheduling.
// Application tags are not considered when processing AllocationAsks.
map<string, string> tags = 5;
// Execution timeout: How long this application can be in a running state
// 0 or negative value means never expire.
int64 executionTimeoutMilliSeconds = 6;
}
message RemoveApplicationRequest {
// The ID of the application to remove
string applicationID = 1;
// The partition the application belongs to
string partitionName = 2;
}
```
User information:
The user that owns the application. Group information can be empty. If the group information is empty the groups will be resolved by the scheduler when needed.
```protobuf
message UserGroupInformation {
// the user name
string user = 1;
// the list of groups of the user, can be empty
repeated string groups = 2;
}
```
PlacementConstraint: (Reference to works have been done in YARN-6592). And here is design doc:
https://issues.apache.org/jira/secure/attachment/12867869/YARN-6592-Rich-Placement-Constraints-Design-V1.pdf
```protobuf
// PlacementConstraint could have simplePlacementConstraint or
// CompositePlacementConstraint. One of them will be set.
message PlacementConstraint {
oneof constraint {
SimplePlacementConstraint simpleConstraint = 1;
// This protocol can extended to support complex constraints
// To make an easier scheduler implementation and avoid confusing user.
// Protocol related to CompositePlacementConstraints will be
// commented and only for your references.
// CompositePlacementConstraint compositeConstraint = 2;
}
}
// Simple placement constraint represent constraint for affinity/anti-affinity
// to node attribute or allocation tags.
// When both of NodeAffinityConstraints and AllocationAffinityConstraints
// specified, both will be checked and verified while scheduling.
message SimplePlacementConstraint {
// Constraint
NodeAffinityConstraints nodeAffinityConstraint = 1;
AllocationAffinityConstraints allocationAffinityAttribute = 2;
}
// Affinity to node, multiple AffinityTargetExpression will be specified,
// They will be connected by AND.
message NodeAffinityConstraints {
repeated AffinityTargetExpression targetExpressions = 2;
}
// Affinity to allocations (containers).
// Affinity is single-direction, which means if RM wants to do mutual affinity/
// anti-affinity between allocations, same constraints need to be added
// to all allocation asks.
message AllocationAffinityConstraints {
// Scope: scope is key of node attribute, which determines if >1 allocations
// in the same group or not.
// When allocations on node(s) which have same node attribute value
// for given node attribute key == scope. They're in the same group.
//
// e.g. when user wants to do anti-affinity between allocation on node
// basis, scope can be set to "hostname", max-cardinality = 1;
string scope = 1;
repeated AffinityTargetExpression tragetExpressions = 2;
int32 minCardinality = 3;
int32 maxCardinality = 4;
// Is this a required (hard) or preferred (soft) request.
bool required = 5;
}
message AffinityTargetExpression {
// Following 4 operators can be specified, by default is "IN".
// When EXIST/NOT_EXISTS specified, scheduler only check if given targetKey
// appears on node attribute or allocation tag.
enum AffinityTargetOperator {
IN = 0;
NOT_IN = 1;
EXIST = 2;
NOT_EXIST = 3;
}
AffinityTargetExpression targetOperator = 1;
string targetKey = 2;
repeated string targetValues = 3;
}
```
As mentioned above, the intention is to support Composite Placement Constraint in the future.
The following protocol block is not marked as `protobuf` code and is added as a reference only and will not be processed as part of the protocol generation.
```
message CompositePlacementConstraintProto {
enum CompositeType {
// All children constraints have to be satisfied.
AND = 0;
// One of the children constraints has to be satisfied.
OR = 1;
// Attempt to satisfy the first child constraint for delays[0] units (e.g.,
// millisec or heartbeats). If this fails, try to satisfy the second child
// constraint for delays[1] units and so on.
DELAYED_OR = 2;
}
CompositeType compositeType = 1;
repeated PlacementConstraintProto childConstraints = 2;
repeated TimedPlacementConstraintProto timedChildConstraints = 3;
}
message TimedPlacementConstraintProto {
enum DelayUnit {
MILLISECONDS = 0;
OPPORTUNITIES = 1;
}
required PlacementConstraintProto placementConstraint = 1;
required int64 schedulingDelay = 2;
DelayUnit delayUnit = 3 [ default = MILLISECONDS ];
}
```
#### Release previously allocated resources
```protobuf
message AllocationReleasesRequest {
// The allocations to release
repeated AllocationReleaseRequest allocationsToRelease = 1;
// The asks to release
repeated AllocationAskReleaseRequest allocationAsksToRelease = 2;
}
// Release allocation
message AllocationReleaseRequest {
// Which partition to release the allocation from, required.
string partitionName = 1;
// optional, when this is set, filter allocations by application id.
// when application id is set and UUID is not set, release all allocations under the application id.
string applicationID = 2;
// optional, when this is set, only release allocation by given UUID.
string UUID = 3;
// For human-readable message
string message = 4;
}
// Release ask
message AllocationAskReleaseRequest {
// Which partition to release the ask from, required.
string partitionName = 1;
// optional, when this is set, filter allocation key by application id.
// when application id is set and allocationKey is not set, release all allocations key under the application id.
string applicationID = 2;
// optional, when this is set, only release allocation ask by specified
string allocationkey = 3;
// For human-readable message
string message = 4;
}
```
#### Schedulable nodes registration and updates
State transition of node:
```
+-----------+ +--------+ +-------+
|SCHEDULABLE|+-------->|DRAINING|+---------->|REMOVED|
+-----------+ +--------+ +-------+
^ Asked by + Aasked by
| RM to DRAIN | RM to REMOVE
| |
+---------------------+
Asked by RM to
SCHEDULE again
```
See protocol below:
Registration of a new node with the scheduler. If the node exists then the request will be rejected.
```protobuf
message NewNodeInfo {
// ID of node, must be unique
string nodeID = 1;
// node attributes
map<string, string> attributes = 2;
// Schedulable Resource
Resource schedulableResource = 3;
// Allocated resources, this will be added when node registered to RM (recovery)
repeated Allocation existingAllocations = 4;
}
```
Update of a registered node with the scheduler. If the node does not exist the update will fail.
```protobuf
message UpdateNodeInfo {
// Action from RM
enum ActionFromRM {
// Update node resources, attributes.
UPDATE = 0;
// Do not allocate new allocations on the node.
DRAIN_NODE = 1;
// Decomission node, it will immediately stop allocations on the node and
// remove the node from schedulable lists.
DECOMISSION = 2;
// From Draining state to SCHEDULABLE state.
// If node is not in draining state, error will be thrown
DRAIN_TO_SCHEDULABLE = 3;
}
// ID of node, the node must exist to be updated
string nodeID = 1;
// New attributes of node, which will replace previously reported attribute.
map<string, string> attributes = 2;
// new schedulable resource, scheduler may preempt allocations on the
// node or schedule more allocations accordingly.
Resource schedulableResource = 3;
// when the scheduler is co-exist with some other schedulers, some node
// resources might be occupied (allocated) by other schedulers.
Resource occupiedResource = 4;
// Action to perform by the scheduler
ActionFromRM action = 5;
}
```
#### Utilization report
```protobuf
message UtilizationReport {
// it could be either a nodeID or allocation UUID.
string ID = 1;
// Actual used resource
Resource actualUsedResource = 2;
}
```
#### Feedback from Scheduler
Following is feedback from scheduler to RM:
Allocation is allocated allocations from scheduler.
```protobuf
message Allocation {
// AllocationKey from AllocationAsk
string allocationKey = 1;
// Allocation tags from AllocationAsk
map<string, string> allocationTags = 2;
// UUID of the allocation
string UUID = 3;
// Resource for each allocation
Resource resourcePerAlloc = 5;
// Priority of ask
Priority priority = 6;
// Queue which the allocation belongs to
string queueName = 7;
// Node which the allocation belongs to
string nodeID = 8;
// The ID of the application
string applicationID = 9;
// Partition of the allocation
string partitionName = 10;
}
```
When allocation ask rejected by scheduler, information will be shared by scheduler.
```protobuf
message RejectedAllocationAsk {
string allocationKey = 1;
// The ID of the application
string applicationID = 2;
// A human-readable reason message
string reason = 3;
}
```
Scheduler can notify suggestions to RM about node. This can be either human-readable or actions can be taken.
```protobuf
message NodeRecommendation {
Resource recommendedSchedulableResource = 1;
// Any other human-readable message
string message = 2;
}
```
For released allocations
```protobuf
// When allocation released, either by RM or preempted by scheduler. It will be sent back to RM.
message AllocationReleaseResponse {
enum TerminationType {
// STOPPED by ResourceManager.
STOPPED_BY_RM = 0;
// TIMEOUT based on the executionTimeoutMilliSeconds
TIMEOUT = 1;
// PREEMPTED by scheduler
PREEMPTED_BY_SCHEDULER = 2;
}
// UUID of the allocation that is released
string UUID = 1;
// Termination type of the released allocation
TerminationType terminationType = 2;
// Any other human-readable message
string message = 3;
}
```
### Following are constant of spec
Scheduler Interface reserved all attribute in si.io namespace.
Known attribute names for nodes and applications.
```golang
// Constants for node attribtues
const (
ARCH="si.io/arch"
HOSTNAME="si.io/hostname"
RACKNAME="si.io/rackname"
OS="si.io/os"
INSTANCE_TYPE="si.io/instance-type"
FAILURE_DOMAIN_ZONE="si.io/zone"
FAILURE_DOMAIN_REGION="si.io/region"
LOCAL_IMAGES="si.io/local-images"
NODE_PARTITION="si.io/node-partition"
)
// Constants for allocation attribtues
const (
APPLICATION_ID="si.io/application-id"
CONTAINER_IMAGE="si.io/container-image"
CONTAINER_PORTS="si.io/container-ports"
)
```
### Scheduler plugin
SchedulerPlugin is a way to extend scheduler capabilities. Scheduler shim can implement such plugin and register itself to
yunikorn-core, so plugged function can be invoked in the scheduler core.
```protobuf
message PredicatesArgs {
// allocation key identifies a container, the predicates function is going to check
// if this container is eligible to be placed ont to a node.
string allocationKey = 1;
// the node ID the container is assigned to.
string nodeID = 2;
}
message ReSyncSchedulerCacheArgs {
// a list of assumed allocations, this will be sync'd to scheduler cache.
repeated AssumedAllocation assumedAllocations = 1;
// a list of allocations to forget
repeated ForgotAllocation forgetAllocations = 2;
}
message AssumedAllocation {
// allocation key used to identify a container.
string allocationKey = 1;
// the node ID the container is assumed to be allocated to, this info is stored in scheduler cache.
string nodeID = 2;
}
message ForgotAllocation {
// allocation key used to identify a container.
string allocationKey = 1;
}
```
### Auto Scaling Metrics
Auto scaling metrics can be monitored and collected by a 3rd party auto-scaler and used as the
supplementary metrics while making auto-scaling decisions. These metrics are indicating how many
outstanding resource requests are there in the cluster, due to the shortage of node resources.
This has excluded requests could not be satisfied because of other reasons, such as hitting queue
resource limit, user/app limit, desire on certain placement constraints, etc.
```protobuf
// auto scaling metrics at a certain point of time
message AutoScalingMetrics {
// a list of outstanding requests that desires for additional resources
repeated OutstandingResourceRequest outstandingRequests = 1;
}
message OutstandingResourceRequest {
// an unique ID
string requestID = 1;
// resource specification
Resource resource = 2;
// an arbitrary map for tags, this stores some useful information that can help the decision
map<string, string> tags = 3;
}
```