2020-08-05 01:11:32 +00:00
|
|
|
package gateway
|
|
|
|
|
|
|
|
import (
|
|
|
|
"context"
|
2020-09-15 06:40:05 +00:00
|
|
|
"fmt"
|
2020-10-27 21:51:51 +00:00
|
|
|
"runtime"
|
2020-09-15 06:40:05 +00:00
|
|
|
"sort"
|
2020-08-05 01:11:32 +00:00
|
|
|
"strings"
|
|
|
|
"sync"
|
|
|
|
|
|
|
|
"github.com/moby/buildkit/cache"
|
|
|
|
"github.com/moby/buildkit/executor"
|
|
|
|
"github.com/moby/buildkit/frontend/gateway/client"
|
2020-09-15 06:40:05 +00:00
|
|
|
"github.com/moby/buildkit/session"
|
2020-10-27 06:13:39 +00:00
|
|
|
"github.com/moby/buildkit/snapshot"
|
2020-08-05 01:11:32 +00:00
|
|
|
"github.com/moby/buildkit/solver"
|
2020-09-15 06:40:05 +00:00
|
|
|
"github.com/moby/buildkit/solver/llbsolver/mounts"
|
2020-08-05 01:11:32 +00:00
|
|
|
opspb "github.com/moby/buildkit/solver/pb"
|
|
|
|
"github.com/moby/buildkit/util/stack"
|
|
|
|
utilsystem "github.com/moby/buildkit/util/system"
|
|
|
|
"github.com/moby/buildkit/worker"
|
|
|
|
"github.com/pkg/errors"
|
|
|
|
"github.com/sirupsen/logrus"
|
|
|
|
"golang.org/x/sync/errgroup"
|
|
|
|
)
|
|
|
|
|
|
|
|
type NewContainerRequest struct {
|
2020-10-02 05:36:33 +00:00
|
|
|
ContainerID string
|
|
|
|
NetMode opspb.NetMode
|
|
|
|
Mounts []Mount
|
2020-10-27 21:51:51 +00:00
|
|
|
Platform *opspb.Platform
|
|
|
|
Constraints *opspb.WorkerConstraints
|
2020-08-05 01:11:32 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// Mount used for the gateway.Container is nearly identical to the client.Mount
|
|
|
|
// except is has a RefProxy instead of Ref to allow for a common abstraction
|
|
|
|
// between gateway clients.
|
|
|
|
type Mount struct {
|
|
|
|
Dest string
|
|
|
|
Selector string
|
|
|
|
Readonly bool
|
|
|
|
MountType opspb.MountType
|
|
|
|
RefProxy solver.ResultProxy
|
2020-09-15 06:40:05 +00:00
|
|
|
CacheOpt *opspb.CacheOpt
|
|
|
|
SecretOpt *opspb.SecretOpt
|
|
|
|
SSHOpt *opspb.SSHOpt
|
2020-08-05 01:11:32 +00:00
|
|
|
}
|
|
|
|
|
2020-09-15 06:40:05 +00:00
|
|
|
func toProtoMount(m Mount) *opspb.Mount {
|
|
|
|
return &opspb.Mount{
|
|
|
|
Selector: m.Selector,
|
|
|
|
Dest: m.Dest,
|
|
|
|
Readonly: m.Readonly,
|
|
|
|
MountType: m.MountType,
|
|
|
|
CacheOpt: m.CacheOpt,
|
|
|
|
SecretOpt: m.SecretOpt,
|
|
|
|
SSHOpt: m.SSHOpt,
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func NewContainer(ctx context.Context, e executor.Executor, sm *session.Manager, g session.Group, req NewContainerRequest) (client.Container, error) {
|
2020-08-05 01:11:32 +00:00
|
|
|
ctx, cancel := context.WithCancel(ctx)
|
|
|
|
eg, ctx := errgroup.WithContext(ctx)
|
2020-10-27 21:51:51 +00:00
|
|
|
platform := opspb.Platform{
|
|
|
|
OS: runtime.GOOS,
|
|
|
|
Architecture: runtime.GOARCH,
|
|
|
|
}
|
|
|
|
if req.Platform != nil {
|
|
|
|
platform = *req.Platform
|
|
|
|
}
|
2020-08-05 01:11:32 +00:00
|
|
|
ctr := &gatewayContainer{
|
2020-10-02 05:36:33 +00:00
|
|
|
id: req.ContainerID,
|
|
|
|
netMode: req.NetMode,
|
2020-10-27 21:51:51 +00:00
|
|
|
platform: platform,
|
2020-10-02 05:36:33 +00:00
|
|
|
executor: e,
|
|
|
|
errGroup: eg,
|
|
|
|
ctx: ctx,
|
|
|
|
cancel: cancel,
|
2020-08-05 01:11:32 +00:00
|
|
|
}
|
|
|
|
|
2020-09-15 06:40:05 +00:00
|
|
|
makeMutable := func(worker worker.Worker, ref cache.ImmutableRef) (cache.MutableRef, error) {
|
2020-10-27 06:13:39 +00:00
|
|
|
mRef, err := worker.CacheManager().New(ctx, ref, g)
|
2020-08-05 01:11:32 +00:00
|
|
|
if err != nil {
|
|
|
|
return nil, stack.Enable(err)
|
|
|
|
}
|
2020-09-15 06:40:05 +00:00
|
|
|
ctr.cleanup = append(ctr.cleanup, func() error {
|
|
|
|
return stack.Enable(mRef.Release(context.TODO()))
|
|
|
|
})
|
|
|
|
return mRef, nil
|
|
|
|
}
|
2020-08-05 01:11:32 +00:00
|
|
|
|
2020-10-02 05:41:18 +00:00
|
|
|
var mm *mounts.MountManager
|
2020-09-15 06:40:05 +00:00
|
|
|
mnts := req.Mounts
|
|
|
|
|
|
|
|
for i, m := range mnts {
|
|
|
|
if m.Dest == opspb.RootMount && m.RefProxy != nil {
|
|
|
|
res, err := m.RefProxy.Result(ctx)
|
|
|
|
if err != nil {
|
|
|
|
return nil, stack.Enable(err)
|
|
|
|
}
|
|
|
|
workerRef, ok := res.Sys().(*worker.WorkerRef)
|
|
|
|
if !ok {
|
|
|
|
return nil, errors.Errorf("invalid reference for exec %T", res.Sys())
|
|
|
|
}
|
|
|
|
|
|
|
|
name := fmt.Sprintf("container %s", req.ContainerID)
|
|
|
|
mm = mounts.NewMountManager(name, workerRef.Worker.CacheManager(), sm, workerRef.Worker.MetadataStore())
|
|
|
|
|
2020-10-27 06:13:39 +00:00
|
|
|
ctr.rootFS = mountWithSession(workerRef.ImmutableRef, g)
|
2020-09-15 06:40:05 +00:00
|
|
|
if !m.Readonly {
|
2020-10-27 06:13:39 +00:00
|
|
|
ref, err := makeMutable(workerRef.Worker, workerRef.ImmutableRef)
|
2020-09-15 06:40:05 +00:00
|
|
|
if err != nil {
|
|
|
|
return nil, stack.Enable(err)
|
|
|
|
}
|
2020-10-27 06:13:39 +00:00
|
|
|
ctr.rootFS = mountWithSession(ref, g)
|
2020-09-15 06:40:05 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// delete root mount from list, handled here
|
|
|
|
mnts = append(mnts[:i], mnts[i+1:]...)
|
|
|
|
break
|
2020-08-05 01:11:32 +00:00
|
|
|
}
|
2020-09-15 06:40:05 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
if ctr.rootFS == nil {
|
|
|
|
return nil, errors.Errorf("root mount required")
|
|
|
|
}
|
|
|
|
|
|
|
|
for _, m := range mnts {
|
|
|
|
var ref cache.ImmutableRef
|
|
|
|
var mountable cache.Mountable
|
|
|
|
if m.RefProxy != nil {
|
|
|
|
res, err := m.RefProxy.Result(ctx)
|
2020-08-05 01:11:32 +00:00
|
|
|
if err != nil {
|
|
|
|
return nil, stack.Enable(err)
|
|
|
|
}
|
2020-09-15 06:40:05 +00:00
|
|
|
workerRef, ok := res.Sys().(*worker.WorkerRef)
|
|
|
|
if !ok {
|
|
|
|
return nil, errors.Errorf("invalid reference for exec %T", res.Sys())
|
|
|
|
}
|
|
|
|
ref = workerRef.ImmutableRef
|
|
|
|
mountable = ref
|
|
|
|
|
|
|
|
if !m.Readonly {
|
|
|
|
mountable, err = makeMutable(workerRef.Worker, ref)
|
|
|
|
if err != nil {
|
|
|
|
return nil, stack.Enable(err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
switch m.MountType {
|
|
|
|
case opspb.MountType_BIND:
|
|
|
|
// nothing to do here
|
|
|
|
case opspb.MountType_CACHE:
|
2020-10-27 06:13:39 +00:00
|
|
|
mRef, err := mm.MountableCache(ctx, toProtoMount(m), ref, g)
|
2020-09-15 06:40:05 +00:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
mountable = mRef
|
2020-09-11 16:48:24 +00:00
|
|
|
ctr.cleanup = append(ctr.cleanup, func() error {
|
2020-09-15 06:40:05 +00:00
|
|
|
return stack.Enable(mRef.Release(context.TODO()))
|
2020-08-05 01:11:32 +00:00
|
|
|
})
|
2020-09-15 06:40:05 +00:00
|
|
|
case opspb.MountType_TMPFS:
|
|
|
|
mountable = mm.MountableTmpFS()
|
|
|
|
case opspb.MountType_SECRET:
|
|
|
|
var err error
|
|
|
|
mountable, err = mm.MountableSecret(ctx, toProtoMount(m), g)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
if mountable == nil {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
case opspb.MountType_SSH:
|
|
|
|
var err error
|
|
|
|
mountable, err = mm.MountableSSH(ctx, toProtoMount(m), g)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
if mountable == nil {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
default:
|
|
|
|
return nil, errors.Errorf("mount type %s not implemented", m.MountType)
|
|
|
|
}
|
2020-09-11 16:48:24 +00:00
|
|
|
|
2020-09-15 06:40:05 +00:00
|
|
|
// validate that there is a mount
|
|
|
|
if mountable == nil {
|
|
|
|
return nil, errors.Errorf("mount %s has no input", m.Dest)
|
2020-08-05 01:11:32 +00:00
|
|
|
}
|
|
|
|
|
2020-09-15 06:40:05 +00:00
|
|
|
execMount := executor.Mount{
|
2020-10-27 06:13:39 +00:00
|
|
|
Src: mountWithSession(mountable, g),
|
2020-09-15 06:40:05 +00:00
|
|
|
Selector: m.Selector,
|
|
|
|
Dest: m.Dest,
|
|
|
|
Readonly: m.Readonly,
|
2020-08-05 01:11:32 +00:00
|
|
|
}
|
2020-09-15 06:40:05 +00:00
|
|
|
|
|
|
|
ctr.mounts = append(ctr.mounts, execMount)
|
2020-08-05 01:11:32 +00:00
|
|
|
}
|
|
|
|
|
2020-09-15 06:40:05 +00:00
|
|
|
// sort mounts so parents are mounted first
|
|
|
|
sort.Slice(ctr.mounts, func(i, j int) bool {
|
|
|
|
return ctr.mounts[i].Dest < ctr.mounts[j].Dest
|
|
|
|
})
|
|
|
|
|
2020-08-05 01:11:32 +00:00
|
|
|
return ctr, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
type gatewayContainer struct {
|
2020-10-02 07:09:35 +00:00
|
|
|
id string
|
|
|
|
netMode opspb.NetMode
|
2020-10-27 21:51:51 +00:00
|
|
|
platform opspb.Platform
|
2020-10-27 06:13:39 +00:00
|
|
|
rootFS executor.Mountable
|
2020-10-02 07:09:35 +00:00
|
|
|
mounts []executor.Mount
|
|
|
|
executor executor.Executor
|
|
|
|
started bool
|
|
|
|
errGroup *errgroup.Group
|
|
|
|
mu sync.Mutex
|
|
|
|
cleanup []func() error
|
|
|
|
ctx context.Context
|
|
|
|
cancel func()
|
2020-08-05 01:11:32 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
func (gwCtr *gatewayContainer) Start(ctx context.Context, req client.StartRequest) (client.ContainerProcess, error) {
|
|
|
|
resize := make(chan executor.WinSize)
|
|
|
|
procInfo := executor.ProcessInfo{
|
|
|
|
Meta: executor.Meta{
|
|
|
|
Args: req.Args,
|
|
|
|
Env: req.Env,
|
|
|
|
User: req.User,
|
|
|
|
Cwd: req.Cwd,
|
|
|
|
Tty: req.Tty,
|
|
|
|
NetMode: gwCtr.netMode,
|
2020-10-02 05:36:33 +00:00
|
|
|
SecurityMode: req.SecurityMode,
|
2020-08-05 01:11:32 +00:00
|
|
|
},
|
|
|
|
Stdin: req.Stdin,
|
|
|
|
Stdout: req.Stdout,
|
|
|
|
Stderr: req.Stderr,
|
|
|
|
Resize: resize,
|
|
|
|
}
|
2020-10-02 20:54:00 +00:00
|
|
|
if procInfo.Meta.Cwd == "" {
|
|
|
|
procInfo.Meta.Cwd = "/"
|
|
|
|
}
|
2020-10-27 21:51:51 +00:00
|
|
|
procInfo.Meta.Env = addDefaultEnvvar(procInfo.Meta.Env, "PATH", utilsystem.DefaultPathEnv(gwCtr.platform.OS))
|
2020-08-05 01:11:32 +00:00
|
|
|
if req.Tty {
|
|
|
|
procInfo.Meta.Env = addDefaultEnvvar(procInfo.Meta.Env, "TERM", "xterm")
|
|
|
|
}
|
|
|
|
|
|
|
|
// mark that we have started on the first call to execProcess for this
|
|
|
|
// container, so that future calls will call Exec rather than Run
|
|
|
|
gwCtr.mu.Lock()
|
|
|
|
started := gwCtr.started
|
|
|
|
gwCtr.started = true
|
|
|
|
gwCtr.mu.Unlock()
|
|
|
|
|
|
|
|
eg, ctx := errgroup.WithContext(gwCtr.ctx)
|
|
|
|
gwProc := &gatewayContainerProcess{
|
|
|
|
resize: resize,
|
|
|
|
errGroup: eg,
|
|
|
|
groupCtx: ctx,
|
|
|
|
}
|
|
|
|
|
|
|
|
if !started {
|
|
|
|
startedCh := make(chan struct{})
|
|
|
|
gwProc.errGroup.Go(func() error {
|
|
|
|
logrus.Debugf("Starting new container for %s with args: %q", gwCtr.id, procInfo.Meta.Args)
|
|
|
|
err := gwCtr.executor.Run(ctx, gwCtr.id, gwCtr.rootFS, gwCtr.mounts, procInfo, startedCh)
|
|
|
|
return stack.Enable(err)
|
|
|
|
})
|
|
|
|
select {
|
|
|
|
case <-ctx.Done():
|
|
|
|
case <-startedCh:
|
|
|
|
}
|
|
|
|
} else {
|
|
|
|
gwProc.errGroup.Go(func() error {
|
|
|
|
logrus.Debugf("Execing into container %s with args: %q", gwCtr.id, procInfo.Meta.Args)
|
|
|
|
err := gwCtr.executor.Exec(ctx, gwCtr.id, procInfo)
|
|
|
|
return stack.Enable(err)
|
|
|
|
})
|
|
|
|
}
|
|
|
|
|
|
|
|
gwCtr.errGroup.Go(gwProc.errGroup.Wait)
|
|
|
|
|
|
|
|
return gwProc, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (gwCtr *gatewayContainer) Release(ctx context.Context) error {
|
|
|
|
gwCtr.cancel()
|
|
|
|
err1 := gwCtr.errGroup.Wait()
|
|
|
|
|
|
|
|
var err2 error
|
|
|
|
for i := len(gwCtr.cleanup) - 1; i >= 0; i-- { // call in LIFO order
|
|
|
|
err := gwCtr.cleanup[i]()
|
|
|
|
if err2 == nil {
|
|
|
|
err2 = err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
if err1 != nil {
|
|
|
|
return stack.Enable(err1)
|
|
|
|
}
|
|
|
|
return stack.Enable(err2)
|
|
|
|
}
|
|
|
|
|
|
|
|
type gatewayContainerProcess struct {
|
|
|
|
errGroup *errgroup.Group
|
|
|
|
groupCtx context.Context
|
|
|
|
resize chan<- executor.WinSize
|
|
|
|
mu sync.Mutex
|
|
|
|
}
|
|
|
|
|
|
|
|
func (gwProc *gatewayContainerProcess) Wait() error {
|
|
|
|
err := stack.Enable(gwProc.errGroup.Wait())
|
|
|
|
gwProc.mu.Lock()
|
|
|
|
defer gwProc.mu.Unlock()
|
|
|
|
close(gwProc.resize)
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
func (gwProc *gatewayContainerProcess) Resize(ctx context.Context, size client.WinSize) error {
|
|
|
|
gwProc.mu.Lock()
|
|
|
|
defer gwProc.mu.Unlock()
|
|
|
|
|
|
|
|
// is the container done or should we proceed with sending event?
|
|
|
|
select {
|
|
|
|
case <-gwProc.groupCtx.Done():
|
|
|
|
return nil
|
|
|
|
case <-ctx.Done():
|
|
|
|
return nil
|
|
|
|
default:
|
|
|
|
}
|
|
|
|
|
|
|
|
// now we select on contexts again in case p.resize blocks b/c
|
|
|
|
// container no longer reading from it. In that case when
|
|
|
|
// the errgroup finishes we want to unblock on the write
|
|
|
|
// and exit
|
|
|
|
select {
|
|
|
|
case <-gwProc.groupCtx.Done():
|
|
|
|
case <-ctx.Done():
|
|
|
|
case gwProc.resize <- executor.WinSize{Cols: size.Cols, Rows: size.Rows}:
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func addDefaultEnvvar(env []string, k, v string) []string {
|
|
|
|
for _, e := range env {
|
|
|
|
if strings.HasPrefix(e, k+"=") {
|
|
|
|
return env
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return append(env, k+"="+v)
|
|
|
|
}
|
2020-10-27 06:13:39 +00:00
|
|
|
|
|
|
|
func mountWithSession(m cache.Mountable, g session.Group) executor.Mountable {
|
|
|
|
return &mountable{m: m, g: g}
|
|
|
|
}
|
|
|
|
|
|
|
|
type mountable struct {
|
|
|
|
m cache.Mountable
|
|
|
|
g session.Group
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mountable) Mount(ctx context.Context, readonly bool) (snapshot.Mountable, error) {
|
|
|
|
return m.m.Mount(ctx, readonly, m.g)
|
|
|
|
}
|