2024-06-17 18:51:02 +00:00
|
|
|
// Package daemon implements the isle daemon, which is a long-running service
|
2024-07-06 13:36:48 +00:00
|
|
|
// managing all isle background tasks and sub-processes for a single network.
|
2022-10-26 21:21:31 +00:00
|
|
|
package daemon
|
|
|
|
|
|
|
|
import (
|
2024-07-06 13:36:48 +00:00
|
|
|
"bytes"
|
2024-06-17 18:51:02 +00:00
|
|
|
"context"
|
2024-07-06 13:36:48 +00:00
|
|
|
"errors"
|
2022-10-26 21:21:31 +00:00
|
|
|
"fmt"
|
|
|
|
"io"
|
2024-07-07 10:44:49 +00:00
|
|
|
"io/fs"
|
2024-06-17 18:51:02 +00:00
|
|
|
"isle/bootstrap"
|
2024-07-14 09:58:39 +00:00
|
|
|
"isle/jsonutil"
|
2024-07-07 18:01:10 +00:00
|
|
|
"isle/nebula"
|
2024-07-13 12:34:06 +00:00
|
|
|
"isle/secrets"
|
2024-07-13 14:31:52 +00:00
|
|
|
"net/netip"
|
2022-10-26 21:21:31 +00:00
|
|
|
"os"
|
2024-07-13 12:34:06 +00:00
|
|
|
"path/filepath"
|
2024-07-06 13:36:48 +00:00
|
|
|
"sync"
|
|
|
|
"time"
|
2022-10-26 21:21:31 +00:00
|
|
|
|
2024-06-22 15:49:56 +00:00
|
|
|
"dev.mediocregopher.com/mediocre-go-lib.git/mlog"
|
2022-10-26 21:21:31 +00:00
|
|
|
)
|
|
|
|
|
2024-07-14 11:33:29 +00:00
|
|
|
// CreateHostOpts are optional parameters to the CreateHost method.
|
|
|
|
type CreateHostOpts struct {
|
|
|
|
// CanCreateHosts indicates that the bootstrap produced by CreateHost should
|
|
|
|
// give the new host the ability to create new hosts as well.
|
|
|
|
CanCreateHosts bool
|
|
|
|
}
|
|
|
|
|
2024-07-14 12:43:17 +00:00
|
|
|
// CreateNebulaCertificateOpts are optional parameters to the
|
|
|
|
// CreateNebulaCertificate method.
|
|
|
|
type CreateNebulaCertificateOpts struct {
|
|
|
|
|
|
|
|
// IP, if given will be used for the host's IP in the created cert. If this
|
|
|
|
// is given then it is not required that the host have an entry in garage.
|
|
|
|
//
|
|
|
|
// TODO once `hosts create` automatically adds the host to garage this can
|
|
|
|
// be removed.
|
|
|
|
IP netip.Addr
|
|
|
|
}
|
|
|
|
|
2024-06-17 18:51:02 +00:00
|
|
|
// Daemon presents all functionality required for client frontends to interact
|
|
|
|
// with isle, typically via the unix socket.
|
|
|
|
type Daemon interface {
|
|
|
|
|
2024-07-07 18:01:10 +00:00
|
|
|
// CreateNetwork will initialize a new network using the given parameters.
|
|
|
|
// - name: Human-readable name of the network.
|
|
|
|
// - domain: Primary domain name that network services are served under.
|
2024-07-12 13:30:21 +00:00
|
|
|
// - ipNet: An IP subnet, in CIDR form, which will be the overall range of
|
|
|
|
// possible IPs in the network. The first IP in this network range will
|
|
|
|
// become this first host's IP.
|
2024-07-07 18:01:10 +00:00
|
|
|
// - hostName: The name of this first host in the network.
|
|
|
|
//
|
2024-07-14 11:11:18 +00:00
|
|
|
// The daemon on which this is called will become the first host in the
|
|
|
|
// network, and will have full administrative privileges.
|
2024-07-07 18:01:10 +00:00
|
|
|
CreateNetwork(
|
2024-07-12 13:30:21 +00:00
|
|
|
ctx context.Context, name, domain string,
|
|
|
|
ipNet nebula.IPNet,
|
|
|
|
hostName nebula.HostName,
|
2024-07-14 11:11:18 +00:00
|
|
|
) error
|
2024-07-07 18:01:10 +00:00
|
|
|
|
2024-07-07 10:44:49 +00:00
|
|
|
// JoinNetwork joins the Daemon to an existing network using the given
|
|
|
|
// Bootstrap.
|
|
|
|
//
|
|
|
|
// Errors:
|
|
|
|
// - ErrAlreadyJoined
|
2024-07-14 09:58:39 +00:00
|
|
|
JoinNetwork(context.Context, JoiningBootstrap) error
|
2024-07-07 10:44:49 +00:00
|
|
|
|
2024-07-12 14:11:42 +00:00
|
|
|
// GetBootstraps returns the currently active Bootstrap.
|
|
|
|
GetBootstrap(context.Context) (bootstrap.Bootstrap, error)
|
2024-07-12 14:03:37 +00:00
|
|
|
|
2024-07-13 12:34:06 +00:00
|
|
|
// GetGarageClientParams returns a GarageClientParams for the current
|
|
|
|
// network state.
|
|
|
|
GetGarageClientParams(context.Context) (GarageClientParams, error)
|
|
|
|
|
2024-07-12 15:05:39 +00:00
|
|
|
// RemoveHost removes the host of the given name from the network.
|
|
|
|
RemoveHost(context.Context, nebula.HostName) error
|
|
|
|
|
2024-07-13 14:31:52 +00:00
|
|
|
// CreateHost creates a bootstrap for a new host with the given name and IP
|
|
|
|
// address.
|
|
|
|
CreateHost(
|
|
|
|
ctx context.Context,
|
|
|
|
hostName nebula.HostName,
|
|
|
|
ip netip.Addr, // TODO automatically choose IP address
|
2024-07-14 11:33:29 +00:00
|
|
|
opts CreateHostOpts,
|
2024-07-13 14:31:52 +00:00
|
|
|
) (
|
2024-07-14 09:58:39 +00:00
|
|
|
JoiningBootstrap, error,
|
2024-07-13 14:31:52 +00:00
|
|
|
)
|
|
|
|
|
2024-07-13 14:08:13 +00:00
|
|
|
// CreateNebulaCertificate creates and signs a new nebula certficate for an
|
|
|
|
// existing host, given the public key for that host. This is currently
|
|
|
|
// mostly useful for creating certs for mobile devices.
|
|
|
|
//
|
|
|
|
// Errors:
|
|
|
|
// - ErrHostNotFound
|
|
|
|
CreateNebulaCertificate(
|
|
|
|
ctx context.Context,
|
|
|
|
hostName nebula.HostName,
|
|
|
|
hostPubKey nebula.EncryptingPublicKey,
|
2024-07-14 12:43:17 +00:00
|
|
|
opts CreateNebulaCertificateOpts,
|
2024-07-13 14:08:13 +00:00
|
|
|
) (
|
|
|
|
nebula.Certificate, error,
|
|
|
|
)
|
|
|
|
|
2024-06-17 18:51:02 +00:00
|
|
|
// Shutdown blocks until all resources held or created by the daemon,
|
2024-06-24 16:55:36 +00:00
|
|
|
// including child processes it has started, have been cleaned up.
|
2024-06-17 18:51:02 +00:00
|
|
|
//
|
|
|
|
// If this returns an error then it's possible that child processes are
|
|
|
|
// still running and are no longer managed.
|
2024-06-24 16:55:36 +00:00
|
|
|
Shutdown() error
|
2024-06-17 18:51:02 +00:00
|
|
|
}
|
2022-10-26 21:21:31 +00:00
|
|
|
|
2024-06-17 18:51:02 +00:00
|
|
|
// Opts are optional parameters which can be passed in when initializing a new
|
|
|
|
// Daemon instance. A nil Opts is equivalent to a zero value.
|
|
|
|
type Opts struct {
|
|
|
|
// Stdout and Stderr are what the associated outputs from child processes
|
|
|
|
// will be directed to.
|
|
|
|
Stdout, Stderr io.Writer
|
2024-06-24 12:45:57 +00:00
|
|
|
|
|
|
|
EnvVars EnvVars // Defaults to that returned by GetEnvVars.
|
2024-06-17 18:51:02 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
func (o *Opts) withDefaults() *Opts {
|
|
|
|
if o == nil {
|
|
|
|
o = new(Opts)
|
2022-10-26 21:21:31 +00:00
|
|
|
}
|
|
|
|
|
2024-06-17 18:51:02 +00:00
|
|
|
if o.Stdout == nil {
|
|
|
|
o.Stdout = os.Stdout
|
|
|
|
}
|
2022-10-26 21:21:31 +00:00
|
|
|
|
2024-06-17 18:51:02 +00:00
|
|
|
if o.Stderr == nil {
|
|
|
|
o.Stderr = os.Stderr
|
2022-10-26 21:21:31 +00:00
|
|
|
}
|
|
|
|
|
2024-06-24 12:45:57 +00:00
|
|
|
if o.EnvVars == (EnvVars{}) {
|
|
|
|
o.EnvVars = GetEnvVars()
|
|
|
|
}
|
|
|
|
|
2024-06-17 18:51:02 +00:00
|
|
|
return o
|
2022-10-26 21:21:31 +00:00
|
|
|
}
|
|
|
|
|
2024-07-06 13:36:48 +00:00
|
|
|
const (
|
2024-07-07 10:44:49 +00:00
|
|
|
daemonStateNoNetwork = iota
|
|
|
|
daemonStateInitializing
|
2024-07-06 13:36:48 +00:00
|
|
|
daemonStateOk
|
|
|
|
daemonStateRestarting
|
|
|
|
daemonStateShutdown
|
|
|
|
)
|
|
|
|
|
2024-06-24 16:55:36 +00:00
|
|
|
type daemon struct {
|
|
|
|
logger *mlog.Logger
|
2024-07-06 13:36:48 +00:00
|
|
|
daemonConfig Config
|
|
|
|
envBinDirPath string
|
|
|
|
opts *Opts
|
|
|
|
|
2024-07-14 10:19:39 +00:00
|
|
|
secretsStore secrets.Store
|
|
|
|
garageAdminToken string
|
2024-07-13 12:34:06 +00:00
|
|
|
|
2024-07-07 10:44:49 +00:00
|
|
|
l sync.RWMutex
|
2024-07-06 13:36:48 +00:00
|
|
|
state int
|
|
|
|
children *Children
|
|
|
|
currBootstrap bootstrap.Bootstrap
|
2024-06-24 16:55:36 +00:00
|
|
|
|
2024-07-07 10:44:49 +00:00
|
|
|
shutdownCh chan struct{}
|
|
|
|
wg sync.WaitGroup
|
2024-06-24 16:55:36 +00:00
|
|
|
}
|
|
|
|
|
2024-07-06 13:36:48 +00:00
|
|
|
// NewDaemon initializes and returns a Daemon instance which will manage all
|
|
|
|
// child processes and state required by the isle service, as well as an HTTP
|
|
|
|
// socket over which RPC calls will be served.
|
|
|
|
//
|
|
|
|
// Inner Children instance(s) will be wrapped such that they will be
|
|
|
|
// automatically shutdown and re-created whenever there's changes in the network
|
|
|
|
// which require the configuration to be changed (e.g. a new nebula lighthouse).
|
|
|
|
// During such an inner restart all methods will return ErrRestarting, except
|
|
|
|
// Shutdown which will block until the currently executing restart is finished
|
|
|
|
// and then shutdown cleanly from there.
|
|
|
|
//
|
|
|
|
// While still starting up the Daemon for the first time all methods will return
|
|
|
|
// ErrInitializing, except Shutdown which will block until initialization is
|
|
|
|
// canceled.
|
|
|
|
//
|
|
|
|
// TODO make daemon smarter, it currently restarts on _any_ change, but
|
|
|
|
// it should restart itself only when there's something actually requiring a
|
|
|
|
// restart.
|
|
|
|
func NewDaemon(
|
2024-07-12 13:30:21 +00:00
|
|
|
logger *mlog.Logger, daemonConfig Config, envBinDirPath string, opts *Opts,
|
2024-07-07 10:44:49 +00:00
|
|
|
) (
|
|
|
|
Daemon, error,
|
|
|
|
) {
|
|
|
|
var (
|
|
|
|
d = &daemon{
|
2024-07-14 10:19:39 +00:00
|
|
|
logger: logger,
|
|
|
|
daemonConfig: daemonConfig,
|
|
|
|
envBinDirPath: envBinDirPath,
|
|
|
|
opts: opts.withDefaults(),
|
|
|
|
garageAdminToken: randStr(32),
|
|
|
|
shutdownCh: make(chan struct{}),
|
2024-07-07 10:44:49 +00:00
|
|
|
}
|
|
|
|
bootstrapFilePath = bootstrap.StateDirPath(d.opts.EnvVars.StateDirPath)
|
|
|
|
)
|
|
|
|
|
2024-07-12 14:34:56 +00:00
|
|
|
if err := d.opts.EnvVars.init(); err != nil {
|
|
|
|
return nil, fmt.Errorf("initializing daemon directories: %w", err)
|
|
|
|
}
|
|
|
|
|
2024-07-13 12:34:06 +00:00
|
|
|
var (
|
|
|
|
secretsPath = filepath.Join(d.opts.EnvVars.StateDirPath, "secrets")
|
|
|
|
err error
|
|
|
|
)
|
|
|
|
|
|
|
|
if d.secretsStore, err = secrets.NewFSStore(secretsPath); err != nil {
|
|
|
|
return nil, fmt.Errorf(
|
|
|
|
"initializing secrets store at %q: %w", secretsPath, err,
|
|
|
|
)
|
|
|
|
}
|
|
|
|
|
2024-07-14 09:58:39 +00:00
|
|
|
var currBootstrap bootstrap.Bootstrap
|
|
|
|
err = jsonutil.LoadFile(&currBootstrap, bootstrapFilePath)
|
2024-07-07 10:44:49 +00:00
|
|
|
if errors.Is(err, fs.ErrNotExist) {
|
|
|
|
// daemon has never had a network created or joined
|
|
|
|
} else if err != nil {
|
|
|
|
return nil, fmt.Errorf(
|
|
|
|
"loading bootstrap from %q: %w", bootstrapFilePath, err,
|
|
|
|
)
|
2024-07-07 18:01:10 +00:00
|
|
|
} else if err := d.initialize(currBootstrap, nil); err != nil {
|
2024-07-07 10:44:49 +00:00
|
|
|
return nil, fmt.Errorf("initializing with bootstrap: %w", err)
|
2024-07-06 13:36:48 +00:00
|
|
|
}
|
|
|
|
|
2024-07-07 10:44:49 +00:00
|
|
|
return d, nil
|
|
|
|
}
|
|
|
|
|
2024-07-07 18:01:10 +00:00
|
|
|
// initialize must be called with d.l write lock held, _but_ the lock should be
|
|
|
|
// released just after initialize returns.
|
|
|
|
//
|
|
|
|
// readyCh will be written to everytime daemon changes state to daemonStateOk,
|
|
|
|
// unless it is nil or blocks.
|
|
|
|
func (d *daemon) initialize(
|
|
|
|
currBootstrap bootstrap.Bootstrap, readyCh chan<- struct{},
|
|
|
|
) error {
|
2024-07-07 10:44:49 +00:00
|
|
|
// we update this Host's data using whatever configuration has been provided
|
|
|
|
// by the daemon config. This way the daemon has the most up-to-date
|
|
|
|
// possible bootstrap. This updated bootstrap will later get updated in
|
|
|
|
// garage as a background daemon task, so other hosts will see it as well.
|
|
|
|
currBootstrap, err := coalesceDaemonConfigAndBootstrap(
|
|
|
|
d.daemonConfig, currBootstrap,
|
|
|
|
)
|
|
|
|
if err != nil {
|
|
|
|
return fmt.Errorf("combining daemon configuration into bootstrap: %w", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
err = writeBootstrapToStateDir(d.opts.EnvVars.StateDirPath, currBootstrap)
|
|
|
|
if err != nil {
|
|
|
|
return fmt.Errorf("writing bootstrap to state dir: %w", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
d.currBootstrap = currBootstrap
|
|
|
|
d.state = daemonStateInitializing
|
|
|
|
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
d.wg.Add(1)
|
2024-07-06 13:36:48 +00:00
|
|
|
go func() {
|
2024-07-07 10:44:49 +00:00
|
|
|
defer d.wg.Done()
|
|
|
|
<-d.shutdownCh
|
|
|
|
cancel()
|
|
|
|
}()
|
|
|
|
|
|
|
|
d.wg.Add(1)
|
|
|
|
go func() {
|
|
|
|
defer d.wg.Done()
|
2024-07-07 18:01:10 +00:00
|
|
|
d.restartLoop(ctx, readyCh)
|
2024-07-07 10:44:49 +00:00
|
|
|
d.logger.Debug(ctx, "Daemon restart loop stopped")
|
2024-07-06 13:36:48 +00:00
|
|
|
}()
|
|
|
|
|
2024-07-07 10:44:49 +00:00
|
|
|
return nil
|
2024-07-06 13:36:48 +00:00
|
|
|
}
|
|
|
|
|
2024-07-07 10:44:49 +00:00
|
|
|
func withCurrBootstrap[Res any](
|
|
|
|
d *daemon, fn func(bootstrap.Bootstrap) (Res, error),
|
2024-07-06 13:36:48 +00:00
|
|
|
) (Res, error) {
|
|
|
|
var zero Res
|
2024-07-07 10:44:49 +00:00
|
|
|
d.l.RLock()
|
|
|
|
defer d.l.RUnlock()
|
|
|
|
|
|
|
|
currBootstrap, state := d.currBootstrap, d.state
|
2024-07-06 13:36:48 +00:00
|
|
|
|
|
|
|
switch state {
|
2024-07-07 10:44:49 +00:00
|
|
|
case daemonStateNoNetwork:
|
|
|
|
return zero, ErrNoNetwork
|
2024-07-06 13:36:48 +00:00
|
|
|
case daemonStateInitializing:
|
|
|
|
return zero, ErrInitializing
|
|
|
|
case daemonStateOk:
|
2024-07-07 10:44:49 +00:00
|
|
|
return fn(currBootstrap)
|
2024-07-06 13:36:48 +00:00
|
|
|
case daemonStateRestarting:
|
|
|
|
return zero, ErrRestarting
|
|
|
|
case daemonStateShutdown:
|
|
|
|
return zero, errors.New("already shutdown")
|
|
|
|
default:
|
|
|
|
panic(fmt.Sprintf("unknown state %d", d.state))
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// creates a new bootstrap file using available information from the network. If
|
|
|
|
// the new bootstrap file is different than the existing one, the existing one
|
|
|
|
// is overwritten and true is returned.
|
|
|
|
func (d *daemon) checkBootstrap(
|
|
|
|
ctx context.Context, hostBootstrap bootstrap.Bootstrap,
|
2022-10-26 21:21:31 +00:00
|
|
|
) (
|
2024-07-06 13:36:48 +00:00
|
|
|
bootstrap.Bootstrap, bool, error,
|
2022-10-26 21:21:31 +00:00
|
|
|
) {
|
|
|
|
|
2024-07-06 13:36:48 +00:00
|
|
|
thisHost := hostBootstrap.ThisHost()
|
2022-10-26 21:21:31 +00:00
|
|
|
|
2024-07-13 12:34:06 +00:00
|
|
|
newHosts, err := d.getGarageBootstrapHosts(ctx, d.logger, hostBootstrap)
|
2024-07-06 13:36:48 +00:00
|
|
|
if err != nil {
|
|
|
|
return bootstrap.Bootstrap{}, false, fmt.Errorf("getting hosts from garage: %w", err)
|
2024-06-17 18:51:02 +00:00
|
|
|
}
|
2022-10-26 21:21:31 +00:00
|
|
|
|
2024-07-06 13:36:48 +00:00
|
|
|
// the daemon's view of this host's bootstrap info takes precedence over
|
|
|
|
// whatever is in garage
|
|
|
|
newHosts[thisHost.Name] = thisHost
|
|
|
|
|
|
|
|
newHostsHash, err := bootstrap.HostsHash(newHosts)
|
2024-06-24 16:55:36 +00:00
|
|
|
if err != nil {
|
2024-07-06 13:36:48 +00:00
|
|
|
return bootstrap.Bootstrap{}, false, fmt.Errorf("calculating hash of new hosts: %w", err)
|
2024-06-24 16:55:36 +00:00
|
|
|
}
|
|
|
|
|
2024-07-06 13:36:48 +00:00
|
|
|
currHostsHash, err := bootstrap.HostsHash(hostBootstrap.Hosts)
|
|
|
|
if err != nil {
|
|
|
|
return bootstrap.Bootstrap{}, false, fmt.Errorf("calculating hash of current hosts: %w", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
if bytes.Equal(newHostsHash, currHostsHash) {
|
|
|
|
return hostBootstrap, false, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
hostBootstrap.Hosts = newHosts
|
|
|
|
|
|
|
|
return hostBootstrap, true, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// blocks until a new bootstrap is available or context is canceled
|
|
|
|
func (d *daemon) watchForChanges(ctx context.Context) bootstrap.Bootstrap {
|
|
|
|
|
|
|
|
ticker := time.NewTicker(3 * time.Minute)
|
|
|
|
defer ticker.Stop()
|
|
|
|
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
|
|
|
|
case <-ctx.Done():
|
|
|
|
return bootstrap.Bootstrap{}
|
|
|
|
|
|
|
|
case <-ticker.C:
|
|
|
|
|
|
|
|
d.logger.Info(ctx, "Checking for changes to bootstrap")
|
|
|
|
|
|
|
|
newBootstrap, changed, err := d.checkBootstrap(
|
|
|
|
ctx, d.currBootstrap,
|
|
|
|
)
|
|
|
|
if err != nil {
|
|
|
|
d.logger.Error(ctx, "Checking bootstrap for changes failed", err)
|
|
|
|
continue
|
|
|
|
} else if !changed {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
err = writeBootstrapToStateDir(d.opts.EnvVars.StateDirPath, newBootstrap)
|
|
|
|
if err != nil {
|
|
|
|
d.logger.Error(ctx, "Writing new bootstrap to disk failed", err)
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
return newBootstrap
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2024-07-07 18:01:10 +00:00
|
|
|
func (d *daemon) postInit(ctx context.Context) bool {
|
|
|
|
if len(d.daemonConfig.Storage.Allocations) > 0 {
|
|
|
|
if !until(
|
|
|
|
ctx,
|
|
|
|
d.logger,
|
|
|
|
"Applying garage layout",
|
|
|
|
func(ctx context.Context) error {
|
2024-07-13 12:34:06 +00:00
|
|
|
return garageApplyLayout(
|
2024-07-14 10:19:39 +00:00
|
|
|
ctx,
|
|
|
|
d.logger,
|
|
|
|
d.daemonConfig,
|
|
|
|
d.garageAdminToken,
|
|
|
|
d.currBootstrap,
|
2024-07-07 18:01:10 +00:00
|
|
|
)
|
|
|
|
},
|
|
|
|
) {
|
|
|
|
return false
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// This is only necessary during network creation, otherwise the bootstrap
|
|
|
|
// should already have these credentials built in.
|
|
|
|
//
|
|
|
|
// TODO this is pretty hacky, but there doesn't seem to be a better way to
|
|
|
|
// manage it at the moment.
|
2024-07-14 10:19:39 +00:00
|
|
|
_, err := getGarageS3APIGlobalBucketCredentials(ctx, d.secretsStore)
|
|
|
|
if errors.Is(err, secrets.ErrNotFound) {
|
2024-07-07 18:01:10 +00:00
|
|
|
if !until(
|
|
|
|
ctx,
|
|
|
|
d.logger,
|
|
|
|
"Initializing garage shared global bucket",
|
|
|
|
func(ctx context.Context) error {
|
2024-07-09 09:43:17 +00:00
|
|
|
garageGlobalBucketCreds, err := garageInitializeGlobalBucket(
|
2024-07-14 10:19:39 +00:00
|
|
|
ctx,
|
|
|
|
d.logger,
|
|
|
|
d.daemonConfig,
|
|
|
|
d.garageAdminToken,
|
|
|
|
d.currBootstrap,
|
2024-07-07 18:01:10 +00:00
|
|
|
)
|
2024-07-09 09:43:17 +00:00
|
|
|
if err != nil {
|
|
|
|
return fmt.Errorf("initializing global bucket: %w", err)
|
|
|
|
}
|
|
|
|
|
2024-07-14 10:19:39 +00:00
|
|
|
err = setGarageS3APIGlobalBucketCredentials(
|
|
|
|
ctx, d.secretsStore, garageGlobalBucketCreds,
|
2024-07-09 09:43:17 +00:00
|
|
|
)
|
|
|
|
if err != nil {
|
2024-07-14 10:19:39 +00:00
|
|
|
return fmt.Errorf("storing global bucket creds: %w", err)
|
2024-07-09 09:43:17 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
2024-07-07 18:01:10 +00:00
|
|
|
},
|
|
|
|
) {
|
|
|
|
return false
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
if !until(
|
|
|
|
ctx,
|
|
|
|
d.logger,
|
|
|
|
"Updating host info in garage",
|
|
|
|
func(ctx context.Context) error {
|
2024-07-13 12:34:06 +00:00
|
|
|
return d.putGarageBoostrapHost(ctx, d.logger, d.currBootstrap)
|
2024-07-07 18:01:10 +00:00
|
|
|
},
|
|
|
|
) {
|
|
|
|
return false
|
|
|
|
}
|
|
|
|
|
|
|
|
return true
|
|
|
|
}
|
|
|
|
|
|
|
|
func (d *daemon) restartLoop(ctx context.Context, readyCh chan<- struct{}) {
|
2024-07-06 13:36:48 +00:00
|
|
|
wait := func(d time.Duration) bool {
|
|
|
|
select {
|
|
|
|
case <-ctx.Done():
|
|
|
|
return false
|
|
|
|
case <-time.After(d):
|
|
|
|
return true
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2024-07-07 18:01:10 +00:00
|
|
|
ready := func() {
|
|
|
|
select {
|
|
|
|
case readyCh <- struct{}{}:
|
|
|
|
default:
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2024-07-06 13:36:48 +00:00
|
|
|
for {
|
|
|
|
if ctx.Err() != nil {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2024-07-07 18:01:10 +00:00
|
|
|
d.logger.Info(ctx, "Creating child processes")
|
2024-07-06 13:36:48 +00:00
|
|
|
children, err := NewChildren(
|
|
|
|
ctx,
|
2024-07-07 18:01:10 +00:00
|
|
|
d.logger.WithNamespace("children"),
|
2024-07-13 12:34:06 +00:00
|
|
|
d.envBinDirPath,
|
|
|
|
d.secretsStore,
|
2024-07-06 13:36:48 +00:00
|
|
|
d.daemonConfig,
|
2024-07-14 10:19:39 +00:00
|
|
|
d.garageAdminToken,
|
2024-07-06 13:36:48 +00:00
|
|
|
d.currBootstrap,
|
|
|
|
d.opts,
|
|
|
|
)
|
|
|
|
if errors.Is(err, context.Canceled) {
|
|
|
|
return
|
|
|
|
} else if err != nil {
|
2024-07-13 12:34:06 +00:00
|
|
|
d.logger.Error(ctx, "failed to initialize child processes", err)
|
2024-07-06 13:36:48 +00:00
|
|
|
if !wait(1 * time.Second) {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
2024-07-07 18:01:10 +00:00
|
|
|
d.logger.Info(ctx, "Child processes created")
|
|
|
|
|
2024-07-06 13:36:48 +00:00
|
|
|
d.l.Lock()
|
|
|
|
d.children = children
|
|
|
|
d.l.Unlock()
|
|
|
|
|
2024-07-07 18:01:10 +00:00
|
|
|
if !d.postInit(ctx) {
|
2024-07-06 13:36:48 +00:00
|
|
|
return
|
2022-10-26 21:21:31 +00:00
|
|
|
}
|
2024-06-17 18:51:02 +00:00
|
|
|
|
2024-07-07 18:01:10 +00:00
|
|
|
d.l.Lock()
|
|
|
|
d.state = daemonStateOk
|
|
|
|
d.l.Unlock()
|
|
|
|
|
|
|
|
ready()
|
|
|
|
|
2024-07-06 13:36:48 +00:00
|
|
|
newBootstrap := d.watchForChanges(ctx)
|
|
|
|
if ctx.Err() != nil {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
d.logger.Info(ctx, "Bootstrap has changed, will restart daemon")
|
|
|
|
d.l.Lock()
|
|
|
|
d.currBootstrap = newBootstrap
|
|
|
|
d.state = daemonStateRestarting
|
|
|
|
d.l.Unlock()
|
|
|
|
|
|
|
|
d.logger.Info(ctx, "Shutting down previous child processes")
|
|
|
|
if err := d.children.Shutdown(); err != nil {
|
|
|
|
d.logger.Fatal(ctx, "Failed to cleanly shutdown children, there may be orphaned child processes", err)
|
|
|
|
}
|
2024-07-07 18:01:10 +00:00
|
|
|
|
|
|
|
// in case context was canceled while shutting the Children down, we
|
|
|
|
// don't want the Shutdown method to re-attempt calling Shutdown on
|
|
|
|
// it.
|
|
|
|
d.children = nil
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func (d *daemon) CreateNetwork(
|
|
|
|
ctx context.Context,
|
2024-07-12 13:30:21 +00:00
|
|
|
name, domain string, ipNet nebula.IPNet, hostName nebula.HostName,
|
2024-07-14 11:11:18 +00:00
|
|
|
) error {
|
2024-07-12 13:30:21 +00:00
|
|
|
nebulaCACreds, err := nebula.NewCACredentials(domain, ipNet)
|
2024-07-07 18:01:10 +00:00
|
|
|
if err != nil {
|
2024-07-14 11:11:18 +00:00
|
|
|
return fmt.Errorf("creating nebula CA cert: %w", err)
|
2024-07-07 18:01:10 +00:00
|
|
|
}
|
|
|
|
|
2024-07-13 12:34:06 +00:00
|
|
|
var (
|
2024-07-14 11:11:18 +00:00
|
|
|
creationParams = bootstrap.CreationParams{
|
|
|
|
ID: randStr(32),
|
|
|
|
Name: name,
|
|
|
|
Domain: domain,
|
2024-07-13 12:34:06 +00:00
|
|
|
}
|
|
|
|
|
2024-07-14 10:19:39 +00:00
|
|
|
garageRPCSecret = randStr(32)
|
2024-07-13 12:34:06 +00:00
|
|
|
)
|
|
|
|
|
2024-07-14 09:58:39 +00:00
|
|
|
err = setGarageRPCSecret(ctx, d.secretsStore, garageRPCSecret)
|
2024-07-13 12:34:06 +00:00
|
|
|
if err != nil {
|
2024-07-14 11:11:18 +00:00
|
|
|
return fmt.Errorf("setting garage RPC secret: %w", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
err = setNebulaCASigningPrivateKey(ctx, d.secretsStore, nebulaCACreds.SigningPrivateKey)
|
|
|
|
if err != nil {
|
|
|
|
return fmt.Errorf("setting nebula CA signing key secret: %w", err)
|
2024-07-07 18:01:10 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
hostBootstrap, err := bootstrap.New(
|
|
|
|
nebulaCACreds,
|
2024-07-14 11:11:18 +00:00
|
|
|
creationParams,
|
2024-07-07 18:01:10 +00:00
|
|
|
hostName,
|
2024-07-12 13:30:21 +00:00
|
|
|
ipNet.FirstAddr(),
|
2024-07-07 18:01:10 +00:00
|
|
|
)
|
|
|
|
if err != nil {
|
2024-07-14 11:11:18 +00:00
|
|
|
return fmt.Errorf("initializing bootstrap data: %w", err)
|
2024-07-07 18:01:10 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
d.l.Lock()
|
|
|
|
|
|
|
|
if d.state != daemonStateNoNetwork {
|
|
|
|
d.l.Unlock()
|
2024-07-14 11:11:18 +00:00
|
|
|
return ErrAlreadyJoined
|
2024-07-07 18:01:10 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
if len(d.daemonConfig.Storage.Allocations) < 3 {
|
|
|
|
d.l.Unlock()
|
2024-07-14 11:11:18 +00:00
|
|
|
return ErrInvalidConfig.WithData(
|
2024-07-07 18:01:10 +00:00
|
|
|
"At least three storage allocations are required.",
|
|
|
|
)
|
|
|
|
}
|
|
|
|
|
|
|
|
readyCh := make(chan struct{}, 1)
|
|
|
|
|
|
|
|
err = d.initialize(hostBootstrap, readyCh)
|
|
|
|
d.l.Unlock()
|
|
|
|
if err != nil {
|
2024-07-14 11:11:18 +00:00
|
|
|
return fmt.Errorf("initializing daemon: %w", err)
|
2024-07-07 18:01:10 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
select {
|
|
|
|
case <-readyCh:
|
|
|
|
case <-ctx.Done():
|
2024-07-14 11:11:18 +00:00
|
|
|
return ctx.Err()
|
2022-10-26 21:21:31 +00:00
|
|
|
}
|
2024-07-07 18:01:10 +00:00
|
|
|
|
2024-07-14 11:11:18 +00:00
|
|
|
return nil
|
2024-07-06 13:36:48 +00:00
|
|
|
}
|
2022-10-26 21:21:31 +00:00
|
|
|
|
2024-07-07 10:44:49 +00:00
|
|
|
func (d *daemon) JoinNetwork(
|
2024-07-14 09:58:39 +00:00
|
|
|
ctx context.Context, newBootstrap JoiningBootstrap,
|
2024-07-07 10:44:49 +00:00
|
|
|
) error {
|
|
|
|
d.l.Lock()
|
|
|
|
|
|
|
|
if d.state != daemonStateNoNetwork {
|
2024-07-07 18:01:10 +00:00
|
|
|
d.l.Unlock()
|
2024-07-07 10:44:49 +00:00
|
|
|
return ErrAlreadyJoined
|
|
|
|
}
|
|
|
|
|
2024-07-07 18:01:10 +00:00
|
|
|
readyCh := make(chan struct{}, 1)
|
|
|
|
|
2024-07-14 09:58:39 +00:00
|
|
|
err := secrets.Import(ctx, d.secretsStore, newBootstrap.Secrets)
|
|
|
|
if err != nil {
|
|
|
|
d.l.Unlock()
|
|
|
|
return fmt.Errorf("importing secrets: %w", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
err = d.initialize(newBootstrap.Bootstrap, readyCh)
|
2024-07-07 18:01:10 +00:00
|
|
|
d.l.Unlock()
|
|
|
|
if err != nil {
|
|
|
|
return fmt.Errorf("initializing daemon: %w", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
select {
|
|
|
|
case <-readyCh:
|
|
|
|
return nil
|
|
|
|
case <-ctx.Done():
|
|
|
|
return ctx.Err()
|
|
|
|
}
|
2024-07-07 10:44:49 +00:00
|
|
|
}
|
|
|
|
|
2024-07-12 14:11:42 +00:00
|
|
|
func (d *daemon) GetBootstrap(ctx context.Context) (bootstrap.Bootstrap, error) {
|
2024-07-12 14:03:37 +00:00
|
|
|
return withCurrBootstrap(d, func(
|
|
|
|
currBootstrap bootstrap.Bootstrap,
|
|
|
|
) (
|
2024-07-12 14:11:42 +00:00
|
|
|
bootstrap.Bootstrap, error,
|
2024-07-12 14:03:37 +00:00
|
|
|
) {
|
2024-07-12 14:11:42 +00:00
|
|
|
return currBootstrap, nil
|
2024-07-12 14:03:37 +00:00
|
|
|
})
|
|
|
|
}
|
|
|
|
|
2024-07-13 12:34:06 +00:00
|
|
|
func (d *daemon) GetGarageClientParams(
|
|
|
|
ctx context.Context,
|
|
|
|
) (
|
|
|
|
GarageClientParams, error,
|
|
|
|
) {
|
|
|
|
return withCurrBootstrap(d, func(
|
|
|
|
currBootstrap bootstrap.Bootstrap,
|
|
|
|
) (
|
|
|
|
GarageClientParams, error,
|
|
|
|
) {
|
|
|
|
return d.getGarageClientParams(ctx, currBootstrap)
|
|
|
|
})
|
|
|
|
}
|
|
|
|
|
2024-07-12 15:05:39 +00:00
|
|
|
func (d *daemon) RemoveHost(ctx context.Context, hostName nebula.HostName) error {
|
|
|
|
// TODO RemoveHost should publish a certificate revocation for the host
|
|
|
|
// being removed.
|
|
|
|
_, err := withCurrBootstrap(d, func(
|
|
|
|
currBootstrap bootstrap.Bootstrap,
|
|
|
|
) (
|
|
|
|
struct{}, error,
|
|
|
|
) {
|
2024-07-13 12:34:06 +00:00
|
|
|
garageClientParams, err := d.getGarageClientParams(ctx, currBootstrap)
|
|
|
|
if err != nil {
|
|
|
|
return struct{}{}, fmt.Errorf("get garage client params: %w", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
client := garageClientParams.GlobalBucketS3APIClient()
|
2024-07-12 15:05:39 +00:00
|
|
|
return struct{}{}, removeGarageBootstrapHost(ctx, client, hostName)
|
|
|
|
})
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2024-07-13 14:08:13 +00:00
|
|
|
func makeCACreds(
|
|
|
|
currBootstrap bootstrap.Bootstrap,
|
|
|
|
caSigningPrivateKey nebula.SigningPrivateKey,
|
|
|
|
) nebula.CACredentials {
|
|
|
|
return nebula.CACredentials{
|
|
|
|
Public: currBootstrap.CAPublicCredentials,
|
|
|
|
SigningPrivateKey: caSigningPrivateKey,
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2024-07-13 14:31:52 +00:00
|
|
|
func (d *daemon) CreateHost(
|
|
|
|
ctx context.Context,
|
|
|
|
hostName nebula.HostName,
|
|
|
|
ip netip.Addr,
|
2024-07-14 11:33:29 +00:00
|
|
|
opts CreateHostOpts,
|
2024-07-13 14:31:52 +00:00
|
|
|
) (
|
2024-07-14 09:58:39 +00:00
|
|
|
JoiningBootstrap, error,
|
2024-07-13 14:31:52 +00:00
|
|
|
) {
|
|
|
|
return withCurrBootstrap(d, func(
|
|
|
|
currBootstrap bootstrap.Bootstrap,
|
|
|
|
) (
|
2024-07-14 09:58:39 +00:00
|
|
|
JoiningBootstrap, error,
|
2024-07-13 14:31:52 +00:00
|
|
|
) {
|
2024-07-14 11:11:18 +00:00
|
|
|
caSigningPrivateKey, err := getNebulaCASigningPrivateKey(
|
|
|
|
ctx, d.secretsStore,
|
2024-07-14 09:58:39 +00:00
|
|
|
)
|
2024-07-14 11:11:18 +00:00
|
|
|
if err != nil {
|
|
|
|
return JoiningBootstrap{}, fmt.Errorf("getting CA signing key: %w", err)
|
|
|
|
}
|
2024-07-13 14:31:52 +00:00
|
|
|
|
2024-07-14 11:11:18 +00:00
|
|
|
var joiningBootstrap JoiningBootstrap
|
2024-07-14 09:58:39 +00:00
|
|
|
joiningBootstrap.Bootstrap, err = bootstrap.New(
|
2024-07-13 14:31:52 +00:00
|
|
|
makeCACreds(currBootstrap, caSigningPrivateKey),
|
2024-07-14 11:11:18 +00:00
|
|
|
currBootstrap.NetworkCreationParams,
|
2024-07-13 14:31:52 +00:00
|
|
|
hostName,
|
|
|
|
ip,
|
|
|
|
)
|
|
|
|
if err != nil {
|
2024-07-14 09:58:39 +00:00
|
|
|
return JoiningBootstrap{}, fmt.Errorf(
|
2024-07-13 14:31:52 +00:00
|
|
|
"initializing bootstrap data: %w", err,
|
|
|
|
)
|
|
|
|
}
|
|
|
|
|
2024-07-14 09:58:39 +00:00
|
|
|
joiningBootstrap.Bootstrap.Hosts = currBootstrap.Hosts
|
|
|
|
|
2024-07-14 11:33:29 +00:00
|
|
|
secretsIDs := []secrets.ID{
|
|
|
|
garageRPCSecretSecretID,
|
|
|
|
garageS3APIGlobalBucketCredentialsSecretID,
|
|
|
|
}
|
|
|
|
|
|
|
|
if opts.CanCreateHosts {
|
|
|
|
secretsIDs = append(secretsIDs, nebulaCASigningPrivateKeySecretID)
|
|
|
|
}
|
|
|
|
|
2024-07-14 09:58:39 +00:00
|
|
|
if joiningBootstrap.Secrets, err = secrets.Export(
|
2024-07-14 11:33:29 +00:00
|
|
|
ctx, d.secretsStore, secretsIDs,
|
2024-07-14 09:58:39 +00:00
|
|
|
); err != nil {
|
|
|
|
return JoiningBootstrap{}, fmt.Errorf("exporting secrets: %w", err)
|
|
|
|
}
|
2024-07-13 14:31:52 +00:00
|
|
|
|
|
|
|
// TODO persist new bootstrap to garage. Requires making the daemon
|
|
|
|
// config change watching logic smarter, so only dnsmasq gets restarted.
|
|
|
|
|
2024-07-14 09:58:39 +00:00
|
|
|
return joiningBootstrap, nil
|
2024-07-13 14:31:52 +00:00
|
|
|
})
|
|
|
|
}
|
|
|
|
|
2024-07-13 14:08:13 +00:00
|
|
|
func (d *daemon) CreateNebulaCertificate(
|
|
|
|
ctx context.Context,
|
|
|
|
hostName nebula.HostName,
|
|
|
|
hostPubKey nebula.EncryptingPublicKey,
|
2024-07-14 12:43:17 +00:00
|
|
|
opts CreateNebulaCertificateOpts,
|
2024-07-13 14:08:13 +00:00
|
|
|
) (
|
|
|
|
nebula.Certificate, error,
|
|
|
|
) {
|
|
|
|
return withCurrBootstrap(d, func(
|
|
|
|
currBootstrap bootstrap.Bootstrap,
|
|
|
|
) (
|
|
|
|
nebula.Certificate, error,
|
|
|
|
) {
|
2024-07-14 12:43:17 +00:00
|
|
|
ip := opts.IP
|
|
|
|
if ip == (netip.Addr{}) {
|
|
|
|
host, ok := currBootstrap.Hosts[hostName]
|
|
|
|
if !ok {
|
|
|
|
return nebula.Certificate{}, ErrHostNotFound
|
|
|
|
}
|
|
|
|
ip = host.IP()
|
2024-07-13 14:08:13 +00:00
|
|
|
}
|
|
|
|
|
2024-07-14 11:11:18 +00:00
|
|
|
caSigningPrivateKey, err := getNebulaCASigningPrivateKey(
|
|
|
|
ctx, d.secretsStore,
|
|
|
|
)
|
|
|
|
if err != nil {
|
|
|
|
return nebula.Certificate{}, fmt.Errorf("getting CA signing key: %w", err)
|
|
|
|
}
|
|
|
|
|
2024-07-13 14:08:13 +00:00
|
|
|
caCreds := makeCACreds(currBootstrap, caSigningPrivateKey)
|
|
|
|
|
2024-07-14 12:43:17 +00:00
|
|
|
return nebula.NewHostCert(caCreds, hostPubKey, hostName, ip)
|
2024-07-13 14:08:13 +00:00
|
|
|
})
|
|
|
|
}
|
|
|
|
|
2024-06-24 16:55:36 +00:00
|
|
|
func (d *daemon) Shutdown() error {
|
2024-07-07 10:44:49 +00:00
|
|
|
d.l.Lock()
|
|
|
|
defer d.l.Unlock()
|
|
|
|
|
|
|
|
close(d.shutdownCh)
|
|
|
|
d.wg.Wait()
|
|
|
|
d.state = daemonStateShutdown
|
|
|
|
|
|
|
|
if d.children != nil {
|
|
|
|
if err := d.children.Shutdown(); err != nil {
|
|
|
|
return fmt.Errorf("shutting down children: %w", err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2024-06-24 16:55:36 +00:00
|
|
|
return nil
|
2022-10-26 21:21:31 +00:00
|
|
|
}
|