2018-07-12 23:15:33 +00:00
|
|
|
package taskrunner
|
|
|
|
|
|
|
|
import (
|
|
|
|
"context"
|
|
|
|
"fmt"
|
|
|
|
"io/ioutil"
|
|
|
|
"os"
|
|
|
|
"path/filepath"
|
|
|
|
"sync"
|
|
|
|
"time"
|
|
|
|
|
|
|
|
"github.com/hashicorp/consul-template/signals"
|
|
|
|
log "github.com/hashicorp/go-hclog"
|
|
|
|
|
2018-10-04 23:22:01 +00:00
|
|
|
"github.com/hashicorp/nomad/client/allocrunner/interfaces"
|
|
|
|
ti "github.com/hashicorp/nomad/client/allocrunner/taskrunner/interfaces"
|
2018-07-12 23:15:33 +00:00
|
|
|
"github.com/hashicorp/nomad/client/vaultclient"
|
|
|
|
"github.com/hashicorp/nomad/nomad/structs"
|
|
|
|
)
|
|
|
|
|
|
|
|
const (
|
|
|
|
// vaultBackoffBaseline is the baseline time for exponential backoff when
|
|
|
|
// attempting to retrieve a Vault token
|
|
|
|
vaultBackoffBaseline = 5 * time.Second
|
|
|
|
|
|
|
|
// vaultBackoffLimit is the limit of the exponential backoff when attempting
|
|
|
|
// to retrieve a Vault token
|
|
|
|
vaultBackoffLimit = 3 * time.Minute
|
|
|
|
|
|
|
|
// vaultTokenFile is the name of the file holding the Vault token inside the
|
|
|
|
// task's secret directory
|
|
|
|
vaultTokenFile = "vault_token"
|
|
|
|
)
|
|
|
|
|
|
|
|
type vaultTokenUpdateHandler interface {
|
|
|
|
updatedVaultToken(token string)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (tr *TaskRunner) updatedVaultToken(token string) {
|
2018-08-01 18:03:52 +00:00
|
|
|
// Update the task runner and environment
|
2018-07-12 23:15:33 +00:00
|
|
|
tr.setVaultToken(token)
|
|
|
|
|
2018-08-01 18:03:52 +00:00
|
|
|
// Trigger update hooks with the new Vault token
|
|
|
|
tr.triggerUpdateHooks()
|
2018-07-12 23:15:33 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
type vaultHookConfig struct {
|
|
|
|
vaultStanza *structs.Vault
|
|
|
|
client vaultclient.VaultClient
|
2018-07-13 20:45:57 +00:00
|
|
|
events ti.EventEmitter
|
|
|
|
lifecycle ti.TaskLifecycle
|
2018-07-12 23:15:33 +00:00
|
|
|
updater vaultTokenUpdateHandler
|
|
|
|
logger log.Logger
|
|
|
|
alloc *structs.Allocation
|
|
|
|
task string
|
|
|
|
}
|
|
|
|
|
|
|
|
type vaultHook struct {
|
|
|
|
// vaultStanza is the vault stanza for the task
|
|
|
|
vaultStanza *structs.Vault
|
|
|
|
|
|
|
|
// eventEmitter is used to emit events to the task
|
2018-07-13 20:45:57 +00:00
|
|
|
eventEmitter ti.EventEmitter
|
2018-07-12 23:15:33 +00:00
|
|
|
|
|
|
|
// lifecycle is used to signal, restart and kill a task
|
2018-07-13 20:45:57 +00:00
|
|
|
lifecycle ti.TaskLifecycle
|
2018-07-12 23:15:33 +00:00
|
|
|
|
|
|
|
// updater is used to update the Vault token
|
|
|
|
updater vaultTokenUpdateHandler
|
|
|
|
|
|
|
|
// client is the Vault client to retrieve and renew the Vault token
|
|
|
|
client vaultclient.VaultClient
|
|
|
|
|
|
|
|
// logger is used to log
|
|
|
|
logger log.Logger
|
|
|
|
|
|
|
|
// ctx and cancel are used to kill the long running token manager
|
|
|
|
ctx context.Context
|
|
|
|
cancel context.CancelFunc
|
|
|
|
|
|
|
|
// tokenPath is the path in which to read and write the token
|
|
|
|
tokenPath string
|
|
|
|
|
|
|
|
// alloc is the allocation
|
|
|
|
alloc *structs.Allocation
|
|
|
|
|
|
|
|
// taskName is the name of the task
|
|
|
|
taskName string
|
|
|
|
|
|
|
|
// firstRun stores whether it is the first run for the hook
|
|
|
|
firstRun bool
|
|
|
|
|
|
|
|
// future is used to wait on retrieving a Vault token
|
|
|
|
future *tokenFuture
|
|
|
|
}
|
|
|
|
|
|
|
|
func newVaultHook(config *vaultHookConfig) *vaultHook {
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
h := &vaultHook{
|
|
|
|
vaultStanza: config.vaultStanza,
|
|
|
|
client: config.client,
|
|
|
|
eventEmitter: config.events,
|
|
|
|
lifecycle: config.lifecycle,
|
|
|
|
updater: config.updater,
|
|
|
|
alloc: config.alloc,
|
|
|
|
taskName: config.task,
|
|
|
|
firstRun: true,
|
|
|
|
ctx: ctx,
|
|
|
|
cancel: cancel,
|
|
|
|
future: newTokenFuture(),
|
|
|
|
}
|
|
|
|
h.logger = config.logger.Named(h.Name())
|
|
|
|
return h
|
|
|
|
}
|
|
|
|
|
|
|
|
func (*vaultHook) Name() string {
|
|
|
|
return "vault"
|
|
|
|
}
|
|
|
|
|
2018-07-17 00:19:56 +00:00
|
|
|
func (h *vaultHook) Prestart(ctx context.Context, req *interfaces.TaskPrestartRequest, resp *interfaces.TaskPrestartResponse) error {
|
|
|
|
// If we have already run prestart before exit early. We do not use the
|
|
|
|
// PrestartDone value because we want to recover the token on restoration.
|
2018-07-12 23:15:33 +00:00
|
|
|
first := h.firstRun
|
|
|
|
h.firstRun = false
|
|
|
|
if !first {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Try to recover a token if it was previously written in the secrets
|
|
|
|
// directory
|
|
|
|
recoveredToken := ""
|
2018-10-10 19:31:59 +00:00
|
|
|
h.tokenPath = filepath.Join(req.TaskDir.SecretsDir, vaultTokenFile)
|
2018-07-12 23:15:33 +00:00
|
|
|
data, err := ioutil.ReadFile(h.tokenPath)
|
|
|
|
if err != nil {
|
|
|
|
if !os.IsNotExist(err) {
|
|
|
|
return fmt.Errorf("failed to recover vault token: %v", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Token file doesn't exist
|
|
|
|
} else {
|
|
|
|
// Store the recovered token
|
|
|
|
recoveredToken = string(data)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Launch the token manager
|
|
|
|
go h.run(recoveredToken)
|
|
|
|
|
|
|
|
// Block until we get a token
|
|
|
|
select {
|
|
|
|
case <-h.future.Wait():
|
|
|
|
case <-ctx.Done():
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
h.updater.updatedVaultToken(h.future.Get())
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2018-07-17 00:19:56 +00:00
|
|
|
func (h *vaultHook) Stop(ctx context.Context, req *interfaces.TaskStopRequest, resp *interfaces.TaskStopResponse) error {
|
2018-07-12 23:15:33 +00:00
|
|
|
// Shutdown any created manager
|
|
|
|
h.cancel()
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2018-11-14 18:29:07 +00:00
|
|
|
func (h *vaultHook) Shutdown() {
|
|
|
|
h.cancel()
|
|
|
|
}
|
|
|
|
|
2018-07-12 23:15:33 +00:00
|
|
|
// run should be called in a go-routine and manages the derivation, renewal and
|
|
|
|
// handling of errors with the Vault token. The optional parameter allows
|
|
|
|
// setting the initial Vault token. This is useful when the Vault token is
|
|
|
|
// recovered off disk.
|
|
|
|
func (h *vaultHook) run(token string) {
|
|
|
|
// Helper for stopping token renewal
|
|
|
|
stopRenewal := func() {
|
|
|
|
if err := h.client.StopRenewToken(h.future.Get()); err != nil {
|
|
|
|
h.logger.Warn("failed to stop token renewal", "error", err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// updatedToken lets us store state between loops. If true, a new token
|
|
|
|
// has been retrieved and we need to apply the Vault change mode
|
|
|
|
var updatedToken bool
|
|
|
|
|
|
|
|
OUTER:
|
|
|
|
for {
|
|
|
|
// Check if we should exit
|
2018-07-13 16:45:29 +00:00
|
|
|
if h.ctx.Err() != nil {
|
2018-07-12 23:15:33 +00:00
|
|
|
stopRenewal()
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Clear the token
|
|
|
|
h.future.Clear()
|
|
|
|
|
|
|
|
// Check if there already is a token which can be the case for
|
|
|
|
// restoring the TaskRunner
|
|
|
|
if token == "" {
|
|
|
|
// Get a token
|
|
|
|
var exit bool
|
|
|
|
token, exit = h.deriveVaultToken()
|
|
|
|
if exit {
|
|
|
|
// Exit the manager
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Write the token to disk
|
|
|
|
if err := h.writeToken(token); err != nil {
|
|
|
|
errorString := "failed to write Vault token to disk"
|
|
|
|
h.logger.Error(errorString, "error", err)
|
2018-07-16 21:37:27 +00:00
|
|
|
h.lifecycle.Kill(h.ctx,
|
|
|
|
structs.NewTaskEvent(structs.TaskKilling).
|
|
|
|
SetFailsTask().
|
|
|
|
SetDisplayMessage(fmt.Sprintf("Vault %v", errorString)))
|
2018-07-12 23:15:33 +00:00
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Start the renewal process
|
|
|
|
renewCh, err := h.client.RenewToken(token, 30)
|
|
|
|
|
|
|
|
// An error returned means the token is not being renewed
|
|
|
|
if err != nil {
|
|
|
|
h.logger.Error("failed to start renewal of Vault token", "error", err)
|
|
|
|
token = ""
|
|
|
|
goto OUTER
|
|
|
|
}
|
|
|
|
|
|
|
|
// The Vault token is valid now, so set it
|
|
|
|
h.future.Set(token)
|
|
|
|
|
|
|
|
if updatedToken {
|
|
|
|
switch h.vaultStanza.ChangeMode {
|
|
|
|
case structs.VaultChangeModeSignal:
|
|
|
|
s, err := signals.Parse(h.vaultStanza.ChangeSignal)
|
|
|
|
if err != nil {
|
|
|
|
h.logger.Error("failed to parse signal", "error", err)
|
2018-07-16 21:37:27 +00:00
|
|
|
h.lifecycle.Kill(h.ctx,
|
|
|
|
structs.NewTaskEvent(structs.TaskKilling).
|
|
|
|
SetFailsTask().
|
|
|
|
SetDisplayMessage(fmt.Sprintf("Vault: failed to parse signal: %v", err)))
|
2018-07-12 23:15:33 +00:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2018-07-16 21:37:27 +00:00
|
|
|
event := structs.NewTaskEvent(structs.TaskSignaling).SetTaskSignal(s).SetDisplayMessage("Vault: new Vault token acquired")
|
2018-10-04 19:08:20 +00:00
|
|
|
if err := h.lifecycle.Signal(event, h.vaultStanza.ChangeSignal); err != nil {
|
2018-07-12 23:15:33 +00:00
|
|
|
h.logger.Error("failed to send signal", "error", err)
|
2018-07-16 21:37:27 +00:00
|
|
|
h.lifecycle.Kill(h.ctx,
|
|
|
|
structs.NewTaskEvent(structs.TaskKilling).
|
|
|
|
SetFailsTask().
|
|
|
|
SetDisplayMessage(fmt.Sprintf("Vault: failed to send signal: %v", err)))
|
2018-07-12 23:15:33 +00:00
|
|
|
return
|
|
|
|
}
|
|
|
|
case structs.VaultChangeModeRestart:
|
|
|
|
const noFailure = false
|
2018-07-16 21:37:27 +00:00
|
|
|
h.lifecycle.Restart(h.ctx,
|
2019-02-22 19:45:17 +00:00
|
|
|
structs.NewTaskEvent(structs.TaskRestartSignal).
|
2018-07-16 21:37:27 +00:00
|
|
|
SetDisplayMessage("Vault: new Vault token acquired"), false)
|
2018-07-12 23:15:33 +00:00
|
|
|
case structs.VaultChangeModeNoop:
|
|
|
|
fallthrough
|
|
|
|
default:
|
|
|
|
h.logger.Error("invalid Vault change mode", "mode", h.vaultStanza.ChangeMode)
|
|
|
|
}
|
|
|
|
|
|
|
|
// We have handled it
|
|
|
|
updatedToken = false
|
|
|
|
|
|
|
|
// Call the handler
|
|
|
|
h.updater.updatedVaultToken(token)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Start watching for renewal errors
|
|
|
|
select {
|
|
|
|
case err := <-renewCh:
|
|
|
|
// Clear the token
|
|
|
|
token = ""
|
|
|
|
h.logger.Error("failed to renew Vault token", "error", err)
|
|
|
|
stopRenewal()
|
|
|
|
|
|
|
|
// Check if we have to do anything
|
|
|
|
if h.vaultStanza.ChangeMode != structs.VaultChangeModeNoop {
|
|
|
|
updatedToken = true
|
|
|
|
}
|
|
|
|
case <-h.ctx.Done():
|
|
|
|
stopRenewal()
|
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// deriveVaultToken derives the Vault token using exponential backoffs. It
|
|
|
|
// returns the Vault token and whether the manager should exit.
|
|
|
|
func (h *vaultHook) deriveVaultToken() (token string, exit bool) {
|
|
|
|
attempts := 0
|
|
|
|
for {
|
|
|
|
tokens, err := h.client.DeriveToken(h.alloc, []string{h.taskName})
|
|
|
|
if err == nil {
|
|
|
|
return tokens[h.taskName], false
|
|
|
|
}
|
|
|
|
|
|
|
|
// Check if this is a server side error
|
|
|
|
if structs.IsServerSide(err) {
|
|
|
|
h.logger.Error("failed to derive Vault token", "error", err, "server_side", true)
|
2018-07-16 21:37:27 +00:00
|
|
|
h.lifecycle.Kill(h.ctx,
|
|
|
|
structs.NewTaskEvent(structs.TaskKilling).
|
|
|
|
SetFailsTask().
|
|
|
|
SetDisplayMessage(fmt.Sprintf("Vault: server failed to derive vault token: %v", err)))
|
2018-07-12 23:15:33 +00:00
|
|
|
return "", true
|
|
|
|
}
|
|
|
|
|
|
|
|
// Check if we can't recover from the error
|
|
|
|
if !structs.IsRecoverable(err) {
|
|
|
|
h.logger.Error("failed to derive Vault token", "error", err, "recoverable", false)
|
2018-07-16 21:37:27 +00:00
|
|
|
h.lifecycle.Kill(h.ctx,
|
|
|
|
structs.NewTaskEvent(structs.TaskKilling).
|
|
|
|
SetFailsTask().
|
|
|
|
SetDisplayMessage(fmt.Sprintf("Vault: failed to derive vault token: %v", err)))
|
2018-07-12 23:15:33 +00:00
|
|
|
return "", true
|
|
|
|
}
|
|
|
|
|
|
|
|
// Handle the retry case
|
|
|
|
backoff := (1 << (2 * uint64(attempts))) * vaultBackoffBaseline
|
|
|
|
if backoff > vaultBackoffLimit {
|
|
|
|
backoff = vaultBackoffLimit
|
|
|
|
}
|
|
|
|
h.logger.Error("failed to derive Vault token", "error", err, "recoverable", true, "backoff", backoff)
|
|
|
|
|
|
|
|
attempts++
|
|
|
|
|
|
|
|
// Wait till retrying
|
|
|
|
select {
|
|
|
|
case <-h.ctx.Done():
|
|
|
|
return "", true
|
|
|
|
case <-time.After(backoff):
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// writeToken writes the given token to disk
|
|
|
|
func (h *vaultHook) writeToken(token string) error {
|
2018-07-13 16:45:29 +00:00
|
|
|
if err := ioutil.WriteFile(h.tokenPath, []byte(token), 0666); err != nil {
|
2018-07-12 23:15:33 +00:00
|
|
|
return fmt.Errorf("failed to write vault token: %v", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// tokenFuture stores the Vault token and allows consumers to block till a valid
|
|
|
|
// token exists
|
|
|
|
type tokenFuture struct {
|
|
|
|
waiting []chan struct{}
|
|
|
|
token string
|
|
|
|
set bool
|
|
|
|
m sync.Mutex
|
|
|
|
}
|
|
|
|
|
|
|
|
// newTokenFuture returns a new token future without any token set
|
|
|
|
func newTokenFuture() *tokenFuture {
|
|
|
|
return &tokenFuture{}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Wait returns a channel that can be waited on. When this channel unblocks, a
|
|
|
|
// valid token will be available via the Get method
|
|
|
|
func (f *tokenFuture) Wait() <-chan struct{} {
|
|
|
|
f.m.Lock()
|
|
|
|
defer f.m.Unlock()
|
|
|
|
|
|
|
|
c := make(chan struct{})
|
|
|
|
if f.set {
|
|
|
|
close(c)
|
|
|
|
return c
|
|
|
|
}
|
|
|
|
|
|
|
|
f.waiting = append(f.waiting, c)
|
|
|
|
return c
|
|
|
|
}
|
|
|
|
|
|
|
|
// Set sets the token value and unblocks any caller of Wait
|
|
|
|
func (f *tokenFuture) Set(token string) *tokenFuture {
|
|
|
|
f.m.Lock()
|
|
|
|
defer f.m.Unlock()
|
|
|
|
|
|
|
|
f.set = true
|
|
|
|
f.token = token
|
|
|
|
for _, w := range f.waiting {
|
|
|
|
close(w)
|
|
|
|
}
|
|
|
|
f.waiting = nil
|
|
|
|
return f
|
|
|
|
}
|
|
|
|
|
|
|
|
// Clear clears the set vault token.
|
|
|
|
func (f *tokenFuture) Clear() *tokenFuture {
|
|
|
|
f.m.Lock()
|
|
|
|
defer f.m.Unlock()
|
|
|
|
|
|
|
|
f.token = ""
|
|
|
|
f.set = false
|
|
|
|
return f
|
|
|
|
}
|
|
|
|
|
|
|
|
// Get returns the set Vault token
|
|
|
|
func (f *tokenFuture) Get() string {
|
|
|
|
f.m.Lock()
|
|
|
|
defer f.m.Unlock()
|
|
|
|
return f.token
|
|
|
|
}
|