mirror of
https://github.com/vmware-tanzu/velero.git
synced 2026-01-04 20:24:02 +00:00
When creating a restore based on a backup that doesn't exist, the restore should be marked as invalid and the error clearly communicated so the user understands why the restore wasn't made. Previously, the restore was left as in progress with an error attached. Since restores are CRDs and must be updated via a controller, there's currently not a way to give the client immediate errors. Signed-off-by: Nolan Brubaker <nolan@heptio.com>
507 lines
16 KiB
Go
507 lines
16 KiB
Go
/*
|
|
Copyright 2017 the Heptio Ark contributors.
|
|
|
|
Licensed under the Apache License, Version 2.0 (the "License");
|
|
you may not use this file except in compliance with the License.
|
|
You may obtain a copy of the License at
|
|
|
|
http://www.apache.org/licenses/LICENSE-2.0
|
|
|
|
Unless required by applicable law or agreed to in writing, software
|
|
distributed under the License is distributed on an "AS IS" BASIS,
|
|
WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
|
|
See the License for the specific language governing permissions and
|
|
limitations under the License.
|
|
*/
|
|
|
|
package controller
|
|
|
|
import (
|
|
"compress/gzip"
|
|
"context"
|
|
"encoding/json"
|
|
"fmt"
|
|
"io"
|
|
"io/ioutil"
|
|
"os"
|
|
"sync"
|
|
"time"
|
|
|
|
"github.com/pkg/errors"
|
|
"github.com/sirupsen/logrus"
|
|
|
|
apierrors "k8s.io/apimachinery/pkg/api/errors"
|
|
"k8s.io/apimachinery/pkg/types"
|
|
"k8s.io/apimachinery/pkg/util/sets"
|
|
"k8s.io/apimachinery/pkg/util/strategicpatch"
|
|
"k8s.io/apimachinery/pkg/util/wait"
|
|
"k8s.io/client-go/tools/cache"
|
|
"k8s.io/client-go/util/workqueue"
|
|
|
|
api "github.com/heptio/ark/pkg/apis/ark/v1"
|
|
"github.com/heptio/ark/pkg/cloudprovider"
|
|
arkv1client "github.com/heptio/ark/pkg/generated/clientset/versioned/typed/ark/v1"
|
|
informers "github.com/heptio/ark/pkg/generated/informers/externalversions/ark/v1"
|
|
listers "github.com/heptio/ark/pkg/generated/listers/ark/v1"
|
|
"github.com/heptio/ark/pkg/plugin"
|
|
"github.com/heptio/ark/pkg/restore"
|
|
"github.com/heptio/ark/pkg/util/collections"
|
|
kubeutil "github.com/heptio/ark/pkg/util/kube"
|
|
)
|
|
|
|
// nonRestorableResources is a blacklist for the restoration process. Any resources
|
|
// included here are explicitly excluded from the restoration process.
|
|
var nonRestorableResources = []string{"nodes"}
|
|
|
|
type restoreController struct {
|
|
restoreClient arkv1client.RestoresGetter
|
|
backupClient arkv1client.BackupsGetter
|
|
restorer restore.Restorer
|
|
backupService cloudprovider.BackupService
|
|
bucket string
|
|
pvProviderExists bool
|
|
backupLister listers.BackupLister
|
|
backupListerSynced cache.InformerSynced
|
|
restoreLister listers.RestoreLister
|
|
restoreListerSynced cache.InformerSynced
|
|
syncHandler func(restoreName string) error
|
|
queue workqueue.RateLimitingInterface
|
|
logger logrus.FieldLogger
|
|
pluginManager plugin.Manager
|
|
}
|
|
|
|
func NewRestoreController(
|
|
restoreInformer informers.RestoreInformer,
|
|
restoreClient arkv1client.RestoresGetter,
|
|
backupClient arkv1client.BackupsGetter,
|
|
restorer restore.Restorer,
|
|
backupService cloudprovider.BackupService,
|
|
bucket string,
|
|
backupInformer informers.BackupInformer,
|
|
pvProviderExists bool,
|
|
logger logrus.FieldLogger,
|
|
pluginManager plugin.Manager,
|
|
) Interface {
|
|
c := &restoreController{
|
|
restoreClient: restoreClient,
|
|
backupClient: backupClient,
|
|
restorer: restorer,
|
|
backupService: backupService,
|
|
bucket: bucket,
|
|
pvProviderExists: pvProviderExists,
|
|
backupLister: backupInformer.Lister(),
|
|
backupListerSynced: backupInformer.Informer().HasSynced,
|
|
restoreLister: restoreInformer.Lister(),
|
|
restoreListerSynced: restoreInformer.Informer().HasSynced,
|
|
queue: workqueue.NewNamedRateLimitingQueue(workqueue.DefaultControllerRateLimiter(), "restore"),
|
|
logger: logger,
|
|
pluginManager: pluginManager,
|
|
}
|
|
|
|
c.syncHandler = c.processRestore
|
|
|
|
restoreInformer.Informer().AddEventHandler(
|
|
cache.ResourceEventHandlerFuncs{
|
|
AddFunc: func(obj interface{}) {
|
|
restore := obj.(*api.Restore)
|
|
|
|
switch restore.Status.Phase {
|
|
case "", api.RestorePhaseNew:
|
|
// only process new restores
|
|
default:
|
|
c.logger.WithFields(logrus.Fields{
|
|
"restore": kubeutil.NamespaceAndName(restore),
|
|
"phase": restore.Status.Phase,
|
|
}).Debug("Restore is not new, skipping")
|
|
return
|
|
}
|
|
|
|
key, err := cache.MetaNamespaceKeyFunc(restore)
|
|
if err != nil {
|
|
c.logger.WithError(errors.WithStack(err)).WithField("restore", restore).Error("Error creating queue key, item not added to queue")
|
|
return
|
|
}
|
|
c.queue.Add(key)
|
|
},
|
|
},
|
|
)
|
|
|
|
return c
|
|
}
|
|
|
|
// Run is a blocking function that runs the specified number of worker goroutines
|
|
// to process items in the work queue. It will return when it receives on the
|
|
// ctx.Done() channel.
|
|
func (controller *restoreController) Run(ctx context.Context, numWorkers int) error {
|
|
var wg sync.WaitGroup
|
|
|
|
defer func() {
|
|
controller.logger.Info("Waiting for workers to finish their work")
|
|
|
|
controller.queue.ShutDown()
|
|
|
|
// We have to wait here in the deferred function instead of at the bottom of the function body
|
|
// because we have to shut down the queue in order for the workers to shut down gracefully, and
|
|
// we want to shut down the queue via defer and not at the end of the body.
|
|
wg.Wait()
|
|
|
|
controller.logger.Info("All workers have finished")
|
|
}()
|
|
|
|
controller.logger.Info("Starting RestoreController")
|
|
defer controller.logger.Info("Shutting down RestoreController")
|
|
|
|
controller.logger.Info("Waiting for caches to sync")
|
|
if !cache.WaitForCacheSync(ctx.Done(), controller.backupListerSynced, controller.restoreListerSynced) {
|
|
return errors.New("timed out waiting for caches to sync")
|
|
}
|
|
controller.logger.Info("Caches are synced")
|
|
|
|
wg.Add(numWorkers)
|
|
for i := 0; i < numWorkers; i++ {
|
|
go func() {
|
|
wait.Until(controller.runWorker, time.Second, ctx.Done())
|
|
wg.Done()
|
|
}()
|
|
}
|
|
|
|
<-ctx.Done()
|
|
|
|
return nil
|
|
}
|
|
|
|
func (controller *restoreController) runWorker() {
|
|
// continually take items off the queue (waits if it's
|
|
// empty) until we get a shutdown signal from the queue
|
|
for controller.processNextWorkItem() {
|
|
}
|
|
}
|
|
|
|
func (controller *restoreController) processNextWorkItem() bool {
|
|
key, quit := controller.queue.Get()
|
|
if quit {
|
|
return false
|
|
}
|
|
// always call done on this item, since if it fails we'll add
|
|
// it back with rate-limiting below
|
|
defer controller.queue.Done(key)
|
|
|
|
err := controller.syncHandler(key.(string))
|
|
if err == nil {
|
|
// If you had no error, tell the queue to stop tracking history for your key. This will reset
|
|
// things like failure counts for per-item rate limiting.
|
|
controller.queue.Forget(key)
|
|
return true
|
|
}
|
|
|
|
controller.logger.WithError(err).WithField("key", key).Error("Error in syncHandler, re-adding item to queue")
|
|
// we had an error processing the item so add it back
|
|
// into the queue for re-processing with rate-limiting
|
|
controller.queue.AddRateLimited(key)
|
|
|
|
return true
|
|
}
|
|
|
|
func (controller *restoreController) processRestore(key string) error {
|
|
logContext := controller.logger.WithField("key", key)
|
|
|
|
logContext.Debug("Running processRestore")
|
|
ns, name, err := cache.SplitMetaNamespaceKey(key)
|
|
if err != nil {
|
|
return errors.Wrap(err, "error splitting queue key")
|
|
}
|
|
|
|
logContext.Debug("Getting Restore")
|
|
restore, err := controller.restoreLister.Restores(ns).Get(name)
|
|
if err != nil {
|
|
return errors.Wrap(err, "error getting Restore")
|
|
}
|
|
|
|
// TODO I think this is now unnecessary. We only initially place
|
|
// item with Phase = ("" | New) into the queue. Items will only get
|
|
// re-queued if syncHandler returns an error, which will only
|
|
// happen if there's an error updating Phase from its initial
|
|
// state to something else. So any time it's re-queued it will
|
|
// still have its initial state, which we've already confirmed
|
|
// is ("" | New)
|
|
switch restore.Status.Phase {
|
|
case "", api.RestorePhaseNew:
|
|
// only process new restores
|
|
default:
|
|
return nil
|
|
}
|
|
|
|
logContext.Debug("Cloning Restore")
|
|
// store ref to original for creating patch
|
|
original := restore
|
|
// don't modify items in the cache
|
|
restore = restore.DeepCopy()
|
|
|
|
excludedResources := sets.NewString(restore.Spec.ExcludedResources...)
|
|
for _, nonrestorable := range nonRestorableResources {
|
|
if !excludedResources.Has(nonrestorable) {
|
|
restore.Spec.ExcludedResources = append(restore.Spec.ExcludedResources, nonrestorable)
|
|
}
|
|
}
|
|
|
|
// validation
|
|
if restore.Status.ValidationErrors = controller.getValidationErrors(restore); len(restore.Status.ValidationErrors) > 0 {
|
|
restore.Status.Phase = api.RestorePhaseFailedValidation
|
|
} else {
|
|
restore.Status.Phase = api.RestorePhaseInProgress
|
|
}
|
|
|
|
// update status
|
|
updatedRestore, err := patchRestore(original, restore, controller.restoreClient)
|
|
if err != nil {
|
|
return errors.Wrapf(err, "error updating Restore phase to %s", restore.Status.Phase)
|
|
}
|
|
// store ref to just-updated item for creating patch
|
|
original = updatedRestore
|
|
restore = updatedRestore.DeepCopy()
|
|
|
|
if restore.Status.Phase == api.RestorePhaseFailedValidation {
|
|
return nil
|
|
}
|
|
|
|
logContext.Debug("Running restore")
|
|
// execution & upload of restore
|
|
restoreWarnings, restoreErrors := controller.runRestore(restore, controller.bucket)
|
|
|
|
restore.Status.Warnings = len(restoreWarnings.Ark) + len(restoreWarnings.Cluster)
|
|
for _, w := range restoreWarnings.Namespaces {
|
|
restore.Status.Warnings += len(w)
|
|
}
|
|
|
|
restore.Status.Errors = len(restoreErrors.Ark) + len(restoreErrors.Cluster)
|
|
for _, e := range restoreErrors.Namespaces {
|
|
restore.Status.Errors += len(e)
|
|
}
|
|
|
|
logContext.Debug("restore completed")
|
|
restore.Status.Phase = api.RestorePhaseCompleted
|
|
|
|
logContext.Debug("Updating Restore final status")
|
|
if _, err = patchRestore(original, restore, controller.restoreClient); err != nil {
|
|
logContext.WithError(errors.WithStack(err)).Info("Error updating Restore final status")
|
|
}
|
|
|
|
return nil
|
|
}
|
|
|
|
func (controller *restoreController) getValidationErrors(itm *api.Restore) []string {
|
|
var validationErrors []string
|
|
|
|
if itm.Spec.BackupName == "" {
|
|
validationErrors = append(validationErrors, "BackupName must be non-empty and correspond to the name of a backup in object storage.")
|
|
} else if _, err := controller.fetchBackup(controller.bucket, itm.Spec.BackupName); err != nil {
|
|
validationErrors = append(validationErrors, fmt.Sprintf("Error retrieving backup: %v", err))
|
|
}
|
|
|
|
includedResources := sets.NewString(itm.Spec.IncludedResources...)
|
|
for _, nonRestorableResource := range nonRestorableResources {
|
|
if includedResources.Has(nonRestorableResource) {
|
|
validationErrors = append(validationErrors, fmt.Sprintf("%v are a non-restorable resource", nonRestorableResource))
|
|
}
|
|
}
|
|
|
|
for _, err := range collections.ValidateIncludesExcludes(itm.Spec.IncludedNamespaces, itm.Spec.ExcludedNamespaces) {
|
|
validationErrors = append(validationErrors, fmt.Sprintf("Invalid included/excluded namespace lists: %v", err))
|
|
}
|
|
|
|
for _, err := range collections.ValidateIncludesExcludes(itm.Spec.IncludedResources, itm.Spec.ExcludedResources) {
|
|
validationErrors = append(validationErrors, fmt.Sprintf("Invalid included/excluded resource lists: %v", err))
|
|
}
|
|
|
|
if !controller.pvProviderExists && itm.Spec.RestorePVs != nil && *itm.Spec.RestorePVs {
|
|
validationErrors = append(validationErrors, "Server is not configured for PV snapshot restores")
|
|
}
|
|
|
|
return validationErrors
|
|
}
|
|
|
|
func (controller *restoreController) fetchBackup(bucket, name string) (*api.Backup, error) {
|
|
backup, err := controller.backupLister.Backups(api.DefaultNamespace).Get(name)
|
|
if err == nil {
|
|
return backup, nil
|
|
}
|
|
|
|
if !apierrors.IsNotFound(err) {
|
|
return nil, errors.WithStack(err)
|
|
}
|
|
|
|
logContext := controller.logger.WithField("backupName", name)
|
|
|
|
logContext.Debug("Backup not found in backupLister, checking object storage directly")
|
|
backup, err = controller.backupService.GetBackup(bucket, name)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
// ResourceVersion needs to be cleared in order to create the object in the API
|
|
backup.ResourceVersion = ""
|
|
|
|
created, createErr := controller.backupClient.Backups(api.DefaultNamespace).Create(backup)
|
|
if createErr != nil {
|
|
logContext.WithError(errors.WithStack(createErr)).Error("Unable to create API object for Backup")
|
|
} else {
|
|
backup = created
|
|
}
|
|
|
|
return backup, nil
|
|
}
|
|
|
|
func (controller *restoreController) runRestore(restore *api.Restore, bucket string) (restoreWarnings, restoreErrors api.RestoreResult) {
|
|
logContext := controller.logger.WithFields(
|
|
logrus.Fields{
|
|
"restore": kubeutil.NamespaceAndName(restore),
|
|
"backup": restore.Spec.BackupName,
|
|
})
|
|
|
|
backup, err := controller.fetchBackup(bucket, restore.Spec.BackupName)
|
|
if err != nil {
|
|
logContext.WithError(err).Error("Error getting backup")
|
|
restoreErrors.Ark = append(restoreErrors.Ark, err.Error())
|
|
return
|
|
}
|
|
|
|
var tempFiles []*os.File
|
|
|
|
backupFile, err := downloadToTempFile(restore.Spec.BackupName, controller.backupService, bucket, controller.logger)
|
|
if err != nil {
|
|
logContext.WithError(err).Error("Error downloading backup")
|
|
restoreErrors.Ark = append(restoreErrors.Ark, err.Error())
|
|
return
|
|
}
|
|
tempFiles = append(tempFiles, backupFile)
|
|
|
|
logFile, err := ioutil.TempFile("", "")
|
|
if err != nil {
|
|
logContext.WithError(errors.WithStack(err)).Error("Error creating log temp file")
|
|
restoreErrors.Ark = append(restoreErrors.Ark, err.Error())
|
|
return
|
|
}
|
|
tempFiles = append(tempFiles, logFile)
|
|
|
|
resultsFile, err := ioutil.TempFile("", "")
|
|
if err != nil {
|
|
logContext.WithError(errors.WithStack(err)).Error("Error creating results temp file")
|
|
restoreErrors.Ark = append(restoreErrors.Ark, err.Error())
|
|
return
|
|
}
|
|
tempFiles = append(tempFiles, resultsFile)
|
|
|
|
defer func() {
|
|
for _, file := range tempFiles {
|
|
if err := file.Close(); err != nil {
|
|
logContext.WithError(errors.WithStack(err)).WithField("file", file.Name()).Error("Error closing file")
|
|
}
|
|
|
|
if err := os.Remove(file.Name()); err != nil {
|
|
logContext.WithError(errors.WithStack(err)).WithField("file", file.Name()).Error("Error removing file")
|
|
}
|
|
}
|
|
}()
|
|
|
|
actions, err := controller.pluginManager.GetRestoreItemActions(restore.Name)
|
|
if err != nil {
|
|
restoreErrors.Ark = append(restoreErrors.Ark, err.Error())
|
|
return
|
|
}
|
|
defer controller.pluginManager.CloseRestoreItemActions(restore.Name)
|
|
|
|
logContext.Info("starting restore")
|
|
restoreWarnings, restoreErrors = controller.restorer.Restore(restore, backup, backupFile, logFile, actions)
|
|
logContext.Info("restore completed")
|
|
|
|
// Try to upload the log file. This is best-effort. If we fail, we'll add to the ark errors.
|
|
|
|
// Reset the offset to 0 for reading
|
|
if _, err = logFile.Seek(0, 0); err != nil {
|
|
restoreErrors.Ark = append(restoreErrors.Ark, fmt.Sprintf("error resetting log file offset to 0: %v", err))
|
|
return
|
|
}
|
|
|
|
if err := controller.backupService.UploadRestoreLog(bucket, restore.Spec.BackupName, restore.Name, logFile); err != nil {
|
|
restoreErrors.Ark = append(restoreErrors.Ark, fmt.Sprintf("error uploading log file to object storage: %v", err))
|
|
}
|
|
|
|
m := map[string]api.RestoreResult{
|
|
"warnings": restoreWarnings,
|
|
"errors": restoreErrors,
|
|
}
|
|
|
|
gzippedResultsFile := gzip.NewWriter(resultsFile)
|
|
|
|
if err := json.NewEncoder(gzippedResultsFile).Encode(m); err != nil {
|
|
logContext.WithError(errors.WithStack(err)).Error("Error encoding restore results")
|
|
return
|
|
}
|
|
gzippedResultsFile.Close()
|
|
|
|
if _, err = resultsFile.Seek(0, 0); err != nil {
|
|
logContext.WithError(errors.WithStack(err)).Error("Error resetting results file offset to 0")
|
|
return
|
|
}
|
|
if err := controller.backupService.UploadRestoreResults(bucket, restore.Spec.BackupName, restore.Name, resultsFile); err != nil {
|
|
logContext.WithError(errors.WithStack(err)).Error("Error uploading results files to object storage")
|
|
}
|
|
|
|
return
|
|
}
|
|
|
|
func downloadToTempFile(backupName string, backupService cloudprovider.BackupService, bucket string, logger logrus.FieldLogger) (*os.File, error) {
|
|
readCloser, err := backupService.DownloadBackup(bucket, backupName)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
defer readCloser.Close()
|
|
|
|
file, err := ioutil.TempFile("", backupName)
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "error creating Backup temp file")
|
|
}
|
|
|
|
n, err := io.Copy(file, readCloser)
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "error copying Backup to temp file")
|
|
}
|
|
|
|
logContext := logger.WithField("backup", backupName)
|
|
|
|
logContext.WithFields(logrus.Fields{
|
|
"fileName": file.Name(),
|
|
"bytes": n,
|
|
}).Debug("Copied Backup to file")
|
|
|
|
if _, err := file.Seek(0, 0); err != nil {
|
|
return nil, errors.Wrap(err, "error resetting Backup file offset")
|
|
}
|
|
|
|
return file, nil
|
|
}
|
|
|
|
func patchRestore(original, updated *api.Restore, client arkv1client.RestoresGetter) (*api.Restore, error) {
|
|
origBytes, err := json.Marshal(original)
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "error marshalling original restore")
|
|
}
|
|
|
|
updatedBytes, err := json.Marshal(updated)
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "error marshalling updated restore")
|
|
}
|
|
|
|
patchBytes, err := strategicpatch.CreateTwoWayMergePatch(origBytes, updatedBytes, api.Restore{})
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "error creating two-way merge patch for restore")
|
|
}
|
|
|
|
res, err := client.Restores(api.DefaultNamespace).Patch(original.Name, types.MergePatchType, patchBytes)
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "error patching restore")
|
|
}
|
|
|
|
return res, nil
|
|
}
|