2015-09-08 22:37:07 +00:00
|
|
|
package api
|
|
|
|
|
2015-09-14 02:55:47 +00:00
|
|
|
import (
|
2019-04-28 21:34:01 +00:00
|
|
|
"context"
|
|
|
|
"encoding/json"
|
|
|
|
"errors"
|
2016-04-29 20:03:02 +00:00
|
|
|
"fmt"
|
2019-04-28 21:34:01 +00:00
|
|
|
"io"
|
2015-09-17 19:40:51 +00:00
|
|
|
"sort"
|
2019-04-28 21:34:01 +00:00
|
|
|
"strconv"
|
|
|
|
"sync"
|
2015-09-14 02:55:47 +00:00
|
|
|
"time"
|
2019-04-28 21:34:01 +00:00
|
|
|
|
|
|
|
"github.com/gorilla/websocket"
|
2015-09-14 02:55:47 +00:00
|
|
|
)
|
|
|
|
|
2016-10-21 01:05:58 +00:00
|
|
|
var (
|
2016-10-25 18:31:09 +00:00
|
|
|
// NodeDownErr marks an operation as not able to complete since the node is
|
|
|
|
// down.
|
2016-10-21 01:05:58 +00:00
|
|
|
NodeDownErr = fmt.Errorf("node down")
|
|
|
|
)
|
|
|
|
|
2019-01-18 23:36:16 +00:00
|
|
|
const (
|
|
|
|
AllocDesiredStatusRun = "run" // Allocation should run
|
|
|
|
AllocDesiredStatusStop = "stop" // Allocation should stop
|
|
|
|
AllocDesiredStatusEvict = "evict" // Allocation should stop, and was evicted
|
|
|
|
)
|
|
|
|
|
|
|
|
const (
|
|
|
|
AllocClientStatusPending = "pending"
|
|
|
|
AllocClientStatusRunning = "running"
|
|
|
|
AllocClientStatusComplete = "complete"
|
|
|
|
AllocClientStatusFailed = "failed"
|
|
|
|
AllocClientStatusLost = "lost"
|
|
|
|
)
|
|
|
|
|
2015-09-09 00:49:31 +00:00
|
|
|
// Allocations is used to query the alloc-related endpoints.
|
|
|
|
type Allocations struct {
|
2015-09-08 22:37:07 +00:00
|
|
|
client *Client
|
|
|
|
}
|
|
|
|
|
2015-09-09 00:49:31 +00:00
|
|
|
// Allocations returns a handle on the allocs endpoints.
|
|
|
|
func (c *Client) Allocations() *Allocations {
|
|
|
|
return &Allocations{client: c}
|
2015-09-08 22:37:07 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// List returns a list of all of the allocations.
|
2015-09-14 02:55:47 +00:00
|
|
|
func (a *Allocations) List(q *QueryOptions) ([]*AllocationListStub, *QueryMeta, error) {
|
|
|
|
var resp []*AllocationListStub
|
2015-09-09 20:18:50 +00:00
|
|
|
qm, err := a.client.query("/v1/allocations", &resp, q)
|
2015-09-08 22:37:07 +00:00
|
|
|
if err != nil {
|
2015-09-08 23:45:16 +00:00
|
|
|
return nil, nil, err
|
2015-09-08 22:37:07 +00:00
|
|
|
}
|
2015-09-17 19:40:51 +00:00
|
|
|
sort.Sort(AllocIndexSort(resp))
|
2015-09-08 23:45:16 +00:00
|
|
|
return resp, qm, nil
|
2015-09-08 22:37:07 +00:00
|
|
|
}
|
|
|
|
|
2015-12-24 10:46:59 +00:00
|
|
|
func (a *Allocations) PrefixList(prefix string) ([]*AllocationListStub, *QueryMeta, error) {
|
|
|
|
return a.List(&QueryOptions{Prefix: prefix})
|
|
|
|
}
|
|
|
|
|
2015-09-09 20:18:50 +00:00
|
|
|
// Info is used to retrieve a single allocation.
|
|
|
|
func (a *Allocations) Info(allocID string, q *QueryOptions) (*Allocation, *QueryMeta, error) {
|
|
|
|
var resp Allocation
|
|
|
|
qm, err := a.client.query("/v1/allocation/"+allocID, &resp, q)
|
|
|
|
if err != nil {
|
|
|
|
return nil, nil, err
|
|
|
|
}
|
|
|
|
return &resp, qm, nil
|
|
|
|
}
|
|
|
|
|
2019-04-28 21:34:01 +00:00
|
|
|
// Exec is used to execute a command inside a running task. The command is to run inside
|
|
|
|
// the task environment.
|
|
|
|
//
|
|
|
|
// The parameters are:
|
|
|
|
// * ctx: context to set deadlines or timeout
|
|
|
|
// * allocation: the allocation to execute command inside
|
|
|
|
// * task: the task's name to execute command in
|
|
|
|
// * tty: indicates whether to start a pseudo-tty for the command
|
|
|
|
// * stdin, stdout, stderr: the std io to pass to command.
|
|
|
|
// If tty is true, then streams need to point to a tty that's alive for the whole process
|
|
|
|
// * terminalSizeCh: A channel to send new tty terminal sizes
|
|
|
|
//
|
|
|
|
// The call blocks until command terminates (or an error occurs), and returns the exit code.
|
|
|
|
func (a *Allocations) Exec(ctx context.Context,
|
|
|
|
alloc *Allocation, task string, tty bool, command []string,
|
|
|
|
stdin io.Reader, stdout, stderr io.Writer,
|
|
|
|
terminalSizeCh <-chan TerminalSize, q *QueryOptions) (exitCode int, err error) {
|
|
|
|
|
|
|
|
ctx, cancelFn := context.WithCancel(ctx)
|
|
|
|
defer cancelFn()
|
|
|
|
|
|
|
|
errCh := make(chan error, 4)
|
|
|
|
|
|
|
|
sender, output := a.execFrames(ctx, alloc, task, tty, command, errCh, q)
|
|
|
|
|
|
|
|
select {
|
|
|
|
case err := <-errCh:
|
|
|
|
return -2, err
|
|
|
|
default:
|
|
|
|
}
|
|
|
|
|
|
|
|
// Errors resulting from sending input (in goroutines) are silently dropped.
|
|
|
|
// To mitigate this, extra care is needed to distinguish between actual send errors
|
|
|
|
// and from send errors due to command terminating and our race to detect failures.
|
|
|
|
// If we have an actual network failure or send a bad input, we'd get an
|
|
|
|
// error in the reading side of websocket.
|
|
|
|
|
|
|
|
go func() {
|
|
|
|
|
|
|
|
bytes := make([]byte, 2048)
|
|
|
|
for {
|
|
|
|
if ctx.Err() != nil {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
input := ExecStreamingInput{Stdin: &ExecStreamingIOOperation{}}
|
|
|
|
|
|
|
|
n, err := stdin.Read(bytes)
|
|
|
|
|
|
|
|
// always send data if we read some
|
|
|
|
if n != 0 {
|
|
|
|
input.Stdin.Data = bytes[:n]
|
|
|
|
sender(&input)
|
|
|
|
}
|
|
|
|
|
|
|
|
// then handle error
|
|
|
|
if err == io.EOF {
|
|
|
|
// if n != 0, send data and we'll get n = 0 on next read
|
|
|
|
if n == 0 {
|
|
|
|
input.Stdin.Close = true
|
|
|
|
sender(&input)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
} else if err != nil {
|
|
|
|
errCh <- err
|
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
|
|
|
// forwarding terminal size
|
|
|
|
go func() {
|
|
|
|
for {
|
|
|
|
resizeInput := ExecStreamingInput{}
|
|
|
|
|
|
|
|
select {
|
|
|
|
case <-ctx.Done():
|
|
|
|
return
|
|
|
|
case size, ok := <-terminalSizeCh:
|
|
|
|
if !ok {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
resizeInput.TTYSize = &size
|
|
|
|
sender(&resizeInput)
|
|
|
|
}
|
|
|
|
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
|
|
|
// send a heartbeat every 10 seconds
|
|
|
|
go func() {
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case <-ctx.Done():
|
|
|
|
return
|
|
|
|
// heartbeat message
|
|
|
|
case <-time.After(10 * time.Second):
|
|
|
|
sender(&execStreamingInputHeartbeat)
|
|
|
|
}
|
|
|
|
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case err := <-errCh:
|
|
|
|
// drop websocket code, not relevant to user
|
|
|
|
if wsErr, ok := err.(*websocket.CloseError); ok && wsErr.Text != "" {
|
|
|
|
return -2, errors.New(wsErr.Text)
|
|
|
|
}
|
|
|
|
return -2, err
|
|
|
|
case <-ctx.Done():
|
|
|
|
return -2, ctx.Err()
|
|
|
|
case frame, ok := <-output:
|
|
|
|
if !ok {
|
|
|
|
return -2, errors.New("disconnected without receiving the exit code")
|
|
|
|
}
|
|
|
|
|
|
|
|
switch {
|
|
|
|
case frame.Stdout != nil:
|
|
|
|
if len(frame.Stdout.Data) != 0 {
|
|
|
|
stdout.Write(frame.Stdout.Data)
|
|
|
|
}
|
|
|
|
// don't really do anything if stdout is closing
|
|
|
|
case frame.Stderr != nil:
|
|
|
|
if len(frame.Stderr.Data) != 0 {
|
|
|
|
stderr.Write(frame.Stderr.Data)
|
|
|
|
}
|
|
|
|
// don't really do anything if stderr is closing
|
|
|
|
case frame.Exited && frame.Result != nil:
|
|
|
|
return frame.Result.ExitCode, nil
|
|
|
|
default:
|
|
|
|
// noop - heartbeat
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func (a *Allocations) execFrames(ctx context.Context, alloc *Allocation, task string, tty bool, command []string,
|
|
|
|
errCh chan<- error, q *QueryOptions) (sendFn func(*ExecStreamingInput) error, output <-chan *ExecStreamingOutput) {
|
2019-10-04 15:23:59 +00:00
|
|
|
nodeClient, _ := a.client.GetNodeClientWithTimeout(alloc.NodeID, ClientConnTimeout, q)
|
2019-04-28 21:34:01 +00:00
|
|
|
|
|
|
|
if q == nil {
|
|
|
|
q = &QueryOptions{}
|
|
|
|
}
|
|
|
|
if q.Params == nil {
|
|
|
|
q.Params = make(map[string]string)
|
|
|
|
}
|
|
|
|
|
|
|
|
commandBytes, err := json.Marshal(command)
|
|
|
|
if err != nil {
|
|
|
|
errCh <- fmt.Errorf("failed to marshal command: %s", err)
|
|
|
|
return nil, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
q.Params["tty"] = strconv.FormatBool(tty)
|
|
|
|
q.Params["task"] = task
|
|
|
|
q.Params["command"] = string(commandBytes)
|
|
|
|
|
|
|
|
reqPath := fmt.Sprintf("/v1/client/allocation/%s/exec", alloc.ID)
|
|
|
|
|
2019-10-04 15:23:59 +00:00
|
|
|
var conn *websocket.Conn
|
|
|
|
|
|
|
|
if nodeClient != nil {
|
2020-03-04 22:43:00 +00:00
|
|
|
conn, _, _ = nodeClient.websocket(reqPath, q)
|
2019-10-04 15:23:59 +00:00
|
|
|
}
|
2019-04-28 21:34:01 +00:00
|
|
|
|
2019-10-04 15:23:59 +00:00
|
|
|
if conn == nil {
|
2019-04-28 21:34:01 +00:00
|
|
|
conn, _, err = a.client.websocket(reqPath, q)
|
|
|
|
if err != nil {
|
|
|
|
errCh <- err
|
|
|
|
return nil, nil
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Create the output channel
|
|
|
|
frames := make(chan *ExecStreamingOutput, 10)
|
|
|
|
|
|
|
|
go func() {
|
|
|
|
defer conn.Close()
|
|
|
|
for ctx.Err() == nil {
|
|
|
|
|
|
|
|
// Decode the next frame
|
|
|
|
var frame ExecStreamingOutput
|
|
|
|
err := conn.ReadJSON(&frame)
|
|
|
|
if websocket.IsCloseError(err, websocket.CloseNormalClosure) {
|
|
|
|
close(frames)
|
|
|
|
return
|
|
|
|
} else if err != nil {
|
|
|
|
errCh <- err
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
frames <- &frame
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
|
|
|
var sendLock sync.Mutex
|
|
|
|
send := func(v *ExecStreamingInput) error {
|
|
|
|
sendLock.Lock()
|
|
|
|
defer sendLock.Unlock()
|
|
|
|
|
|
|
|
return conn.WriteJSON(v)
|
|
|
|
}
|
|
|
|
|
|
|
|
return send, frames
|
|
|
|
|
|
|
|
}
|
|
|
|
|
2016-06-12 03:15:50 +00:00
|
|
|
func (a *Allocations) Stats(alloc *Allocation, q *QueryOptions) (*AllocResourceUsage, error) {
|
|
|
|
var resp AllocResourceUsage
|
2018-02-07 02:51:34 +00:00
|
|
|
path := fmt.Sprintf("/v1/client/allocation/%s/stats", alloc.ID)
|
|
|
|
_, err := a.client.query(path, &resp, q)
|
2016-06-12 03:15:50 +00:00
|
|
|
return &resp, err
|
2016-04-29 20:03:02 +00:00
|
|
|
}
|
|
|
|
|
2017-01-13 00:18:29 +00:00
|
|
|
func (a *Allocations) GC(alloc *Allocation, q *QueryOptions) error {
|
2017-08-28 21:41:21 +00:00
|
|
|
nodeClient, err := a.client.GetNodeClient(alloc.NodeID, q)
|
2017-01-13 00:18:29 +00:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
var resp struct{}
|
2017-08-28 18:32:52 +00:00
|
|
|
_, err = nodeClient.query("/v1/client/allocation/"+alloc.ID+"/gc", &resp, nil)
|
2017-01-13 00:18:29 +00:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2019-04-01 12:56:02 +00:00
|
|
|
func (a *Allocations) Restart(alloc *Allocation, taskName string, q *QueryOptions) error {
|
|
|
|
req := AllocationRestartRequest{
|
|
|
|
TaskName: taskName,
|
|
|
|
}
|
|
|
|
|
|
|
|
var resp struct{}
|
|
|
|
_, err := a.client.putQuery("/v1/client/allocation/"+alloc.ID+"/restart", &req, &resp, q)
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2019-04-01 14:21:03 +00:00
|
|
|
func (a *Allocations) Stop(alloc *Allocation, q *QueryOptions) (*AllocStopResponse, error) {
|
|
|
|
var resp AllocStopResponse
|
|
|
|
_, err := a.client.putQuery("/v1/allocation/"+alloc.ID+"/stop", nil, &resp, q)
|
|
|
|
return &resp, err
|
|
|
|
}
|
|
|
|
|
|
|
|
// AllocStopResponse is the response to an `AllocStopRequest`
|
|
|
|
type AllocStopResponse struct {
|
|
|
|
// EvalID is the id of the follow up evalution for the rescheduled alloc.
|
|
|
|
EvalID string
|
|
|
|
|
|
|
|
WriteMeta
|
|
|
|
}
|
|
|
|
|
2019-04-03 10:46:15 +00:00
|
|
|
func (a *Allocations) Signal(alloc *Allocation, q *QueryOptions, task, signal string) error {
|
|
|
|
nodeClient, err := a.client.GetNodeClient(alloc.NodeID, q)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2019-04-27 12:33:47 +00:00
|
|
|
req := AllocSignalRequest{
|
2019-06-21 21:44:38 +00:00
|
|
|
Signal: signal,
|
|
|
|
Task: task,
|
2019-04-03 10:46:15 +00:00
|
|
|
}
|
|
|
|
|
2019-04-27 12:33:47 +00:00
|
|
|
var resp GenericResponse
|
2019-04-03 10:46:15 +00:00
|
|
|
_, err = nodeClient.putQuery("/v1/client/allocation/"+alloc.ID+"/signal", &req, &resp, q)
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2015-09-09 00:49:31 +00:00
|
|
|
// Allocation is used for serialization of allocations.
|
|
|
|
type Allocation struct {
|
2018-09-10 17:38:36 +00:00
|
|
|
ID string
|
|
|
|
Namespace string
|
|
|
|
EvalID string
|
|
|
|
Name string
|
|
|
|
NodeID string
|
2018-07-17 10:03:13 +00:00
|
|
|
NodeName string
|
2018-09-10 17:38:36 +00:00
|
|
|
JobID string
|
|
|
|
Job *Job
|
|
|
|
TaskGroup string
|
|
|
|
Resources *Resources
|
|
|
|
TaskResources map[string]*Resources
|
|
|
|
AllocatedResources *AllocatedResources
|
|
|
|
Services map[string]string
|
|
|
|
Metrics *AllocationMetric
|
|
|
|
DesiredStatus string
|
|
|
|
DesiredDescription string
|
|
|
|
DesiredTransition DesiredTransition
|
|
|
|
ClientStatus string
|
|
|
|
ClientDescription string
|
|
|
|
TaskStates map[string]*TaskState
|
|
|
|
DeploymentID string
|
|
|
|
DeploymentStatus *AllocDeploymentStatus
|
|
|
|
FollowupEvalID string
|
|
|
|
PreviousAllocation string
|
|
|
|
NextAllocation string
|
|
|
|
RescheduleTracker *RescheduleTracker
|
|
|
|
PreemptedAllocations []string
|
|
|
|
PreemptedByAllocation string
|
|
|
|
CreateIndex uint64
|
|
|
|
ModifyIndex uint64
|
|
|
|
AllocModifyIndex uint64
|
|
|
|
CreateTime int64
|
|
|
|
ModifyTime int64
|
2015-09-14 02:55:47 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// AllocationMetric is used to deserialize allocation metrics.
|
|
|
|
type AllocationMetric struct {
|
|
|
|
NodesEvaluated int
|
|
|
|
NodesFiltered int
|
2016-01-04 22:23:06 +00:00
|
|
|
NodesAvailable map[string]int
|
2015-09-14 02:55:47 +00:00
|
|
|
ClassFiltered map[string]int
|
|
|
|
ConstraintFiltered map[string]int
|
|
|
|
NodesExhausted int
|
|
|
|
ClassExhausted map[string]int
|
2015-09-18 19:06:51 +00:00
|
|
|
DimensionExhausted map[string]int
|
2017-10-13 21:36:02 +00:00
|
|
|
QuotaExhausted []string
|
2018-08-18 01:11:07 +00:00
|
|
|
// Deprecated, replaced with ScoreMetaData
|
|
|
|
Scores map[string]float64
|
|
|
|
AllocationTime time.Duration
|
|
|
|
CoalescedFailures int
|
|
|
|
ScoreMetaData []*NodeScoreMeta
|
2018-08-08 14:41:56 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// NodeScoreMeta is used to serialize node scoring metadata
|
|
|
|
// displayed in the CLI during verbose mode
|
|
|
|
type NodeScoreMeta struct {
|
2018-08-17 23:44:00 +00:00
|
|
|
NodeID string
|
|
|
|
Scores map[string]float64
|
|
|
|
NormScore float64
|
2015-09-14 02:55:47 +00:00
|
|
|
}
|
|
|
|
|
2020-03-06 15:09:10 +00:00
|
|
|
// Stub returns a list stub for the allocation
|
|
|
|
func (a *Allocation) Stub() *AllocationListStub {
|
|
|
|
return &AllocationListStub{
|
|
|
|
ID: a.ID,
|
|
|
|
EvalID: a.EvalID,
|
|
|
|
Name: a.Name,
|
|
|
|
Namespace: a.Namespace,
|
|
|
|
NodeID: a.NodeID,
|
|
|
|
NodeName: a.NodeName,
|
|
|
|
JobID: a.JobID,
|
|
|
|
JobType: *a.Job.Type,
|
|
|
|
JobVersion: *a.Job.Version,
|
|
|
|
TaskGroup: a.TaskGroup,
|
|
|
|
DesiredStatus: a.DesiredStatus,
|
|
|
|
DesiredDescription: a.DesiredDescription,
|
|
|
|
ClientStatus: a.ClientStatus,
|
|
|
|
ClientDescription: a.ClientDescription,
|
|
|
|
TaskStates: a.TaskStates,
|
|
|
|
DeploymentStatus: a.DeploymentStatus,
|
|
|
|
FollowupEvalID: a.FollowupEvalID,
|
|
|
|
RescheduleTracker: a.RescheduleTracker,
|
|
|
|
PreemptedAllocations: a.PreemptedAllocations,
|
|
|
|
PreemptedByAllocation: a.PreemptedByAllocation,
|
|
|
|
CreateIndex: a.CreateIndex,
|
|
|
|
ModifyIndex: a.ModifyIndex,
|
|
|
|
CreateTime: a.CreateTime,
|
|
|
|
ModifyTime: a.ModifyTime,
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2015-09-14 02:55:47 +00:00
|
|
|
// AllocationListStub is used to return a subset of an allocation
|
|
|
|
// during list operations.
|
|
|
|
type AllocationListStub struct {
|
2019-04-18 15:24:31 +00:00
|
|
|
ID string
|
|
|
|
EvalID string
|
|
|
|
Name string
|
|
|
|
Namespace string
|
|
|
|
NodeID string
|
|
|
|
NodeName string
|
|
|
|
JobID string
|
|
|
|
JobType string
|
|
|
|
JobVersion uint64
|
|
|
|
TaskGroup string
|
|
|
|
DesiredStatus string
|
|
|
|
DesiredDescription string
|
|
|
|
ClientStatus string
|
|
|
|
ClientDescription string
|
|
|
|
TaskStates map[string]*TaskState
|
|
|
|
DeploymentStatus *AllocDeploymentStatus
|
|
|
|
FollowupEvalID string
|
|
|
|
RescheduleTracker *RescheduleTracker
|
|
|
|
PreemptedAllocations []string
|
|
|
|
PreemptedByAllocation string
|
|
|
|
CreateIndex uint64
|
|
|
|
ModifyIndex uint64
|
|
|
|
CreateTime int64
|
|
|
|
ModifyTime int64
|
2015-09-08 22:37:07 +00:00
|
|
|
}
|
2015-09-17 19:40:51 +00:00
|
|
|
|
2017-06-26 21:23:52 +00:00
|
|
|
// AllocDeploymentStatus captures the status of the allocation as part of the
|
|
|
|
// deployment. This can include things like if the allocation has been marked as
|
2017-10-25 18:06:25 +00:00
|
|
|
// healthy.
|
2017-06-26 21:23:52 +00:00
|
|
|
type AllocDeploymentStatus struct {
|
|
|
|
Healthy *bool
|
2018-04-19 20:58:06 +00:00
|
|
|
Timestamp time.Time
|
|
|
|
Canary bool
|
2017-06-26 21:23:52 +00:00
|
|
|
ModifyIndex uint64
|
|
|
|
}
|
|
|
|
|
2018-10-02 20:36:04 +00:00
|
|
|
type AllocatedResources struct {
|
|
|
|
Tasks map[string]*AllocatedTaskResources
|
|
|
|
Shared AllocatedSharedResources
|
|
|
|
}
|
|
|
|
|
|
|
|
type AllocatedTaskResources struct {
|
|
|
|
Cpu AllocatedCpuResources
|
|
|
|
Memory AllocatedMemoryResources
|
|
|
|
Networks []*NetworkResource
|
|
|
|
}
|
|
|
|
|
|
|
|
type AllocatedSharedResources struct {
|
2019-06-25 22:11:09 +00:00
|
|
|
DiskMB int64
|
|
|
|
Networks []*NetworkResource
|
2018-10-02 20:36:04 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
type AllocatedCpuResources struct {
|
2018-10-16 22:34:32 +00:00
|
|
|
CpuShares int64
|
2018-10-02 20:36:04 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
type AllocatedMemoryResources struct {
|
2018-10-16 22:34:32 +00:00
|
|
|
MemoryMB int64
|
2018-10-02 20:36:04 +00:00
|
|
|
}
|
|
|
|
|
2015-09-17 19:40:51 +00:00
|
|
|
// AllocIndexSort reverse sorts allocs by CreateIndex.
|
|
|
|
type AllocIndexSort []*AllocationListStub
|
|
|
|
|
|
|
|
func (a AllocIndexSort) Len() int {
|
|
|
|
return len(a)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (a AllocIndexSort) Less(i, j int) bool {
|
|
|
|
return a[i].CreateIndex > a[j].CreateIndex
|
|
|
|
}
|
|
|
|
|
|
|
|
func (a AllocIndexSort) Swap(i, j int) {
|
|
|
|
a[i], a[j] = a[j], a[i]
|
|
|
|
}
|
2018-01-19 00:05:20 +00:00
|
|
|
|
2020-03-11 16:47:14 +00:00
|
|
|
func (a Allocation) GetTaskGroup() *TaskGroup {
|
2018-01-25 17:46:12 +00:00
|
|
|
for _, tg := range a.Job.TaskGroups {
|
|
|
|
if *tg.Name == a.TaskGroup {
|
2020-03-11 16:47:14 +00:00
|
|
|
return tg
|
2018-01-25 17:46:12 +00:00
|
|
|
}
|
|
|
|
}
|
2020-03-11 16:47:14 +00:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// RescheduleInfo is used to calculate remaining reschedule attempts
|
|
|
|
// according to the given time and the task groups reschedule policy
|
|
|
|
func (a Allocation) RescheduleInfo(t time.Time) (int, int) {
|
|
|
|
tg := a.GetTaskGroup()
|
|
|
|
if tg == nil || tg.ReschedulePolicy == nil {
|
2018-01-29 22:31:25 +00:00
|
|
|
return 0, 0
|
2018-01-25 17:46:12 +00:00
|
|
|
}
|
2020-03-11 16:47:14 +00:00
|
|
|
reschedulePolicy := tg.ReschedulePolicy
|
2018-01-29 22:31:25 +00:00
|
|
|
availableAttempts := *reschedulePolicy.Attempts
|
|
|
|
interval := *reschedulePolicy.Interval
|
|
|
|
attempted := 0
|
|
|
|
|
|
|
|
// Loop over reschedule tracker to find attempts within the restart policy's interval
|
2018-01-25 17:46:12 +00:00
|
|
|
if a.RescheduleTracker != nil && availableAttempts > 0 && interval > 0 {
|
|
|
|
for j := len(a.RescheduleTracker.Events) - 1; j >= 0; j-- {
|
|
|
|
lastAttempt := a.RescheduleTracker.Events[j].RescheduleTime
|
|
|
|
timeDiff := t.UTC().UnixNano() - lastAttempt
|
|
|
|
if timeDiff < interval.Nanoseconds() {
|
|
|
|
attempted += 1
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
2018-01-29 22:31:25 +00:00
|
|
|
return attempted, availableAttempts
|
2018-01-25 17:46:12 +00:00
|
|
|
}
|
|
|
|
|
2019-04-01 12:56:02 +00:00
|
|
|
type AllocationRestartRequest struct {
|
|
|
|
TaskName string
|
|
|
|
}
|
|
|
|
|
2019-04-27 12:33:47 +00:00
|
|
|
type AllocSignalRequest struct {
|
2019-06-21 21:44:38 +00:00
|
|
|
Task string
|
|
|
|
Signal string
|
2019-04-27 12:33:47 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// GenericResponse is used to respond to a request where no
|
|
|
|
// specific response information is needed.
|
|
|
|
type GenericResponse struct {
|
|
|
|
WriteMeta
|
|
|
|
}
|
|
|
|
|
2018-01-19 00:05:20 +00:00
|
|
|
// RescheduleTracker encapsulates previous reschedule events
|
|
|
|
type RescheduleTracker struct {
|
|
|
|
Events []*RescheduleEvent
|
|
|
|
}
|
|
|
|
|
|
|
|
// RescheduleEvent is used to keep track of previous attempts at rescheduling an allocation
|
|
|
|
type RescheduleEvent struct {
|
|
|
|
// RescheduleTime is the timestamp of a reschedule attempt
|
|
|
|
RescheduleTime int64
|
|
|
|
|
|
|
|
// PrevAllocID is the ID of the previous allocation being restarted
|
|
|
|
PrevAllocID string
|
|
|
|
|
|
|
|
// PrevNodeID is the node ID of the previous allocation
|
|
|
|
PrevNodeID string
|
|
|
|
}
|
2018-02-21 18:58:04 +00:00
|
|
|
|
2018-02-23 01:38:44 +00:00
|
|
|
// DesiredTransition is used to mark an allocation as having a desired state
|
|
|
|
// transition. This information can be used by the scheduler to make the
|
2018-02-21 18:58:04 +00:00
|
|
|
// correct decision.
|
2018-02-23 01:38:44 +00:00
|
|
|
type DesiredTransition struct {
|
2018-02-21 18:58:04 +00:00
|
|
|
// Migrate is used to indicate that this allocation should be stopped and
|
|
|
|
// migrated to another node.
|
|
|
|
Migrate *bool
|
2018-04-07 00:23:35 +00:00
|
|
|
|
|
|
|
// Reschedule is used to indicate that this allocation is eligible to be
|
|
|
|
// rescheduled.
|
|
|
|
Reschedule *bool
|
2018-02-21 18:58:04 +00:00
|
|
|
}
|
2018-03-07 00:23:21 +00:00
|
|
|
|
|
|
|
// ShouldMigrate returns whether the transition object dictates a migration.
|
|
|
|
func (d DesiredTransition) ShouldMigrate() bool {
|
|
|
|
return d.Migrate != nil && *d.Migrate
|
|
|
|
}
|
2019-04-28 21:34:01 +00:00
|
|
|
|
|
|
|
// ExecStreamingIOOperation represents a stream write operation: either appending data or close (exclusively)
|
|
|
|
type ExecStreamingIOOperation struct {
|
|
|
|
Data []byte `json:"data,omitempty"`
|
|
|
|
Close bool `json:"close,omitempty"`
|
|
|
|
}
|
|
|
|
|
|
|
|
// TerminalSize represents the size of the terminal
|
|
|
|
type TerminalSize struct {
|
|
|
|
Height int `json:"height,omitempty"`
|
|
|
|
Width int `json:"width,omitempty"`
|
|
|
|
}
|
|
|
|
|
|
|
|
var execStreamingInputHeartbeat = ExecStreamingInput{}
|
|
|
|
|
|
|
|
// ExecStreamingInput represents user input to be sent to nomad exec handler.
|
|
|
|
//
|
|
|
|
// At most one field should be set.
|
|
|
|
type ExecStreamingInput struct {
|
|
|
|
Stdin *ExecStreamingIOOperation `json:"stdin,omitempty"`
|
|
|
|
TTYSize *TerminalSize `json:"tty_size,omitempty"`
|
|
|
|
}
|
|
|
|
|
|
|
|
// ExecStreamingExitResults captures the exit code of just completed nomad exec command
|
|
|
|
type ExecStreamingExitResult struct {
|
|
|
|
ExitCode int `json:"exit_code"`
|
|
|
|
}
|
|
|
|
|
|
|
|
// ExecStreamingInput represents an output streaming entity, e.g. stdout/stderr update or termination
|
|
|
|
//
|
|
|
|
// At most one of these fields should be set: `Stdout`, `Stderr`, or `Result`.
|
|
|
|
// If `Exited` is true, then `Result` is non-nil, and other fields are nil.
|
|
|
|
type ExecStreamingOutput struct {
|
|
|
|
Stdout *ExecStreamingIOOperation `json:"stdout,omitempty"`
|
|
|
|
Stderr *ExecStreamingIOOperation `json:"stderr,omitempty"`
|
|
|
|
|
|
|
|
Exited bool `json:"exited,omitempty"`
|
|
|
|
Result *ExecStreamingExitResult `json:"result,omitempty"`
|
|
|
|
}
|