2016-06-25 09:31:32 +00:00
/ *
Copyright 2016 The Kubernetes Authors .
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 deployment
import (
"fmt"
"reflect"
"sort"
"strconv"
"github.com/golang/glog"
2017-01-13 17:48:50 +00:00
"k8s.io/apimachinery/pkg/api/errors"
2017-01-11 14:09:48 +00:00
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
2017-02-26 18:53:45 +00:00
"k8s.io/apimachinery/pkg/types"
2017-01-11 14:09:48 +00:00
utilerrors "k8s.io/apimachinery/pkg/util/errors"
2016-06-25 09:31:32 +00:00
"k8s.io/kubernetes/pkg/api"
2016-11-18 20:50:17 +00:00
"k8s.io/kubernetes/pkg/api/v1"
extensions "k8s.io/kubernetes/pkg/apis/extensions/v1beta1"
2016-06-25 09:31:32 +00:00
"k8s.io/kubernetes/pkg/controller"
2016-07-05 07:29:09 +00:00
deploymentutil "k8s.io/kubernetes/pkg/controller/deployment/util"
2016-06-25 09:31:32 +00:00
labelsutil "k8s.io/kubernetes/pkg/util/labels"
)
2016-06-17 11:46:43 +00:00
// syncStatusOnly only updates Deployments Status and doesn't take any mutating actions.
2017-02-26 18:53:45 +00:00
func ( dc * DeploymentController ) syncStatusOnly ( d * extensions . Deployment , rsList [ ] * extensions . ReplicaSet , podMap map [ types . UID ] * v1 . PodList ) error {
newRS , oldRSs , err := dc . getAllReplicaSetsAndSyncRevision ( d , rsList , podMap , false )
2016-06-17 11:46:43 +00:00
if err != nil {
return err
}
allRSs := append ( oldRSs , newRS )
2017-02-26 18:53:45 +00:00
return dc . syncDeploymentStatus ( allRSs , newRS , d )
2016-06-17 11:46:43 +00:00
}
2016-06-25 09:31:32 +00:00
// sync is responsible for reconciling deployments on scaling events or when they
// are paused.
2017-02-26 18:53:45 +00:00
func ( dc * DeploymentController ) sync ( d * extensions . Deployment , rsList [ ] * extensions . ReplicaSet , podMap map [ types . UID ] * v1 . PodList ) error {
newRS , oldRSs , err := dc . getAllReplicaSetsAndSyncRevision ( d , rsList , podMap , false )
2016-06-25 09:31:32 +00:00
if err != nil {
return err
}
2017-02-26 18:53:45 +00:00
if err := dc . scale ( d , newRS , oldRSs ) ; err != nil {
2016-06-25 09:31:32 +00:00
// If we get an error while trying to scale, the deployment will be requeued
// so we can abort this resync
return err
}
allRSs := append ( oldRSs , newRS )
2017-02-26 18:53:45 +00:00
return dc . syncDeploymentStatus ( allRSs , newRS , d )
2016-06-25 09:31:32 +00:00
}
2016-09-15 15:57:53 +00:00
// checkPausedConditions checks if the given deployment is paused or not and adds an appropriate condition.
// These conditions are needed so that we won't accidentally report lack of progress for resumed deployments
// that were paused for longer than progressDeadlineSeconds.
func ( dc * DeploymentController ) checkPausedConditions ( d * extensions . Deployment ) error {
if d . Spec . ProgressDeadlineSeconds == nil {
return nil
}
cond := deploymentutil . GetDeploymentCondition ( d . Status , extensions . DeploymentProgressing )
if cond != nil && cond . Reason == deploymentutil . TimedOutReason {
// If we have reported lack of progress, do not overwrite it with a paused condition.
return nil
}
pausedCondExists := cond != nil && cond . Reason == deploymentutil . PausedDeployReason
needsUpdate := false
if d . Spec . Paused && ! pausedCondExists {
2016-11-18 20:50:17 +00:00
condition := deploymentutil . NewDeploymentCondition ( extensions . DeploymentProgressing , v1 . ConditionUnknown , deploymentutil . PausedDeployReason , "Deployment is paused" )
2016-09-15 15:57:53 +00:00
deploymentutil . SetDeploymentCondition ( & d . Status , * condition )
needsUpdate = true
} else if ! d . Spec . Paused && pausedCondExists {
2016-11-18 20:50:17 +00:00
condition := deploymentutil . NewDeploymentCondition ( extensions . DeploymentProgressing , v1 . ConditionUnknown , deploymentutil . ResumedDeployReason , "Deployment is resumed" )
2016-09-15 15:57:53 +00:00
deploymentutil . SetDeploymentCondition ( & d . Status , * condition )
needsUpdate = true
}
if ! needsUpdate {
return nil
}
var err error
d , err = dc . client . Extensions ( ) . Deployments ( d . Namespace ) . UpdateStatus ( d )
return err
}
2016-06-25 09:31:32 +00:00
// getAllReplicaSetsAndSyncRevision returns all the replica sets for the provided deployment (new and all old), with new RS's and deployment's revision updated.
2017-02-26 18:53:45 +00:00
//
// rsList should come from getReplicaSetsForDeployment(d).
2017-03-04 00:10:27 +00:00
// podMap should come from getPodMapForDeployment(d, rsList).
2017-02-26 18:53:45 +00:00
//
2016-06-25 09:31:32 +00:00
// 1. Get all old RSes this deployment targets, and calculate the max revision number among them (maxOldV).
// 2. Get new RS this deployment targets (whose pod template matches deployment's), and update new RS's revision number to (maxOldV + 1),
// only if its revision number is smaller than (maxOldV + 1). If this step failed, we'll update it in the next deployment sync loop.
// 3. Copy new RS's revision number to deployment (update deployment's revision). If this step failed, we'll update it in the next deployment sync loop.
2017-02-26 18:53:45 +00:00
//
2016-06-25 09:31:32 +00:00
// Note that currently the deployment controller is using caches to avoid querying the server for reads.
// This may lead to stale reads of replica sets, thus incorrect deployment status.
2017-02-26 18:53:45 +00:00
func ( dc * DeploymentController ) getAllReplicaSetsAndSyncRevision ( d * extensions . Deployment , rsList [ ] * extensions . ReplicaSet , podMap map [ types . UID ] * v1 . PodList , createIfNotExisted bool ) ( * extensions . ReplicaSet , [ ] * extensions . ReplicaSet , error ) {
2016-06-25 09:31:32 +00:00
// List the deployment's RSes & Pods and apply pod-template-hash info to deployment's adopted RSes/Pods
2017-02-26 18:53:45 +00:00
rsList , podList , err := dc . rsAndPodsWithHashKeySynced ( d , rsList , podMap )
2016-06-25 09:31:32 +00:00
if err != nil {
return nil , nil , fmt . Errorf ( "error labeling replica sets and pods with pod-template-hash: %v" , err )
}
2017-02-26 18:53:45 +00:00
_ , allOldRSs , err := deploymentutil . FindOldReplicaSets ( d , rsList , podList )
2016-06-25 09:31:32 +00:00
if err != nil {
return nil , nil , err
}
// Get new replica set with the updated revision number
2017-02-26 18:53:45 +00:00
newRS , err := dc . getNewReplicaSet ( d , rsList , allOldRSs , createIfNotExisted )
2016-06-25 09:31:32 +00:00
if err != nil {
return nil , nil , err
}
return newRS , allOldRSs , nil
}
2017-02-26 18:53:45 +00:00
// rsAndPodsWithHashKeySynced returns the RSes and pods the given deployment
// targets, with pod-template-hash information synced.
//
// rsList should come from getReplicaSetsForDeployment(d).
2017-03-04 00:10:27 +00:00
// podMap should come from getPodMapForDeployment(d, rsList).
2017-02-26 18:53:45 +00:00
func ( dc * DeploymentController ) rsAndPodsWithHashKeySynced ( d * extensions . Deployment , rsList [ ] * extensions . ReplicaSet , podMap map [ types . UID ] * v1 . PodList ) ( [ ] * extensions . ReplicaSet , * v1 . PodList , error ) {
2016-10-04 17:23:27 +00:00
syncedRSList := [ ] * extensions . ReplicaSet { }
2016-06-25 09:31:32 +00:00
for _ , rs := range rsList {
// Add pod-template-hash information if it's not in the RS.
// Otherwise, new RS produced by Deployment will overlap with pre-existing ones
// that aren't constrained by the pod-template-hash.
2017-02-26 18:53:45 +00:00
syncedRS , err := dc . addHashKeyToRSAndPods ( rs , podMap [ rs . UID ] )
2016-06-25 09:31:32 +00:00
if err != nil {
return nil , nil , err
}
2016-10-04 17:23:27 +00:00
syncedRSList = append ( syncedRSList , syncedRS )
2016-06-25 09:31:32 +00:00
}
2017-02-26 18:53:45 +00:00
// Put all Pods from podMap into one list.
syncedPodList := & v1 . PodList { }
for _ , podList := range podMap {
syncedPodList . Items = append ( syncedPodList . Items , podList . Items ... )
2016-06-25 09:31:32 +00:00
}
return syncedRSList , syncedPodList , nil
}
// addHashKeyToRSAndPods adds pod-template-hash information to the given rs, if it's not already there, with the following steps:
// 1. Add hash label to the rs's pod template, and make sure the controller sees this update so that no orphaned pods will be created
// 2. Add hash label to all pods this rs owns, wait until replicaset controller reports rs.Status.FullyLabeledReplicas equal to the desired number of replicas
// 3. Add hash label to the rs's label and selector
2017-02-26 18:53:45 +00:00
func ( dc * DeploymentController ) addHashKeyToRSAndPods ( rs * extensions . ReplicaSet , podList * v1 . PodList ) ( * extensions . ReplicaSet , error ) {
2016-06-25 09:31:32 +00:00
// If the rs already has the new hash label in its selector, it's done syncing
if labelsutil . SelectorHasLabel ( rs . Spec . Selector , extensions . DefaultDeploymentUniqueLabelKey ) {
2016-11-07 13:23:15 +00:00
return rs , nil
2016-06-25 09:31:32 +00:00
}
2016-11-07 13:23:15 +00:00
hash := deploymentutil . GetReplicaSetHash ( rs )
2016-06-25 09:31:32 +00:00
// 1. Add hash template label to the rs. This ensures that any newly created pods will have the new label.
2016-11-07 13:23:15 +00:00
updatedRS , err := deploymentutil . UpdateRSWithRetries ( dc . client . Extensions ( ) . ReplicaSets ( rs . Namespace ) , dc . rsLister , rs . Namespace , rs . Name ,
2016-06-25 09:31:32 +00:00
func ( updated * extensions . ReplicaSet ) error {
// Precondition: the RS doesn't contain the new hash in its pod template label.
if updated . Spec . Template . Labels [ extensions . DefaultDeploymentUniqueLabelKey ] == hash {
return utilerrors . ErrPreconditionViolated
}
updated . Spec . Template . Labels = labelsutil . AddLabel ( updated . Spec . Template . Labels , extensions . DefaultDeploymentUniqueLabelKey , hash )
return nil
} )
if err != nil {
2016-11-07 13:23:15 +00:00
return nil , fmt . Errorf ( "error updating replica set %s/%s pod template label with template hash: %v" , rs . Namespace , rs . Name , err )
2016-06-25 09:31:32 +00:00
}
// Make sure rs pod template is updated so that it won't create pods without the new label (orphaned pods).
if updatedRS . Generation > updatedRS . Status . ObservedGeneration {
2017-02-10 16:43:30 +00:00
// TODO: Revisit if we really need to wait here as opposed to returning and
// potentially unblocking this worker (can wait up to 1min before timing out).
if err = deploymentutil . WaitForReplicaSetUpdated ( dc . rsLister , updatedRS . Generation , updatedRS . Namespace , updatedRS . Name ) ; err != nil {
2016-11-07 13:23:15 +00:00
return nil , fmt . Errorf ( "error waiting for replica set %s/%s to be observed by controller: %v" , updatedRS . Namespace , updatedRS . Name , err )
2016-06-25 09:31:32 +00:00
}
2016-11-07 13:23:15 +00:00
glog . V ( 4 ) . Infof ( "Observed the update of replica set %s/%s's pod template with hash %s." , rs . Namespace , rs . Name , hash )
2016-06-25 09:31:32 +00:00
}
// 2. Update all pods managed by the rs to have the new hash label, so they will be correctly adopted.
2017-02-26 18:53:45 +00:00
if err := deploymentutil . LabelPodsWithHash ( podList , dc . client , dc . podLister , rs . Namespace , rs . Name , hash ) ; err != nil {
2016-06-25 09:31:32 +00:00
return nil , fmt . Errorf ( "error in adding template hash label %s to pods %+v: %s" , hash , podList , err )
}
// We need to wait for the replicaset controller to observe the pods being
// labeled with pod template hash. Because previously we've called
// WaitForReplicaSetUpdated, the replicaset controller should have dropped
// FullyLabeledReplicas to 0 already, we only need to wait it to increase
// back to the number of replicas in the spec.
2017-02-10 16:43:30 +00:00
// TODO: Revisit if we really need to wait here as opposed to returning and
// potentially unblocking this worker (can wait up to 1min before timing out).
if err := deploymentutil . WaitForPodsHashPopulated ( dc . rsLister , updatedRS . Generation , updatedRS . Namespace , updatedRS . Name ) ; err != nil {
2016-11-07 13:23:15 +00:00
return nil , fmt . Errorf ( "Replica set %s/%s: error waiting for replicaset controller to observe pods being labeled with template hash: %v" , updatedRS . Namespace , updatedRS . Name , err )
2016-06-25 09:31:32 +00:00
}
// 3. Update rs label and selector to include the new hash label
// Copy the old selector, so that we can scrub out any orphaned pods
2016-11-07 13:23:15 +00:00
updatedRS , err = deploymentutil . UpdateRSWithRetries ( dc . client . Extensions ( ) . ReplicaSets ( rs . Namespace ) , dc . rsLister , rs . Namespace , rs . Name , func ( updated * extensions . ReplicaSet ) error {
// Precondition: the RS doesn't contain the new hash in its label and selector.
if updated . Labels [ extensions . DefaultDeploymentUniqueLabelKey ] == hash && updated . Spec . Selector . MatchLabels [ extensions . DefaultDeploymentUniqueLabelKey ] == hash {
return utilerrors . ErrPreconditionViolated
}
updated . Labels = labelsutil . AddLabel ( updated . Labels , extensions . DefaultDeploymentUniqueLabelKey , hash )
updated . Spec . Selector = labelsutil . AddLabelToSelector ( updated . Spec . Selector , extensions . DefaultDeploymentUniqueLabelKey , hash )
return nil
} )
// If the RS isn't actually updated, that's okay, we'll retry in the
// next sync loop since its selector isn't updated yet.
if err != nil {
return nil , fmt . Errorf ( "error updating ReplicaSet %s/%s label and selector with template hash: %v" , updatedRS . Namespace , updatedRS . Name , err )
2016-06-25 09:31:32 +00:00
}
// TODO: look for orphaned pods and label them in the background somewhere else periodically
return updatedRS , nil
}
// Returns a replica set that matches the intent of the given deployment. Returns nil if the new replica set doesn't exist yet.
// 1. Get existing new RS (the RS that the given deployment targets, whose pod template is the same as deployment's).
// 2. If there's existing new RS, update its revision number if it's smaller than (maxOldRevision + 1), where maxOldRevision is the max revision number among all old RSes.
// 3. If there's no existing new RS and createIfNotExisted is true, create one with appropriate revision number (maxOldRevision + 1) and replicas.
// Note that the pod-template-hash will be added to adopted RSes and pods.
2016-10-06 15:02:51 +00:00
func ( dc * DeploymentController ) getNewReplicaSet ( deployment * extensions . Deployment , rsList , oldRSs [ ] * extensions . ReplicaSet , createIfNotExisted bool ) ( * extensions . ReplicaSet , error ) {
2016-06-25 09:31:32 +00:00
existingNewRS , err := deploymentutil . FindNewReplicaSet ( deployment , rsList )
if err != nil {
return nil , err
2016-10-06 15:02:51 +00:00
}
// Calculate the max revision number among all old RSes
maxOldRevision := deploymentutil . MaxRevision ( oldRSs )
// Calculate revision number for this new replica set
newRevision := strconv . FormatInt ( maxOldRevision + 1 , 10 )
// Latest replica set exists. We need to sync its annotations (includes copying all but
// annotationsToSkip from the parent deployment, and update revision, desiredReplicas,
// and maxReplicas) and also update the revision annotation in the deployment with the
// latest revision.
if existingNewRS != nil {
2016-10-04 17:23:27 +00:00
objCopy , err := api . Scheme . Copy ( existingNewRS )
if err != nil {
return nil , err
}
rsCopy := objCopy . ( * extensions . ReplicaSet )
2016-06-25 09:31:32 +00:00
// Set existing new replica set's annotation
2016-10-11 14:37:39 +00:00
annotationsUpdated := deploymentutil . SetNewReplicaSetAnnotations ( deployment , rsCopy , newRevision , true )
minReadySecondsNeedsUpdate := rsCopy . Spec . MinReadySeconds != deployment . Spec . MinReadySeconds
if annotationsUpdated || minReadySecondsNeedsUpdate {
rsCopy . Spec . MinReadySeconds = deployment . Spec . MinReadySeconds
return dc . client . Extensions ( ) . ReplicaSets ( rsCopy . ObjectMeta . Namespace ) . Update ( rsCopy )
2016-10-06 15:02:51 +00:00
}
updateConditions := deploymentutil . SetDeploymentRevision ( deployment , newRevision )
2016-09-15 15:57:53 +00:00
// If no other Progressing condition has been recorded and we need to estimate the progress
// of this deployment then it is likely that old users started caring about progress. In that
// case we need to take into account the first time we noticed their new replica set.
cond := deploymentutil . GetDeploymentCondition ( deployment . Status , extensions . DeploymentProgressing )
if deployment . Spec . ProgressDeadlineSeconds != nil && cond == nil {
msg := fmt . Sprintf ( "Found new replica set %q" , rsCopy . Name )
2016-11-18 20:50:17 +00:00
condition := deploymentutil . NewDeploymentCondition ( extensions . DeploymentProgressing , v1 . ConditionTrue , deploymentutil . FoundNewRSReason , msg )
2016-09-15 15:57:53 +00:00
deploymentutil . SetDeploymentCondition ( & deployment . Status , * condition )
updateConditions = true
}
2016-10-06 15:02:51 +00:00
if updateConditions {
if deployment , err = dc . client . Extensions ( ) . Deployments ( deployment . Namespace ) . UpdateStatus ( deployment ) ; err != nil {
return nil , err
}
2016-06-25 09:31:32 +00:00
}
2016-10-04 17:23:27 +00:00
return rsCopy , nil
2016-06-25 09:31:32 +00:00
}
if ! createIfNotExisted {
return nil , nil
}
// new ReplicaSet does not exist, create one.
2016-10-06 15:02:51 +00:00
namespace := deployment . Namespace
2016-12-01 09:10:30 +00:00
podTemplateSpecHash := fmt . Sprintf ( "%d" , deploymentutil . GetPodTemplateSpecHash ( deployment . Spec . Template ) )
2016-06-25 09:31:32 +00:00
newRSTemplate := deploymentutil . GetNewReplicaSetTemplate ( deployment )
2016-12-01 09:10:30 +00:00
newRSTemplate . Labels = labelsutil . CloneAndAddLabel ( deployment . Spec . Template . Labels , extensions . DefaultDeploymentUniqueLabelKey , podTemplateSpecHash )
2016-06-25 09:31:32 +00:00
// Add podTemplateHash label to selector.
newRSSelector := labelsutil . CloneSelectorAndAddLabel ( deployment . Spec . Selector , extensions . DefaultDeploymentUniqueLabelKey , podTemplateSpecHash )
// Create new ReplicaSet
newRS := extensions . ReplicaSet {
2017-01-17 03:38:19 +00:00
ObjectMeta : metav1 . ObjectMeta {
2016-06-25 09:31:32 +00:00
// Make the name deterministic, to ensure idempotence
2017-02-26 18:53:45 +00:00
Name : deployment . Name + "-" + podTemplateSpecHash ,
Namespace : namespace ,
OwnerReferences : [ ] metav1 . OwnerReference { * newControllerRef ( deployment ) } ,
2016-06-25 09:31:32 +00:00
} ,
Spec : extensions . ReplicaSetSpec {
2017-02-26 18:53:45 +00:00
Replicas : new ( int32 ) ,
2016-10-11 14:37:39 +00:00
MinReadySeconds : deployment . Spec . MinReadySeconds ,
Selector : newRSSelector ,
Template : newRSTemplate ,
2016-06-25 09:31:32 +00:00
} ,
}
allRSs := append ( oldRSs , & newRS )
newReplicasCount , err := deploymentutil . NewRSNewReplicas ( deployment , allRSs , & newRS )
if err != nil {
return nil , err
}
2016-11-18 20:50:17 +00:00
* ( newRS . Spec . Replicas ) = newReplicasCount
2016-06-25 09:31:32 +00:00
// Set new replica set's annotation
2016-07-05 07:29:09 +00:00
deploymentutil . SetNewReplicaSetAnnotations ( deployment , & newRS , newRevision , false )
2016-06-25 09:31:32 +00:00
createdRS , err := dc . client . Extensions ( ) . ReplicaSets ( namespace ) . Create ( & newRS )
2016-09-15 15:57:53 +00:00
switch {
// We may end up hitting this due to a slow cache or a fast resync of the deployment.
2016-11-10 14:45:56 +00:00
// TODO: Restore once https://github.com/kubernetes/kubernetes/issues/29735 is fixed
// ie. we start using a new hashing algorithm.
2016-11-11 09:49:05 +00:00
case errors . IsAlreadyExists ( err ) :
return nil , err
2016-11-10 14:45:56 +00:00
// return dc.rsLister.ReplicaSets(namespace).Get(newRS.Name)
2016-09-15 15:57:53 +00:00
case err != nil :
msg := fmt . Sprintf ( "Failed to create new replica set %q: %v" , newRS . Name , err )
if deployment . Spec . ProgressDeadlineSeconds != nil {
2016-11-18 20:50:17 +00:00
cond := deploymentutil . NewDeploymentCondition ( extensions . DeploymentProgressing , v1 . ConditionFalse , deploymentutil . FailedRSCreateReason , msg )
2016-09-15 15:57:53 +00:00
deploymentutil . SetDeploymentCondition ( & deployment . Status , * cond )
// We don't really care about this error at this point, since we have a bigger issue to report.
// TODO: Update the rest of the Deployment status, too. We may need to do this every time we
// error out in all other places in the controller so that we let users know that their deployments
// have been noticed by the controller, albeit with errors.
// TODO: Identify which errors are permanent and switch DeploymentIsFailed to take into account
// these reasons as well. Related issue: https://github.com/kubernetes/kubernetes/issues/18568
_ , _ = dc . client . Extensions ( ) . Deployments ( deployment . ObjectMeta . Namespace ) . UpdateStatus ( deployment )
}
2016-11-18 20:50:17 +00:00
dc . eventRecorder . Eventf ( deployment , v1 . EventTypeWarning , deploymentutil . FailedRSCreateReason , msg )
2016-09-15 15:57:53 +00:00
return nil , err
2016-06-25 09:31:32 +00:00
}
if newReplicasCount > 0 {
2016-11-18 20:50:17 +00:00
dc . eventRecorder . Eventf ( deployment , v1 . EventTypeNormal , "ScalingReplicaSet" , "Scaled up replica set %s to %d" , createdRS . Name , newReplicasCount )
2016-06-25 09:31:32 +00:00
}
2016-10-06 15:02:51 +00:00
deploymentutil . SetDeploymentRevision ( deployment , newRevision )
2016-09-15 15:57:53 +00:00
if deployment . Spec . ProgressDeadlineSeconds != nil {
msg := fmt . Sprintf ( "Created new replica set %q" , createdRS . Name )
2016-11-18 20:50:17 +00:00
condition := deploymentutil . NewDeploymentCondition ( extensions . DeploymentProgressing , v1 . ConditionTrue , deploymentutil . NewReplicaSetReason , msg )
2016-09-15 15:57:53 +00:00
deploymentutil . SetDeploymentCondition ( & deployment . Status , * condition )
}
2016-10-06 15:02:51 +00:00
_ , err = dc . client . Extensions ( ) . Deployments ( deployment . Namespace ) . UpdateStatus ( deployment )
return createdRS , err
2016-06-25 09:31:32 +00:00
}
// scale scales proportionally in order to mitigate risk. Otherwise, scaling up can increase the size
// of the new replica set and scaling down can decrease the sizes of the old ones, both of which would
// have the effect of hastening the rollout progress, which could produce a higher proportion of unavailable
// replicas in the event of a problem with the rolled out template. Should run only on scaling events or
// when a deployment is paused and not during the normal rollout process.
func ( dc * DeploymentController ) scale ( deployment * extensions . Deployment , newRS * extensions . ReplicaSet , oldRSs [ ] * extensions . ReplicaSet ) error {
// If there is only one active replica set then we should scale that up to the full count of the
// deployment. If there is no active replica set, then we should scale up the newest replica set.
2016-07-05 07:29:09 +00:00
if activeOrLatest := deploymentutil . FindActiveOrLatest ( newRS , oldRSs ) ; activeOrLatest != nil {
2016-11-18 20:50:17 +00:00
if * ( activeOrLatest . Spec . Replicas ) == * ( deployment . Spec . Replicas ) {
2016-06-25 09:31:32 +00:00
return nil
}
2016-11-18 20:50:17 +00:00
_ , _ , err := dc . scaleReplicaSetAndRecordEvent ( activeOrLatest , * ( deployment . Spec . Replicas ) , deployment )
2016-06-25 09:31:32 +00:00
return err
}
// If the new replica set is saturated, old replica sets should be fully scaled down.
// This case handles replica set adoption during a saturated new replica set.
if deploymentutil . IsSaturated ( deployment , newRS ) {
for _ , old := range controller . FilterActiveReplicaSets ( oldRSs ) {
if _ , _ , err := dc . scaleReplicaSetAndRecordEvent ( old , 0 , deployment ) ; err != nil {
return err
}
}
return nil
}
// There are old replica sets with pods and the new replica set is not saturated.
// We need to proportionally scale all replica sets (new and old) in case of a
// rolling deployment.
if deploymentutil . IsRollingUpdate ( deployment ) {
allRSs := controller . FilterActiveReplicaSets ( append ( oldRSs , newRS ) )
allRSsReplicas := deploymentutil . GetReplicaCountForReplicaSets ( allRSs )
allowedSize := int32 ( 0 )
2016-11-18 20:50:17 +00:00
if * ( deployment . Spec . Replicas ) > 0 {
allowedSize = * ( deployment . Spec . Replicas ) + deploymentutil . MaxSurge ( * deployment )
2016-06-25 09:31:32 +00:00
}
// Number of additional replicas that can be either added or removed from the total
// replicas count. These replicas should be distributed proportionally to the active
// replica sets.
deploymentReplicasToAdd := allowedSize - allRSsReplicas
// The additional replicas should be distributed proportionally amongst the active
// replica sets from the larger to the smaller in size replica set. Scaling direction
// drives what happens in case we are trying to scale replica sets of the same size.
// In such a case when scaling up, we should scale up newer replica sets first, and
// when scaling down, we should scale down older replica sets first.
2016-11-04 12:00:37 +00:00
var scalingOperation string
2016-06-25 09:31:32 +00:00
switch {
case deploymentReplicasToAdd > 0 :
sort . Sort ( controller . ReplicaSetsBySizeNewer ( allRSs ) )
2016-11-04 12:00:37 +00:00
scalingOperation = "up"
2016-06-25 09:31:32 +00:00
case deploymentReplicasToAdd < 0 :
sort . Sort ( controller . ReplicaSetsBySizeOlder ( allRSs ) )
scalingOperation = "down"
}
// Iterate over all active replica sets and estimate proportions for each of them.
// The absolute value of deploymentReplicasAdded should never exceed the absolute
// value of deploymentReplicasToAdd.
deploymentReplicasAdded := int32 ( 0 )
2016-11-04 12:00:37 +00:00
nameToSize := make ( map [ string ] int32 )
2016-06-25 09:31:32 +00:00
for i := range allRSs {
rs := allRSs [ i ]
2016-11-04 12:00:37 +00:00
// Estimate proportions if we have replicas to add, otherwise simply populate
// nameToSize with the current sizes for each replica set.
if deploymentReplicasToAdd != 0 {
proportion := deploymentutil . GetProportion ( rs , * deployment , deploymentReplicasToAdd , deploymentReplicasAdded )
2016-06-25 09:31:32 +00:00
2016-11-18 20:50:17 +00:00
nameToSize [ rs . Name ] = * ( rs . Spec . Replicas ) + proportion
2016-11-04 12:00:37 +00:00
deploymentReplicasAdded += proportion
} else {
2016-11-18 20:50:17 +00:00
nameToSize [ rs . Name ] = * ( rs . Spec . Replicas )
2016-11-04 12:00:37 +00:00
}
2016-06-25 09:31:32 +00:00
}
// Update all replica sets
for i := range allRSs {
rs := allRSs [ i ]
// Add/remove any leftovers to the largest replica set.
2016-11-04 12:00:37 +00:00
if i == 0 && deploymentReplicasToAdd != 0 {
2016-06-25 09:31:32 +00:00
leftover := deploymentReplicasToAdd - deploymentReplicasAdded
2016-11-04 12:00:37 +00:00
nameToSize [ rs . Name ] = nameToSize [ rs . Name ] + leftover
if nameToSize [ rs . Name ] < 0 {
nameToSize [ rs . Name ] = 0
2016-06-25 09:31:32 +00:00
}
}
2016-11-04 12:00:37 +00:00
// TODO: Use transactions when we have them.
2016-11-08 11:10:25 +00:00
if _ , _ , err := dc . scaleReplicaSet ( rs , nameToSize [ rs . Name ] , deployment , scalingOperation ) ; err != nil {
2016-06-25 09:31:32 +00:00
// Return as soon as we fail, the deployment is requeued
return err
}
}
}
return nil
}
func ( dc * DeploymentController ) scaleReplicaSetAndRecordEvent ( rs * extensions . ReplicaSet , newScale int32 , deployment * extensions . Deployment ) ( bool , * extensions . ReplicaSet , error ) {
// No need to scale
2016-11-18 20:50:17 +00:00
if * ( rs . Spec . Replicas ) == newScale {
2016-06-25 09:31:32 +00:00
return false , rs , nil
}
var scalingOperation string
2016-11-18 20:50:17 +00:00
if * ( rs . Spec . Replicas ) < newScale {
2016-06-25 09:31:32 +00:00
scalingOperation = "up"
} else {
scalingOperation = "down"
}
2016-11-08 11:10:25 +00:00
scaled , newRS , err := dc . scaleReplicaSet ( rs , newScale , deployment , scalingOperation )
return scaled , newRS , err
2016-06-25 09:31:32 +00:00
}
2016-11-08 11:10:25 +00:00
func ( dc * DeploymentController ) scaleReplicaSet ( rs * extensions . ReplicaSet , newScale int32 , deployment * extensions . Deployment , scalingOperation string ) ( bool , * extensions . ReplicaSet , error ) {
2016-11-04 12:00:37 +00:00
objCopy , err := api . Scheme . Copy ( rs )
if err != nil {
2016-11-08 11:10:25 +00:00
return false , nil , err
2016-11-04 12:00:37 +00:00
}
rsCopy := objCopy . ( * extensions . ReplicaSet )
2016-11-18 20:50:17 +00:00
sizeNeedsUpdate := * ( rsCopy . Spec . Replicas ) != newScale
2016-11-08 11:10:25 +00:00
// TODO: Do not mutate the replica set here, instead simply compare the annotation and if they mismatch
// call SetReplicasAnnotations inside the following if clause. Then we can also move the deep-copy from
// above inside the if too.
2016-11-18 20:50:17 +00:00
annotationsNeedUpdate := deploymentutil . SetReplicasAnnotations ( rsCopy , * ( deployment . Spec . Replicas ) , * ( deployment . Spec . Replicas ) + deploymentutil . MaxSurge ( * deployment ) )
2016-11-04 12:00:37 +00:00
2016-11-08 11:10:25 +00:00
scaled := false
2016-11-04 12:00:37 +00:00
if sizeNeedsUpdate || annotationsNeedUpdate {
2016-11-18 20:50:17 +00:00
* ( rsCopy . Spec . Replicas ) = newScale
2016-11-04 12:00:37 +00:00
rs , err = dc . client . Extensions ( ) . ReplicaSets ( rsCopy . Namespace ) . Update ( rsCopy )
if err == nil && sizeNeedsUpdate {
2016-11-08 11:10:25 +00:00
scaled = true
2016-11-18 20:50:17 +00:00
dc . eventRecorder . Eventf ( deployment , v1 . EventTypeNormal , "ScalingReplicaSet" , "Scaled %s replica set %s to %d" , scalingOperation , rs . Name , newScale )
2016-11-04 12:00:37 +00:00
}
2016-06-25 09:31:32 +00:00
}
2016-11-08 11:10:25 +00:00
return scaled , rs , err
2016-06-25 09:31:32 +00:00
}
// cleanupDeployment is responsible for cleaning up a deployment ie. retains all but the latest N old replica sets
// where N=d.Spec.RevisionHistoryLimit. Old replica sets are older versions of the podtemplate of a deployment kept
// around by default 1) for historical reasons and 2) for the ability to rollback a deployment.
func ( dc * DeploymentController ) cleanupDeployment ( oldRSs [ ] * extensions . ReplicaSet , deployment * extensions . Deployment ) error {
if deployment . Spec . RevisionHistoryLimit == nil {
return nil
}
2017-02-08 22:18:13 +00:00
// Avoid deleting replica set with deletion timestamp set
aliveFilter := func ( rs * extensions . ReplicaSet ) bool {
return rs != nil && rs . ObjectMeta . DeletionTimestamp == nil
}
cleanableRSes := controller . FilterReplicaSets ( oldRSs , aliveFilter )
diff := int32 ( len ( cleanableRSes ) ) - * deployment . Spec . RevisionHistoryLimit
2016-06-25 09:31:32 +00:00
if diff <= 0 {
return nil
}
2017-02-08 22:18:13 +00:00
sort . Sort ( controller . ReplicaSetsByCreationTimestamp ( cleanableRSes ) )
2017-02-24 17:37:32 +00:00
glog . V ( 4 ) . Infof ( "Looking to cleanup old replica sets for deployment %q" , deployment . Name )
2016-06-25 09:31:32 +00:00
var errList [ ] error
// TODO: This should be parallelized.
for i := int32 ( 0 ) ; i < diff ; i ++ {
2017-02-08 22:18:13 +00:00
rs := cleanableRSes [ i ]
2016-06-25 09:31:32 +00:00
// Avoid delete replica set with non-zero replica counts
2017-02-09 09:30:32 +00:00
if rs . Status . Replicas != 0 || * ( rs . Spec . Replicas ) != 0 || rs . Generation > rs . Status . ObservedGeneration || rs . DeletionTimestamp != nil {
2016-06-25 09:31:32 +00:00
continue
}
2017-02-24 17:37:32 +00:00
glog . V ( 4 ) . Infof ( "Trying to cleanup replica set %q for deployment %q" , rs . Name , deployment . Name )
2016-06-25 09:31:32 +00:00
if err := dc . client . Extensions ( ) . ReplicaSets ( rs . Namespace ) . Delete ( rs . Name , nil ) ; err != nil && ! errors . IsNotFound ( err ) {
glog . V ( 2 ) . Infof ( "Failed deleting old replica set %v for deployment %v: %v" , rs . Name , deployment . Name , err )
errList = append ( errList , err )
}
}
return utilerrors . NewAggregate ( errList )
}
// syncDeploymentStatus checks if the status is up-to-date and sync it if necessary
func ( dc * DeploymentController ) syncDeploymentStatus ( allRSs [ ] * extensions . ReplicaSet , newRS * extensions . ReplicaSet , d * extensions . Deployment ) error {
2016-12-09 16:16:00 +00:00
newStatus := calculateStatus ( allRSs , newRS , d )
2016-10-11 14:37:39 +00:00
if reflect . DeepEqual ( d . Status , newStatus ) {
return nil
2016-06-25 09:31:32 +00:00
}
2016-10-11 14:37:39 +00:00
newDeployment := d
newDeployment . Status = newStatus
_ , err := dc . client . Extensions ( ) . Deployments ( newDeployment . Namespace ) . UpdateStatus ( newDeployment )
return err
2016-06-25 09:31:32 +00:00
}
2016-12-09 16:16:00 +00:00
// calculateStatus calculates the latest status for the provided deployment by looking into the provided replica sets.
func calculateStatus ( allRSs [ ] * extensions . ReplicaSet , newRS * extensions . ReplicaSet , deployment * extensions . Deployment ) extensions . DeploymentStatus {
2016-10-11 14:37:39 +00:00
availableReplicas := deploymentutil . GetAvailableReplicaCountForReplicaSets ( allRSs )
2016-06-25 09:31:32 +00:00
totalReplicas := deploymentutil . GetReplicaCountForReplicaSets ( allRSs )
2016-12-07 16:31:29 +00:00
unavailableReplicas := totalReplicas - availableReplicas
// If unavailableReplicas is negative, then that means the Deployment has more available replicas running than
// desired, eg. whenever it scales down. In such a case we should simply default unavailableReplicas to zero.
if unavailableReplicas < 0 {
unavailableReplicas = 0
}
2016-06-25 09:31:32 +00:00
2016-12-09 16:16:00 +00:00
status := extensions . DeploymentStatus {
2016-06-25 09:31:32 +00:00
// TODO: Ensure that if we start retrying status updates, we won't pick up a new Generation value.
ObservedGeneration : deployment . Generation ,
Replicas : deploymentutil . GetActualReplicaCountForReplicaSets ( allRSs ) ,
UpdatedReplicas : deploymentutil . GetActualReplicaCountForReplicaSets ( [ ] * extensions . ReplicaSet { newRS } ) ,
2016-12-02 16:32:34 +00:00
ReadyReplicas : deploymentutil . GetReadyReplicaCountForReplicaSets ( allRSs ) ,
2016-06-25 09:31:32 +00:00
AvailableReplicas : availableReplicas ,
2016-12-07 16:31:29 +00:00
UnavailableReplicas : unavailableReplicas ,
2016-06-25 09:31:32 +00:00
}
2016-12-09 16:16:00 +00:00
// Copy conditions one by one so we won't mutate the original object.
conditions := deployment . Status . Conditions
for i := range conditions {
status . Conditions = append ( status . Conditions , conditions [ i ] )
}
if availableReplicas >= * ( deployment . Spec . Replicas ) - deploymentutil . MaxUnavailable ( * deployment ) {
minAvailability := deploymentutil . NewDeploymentCondition ( extensions . DeploymentAvailable , v1 . ConditionTrue , deploymentutil . MinimumReplicasAvailable , "Deployment has minimum availability." )
deploymentutil . SetDeploymentCondition ( & status , * minAvailability )
} else {
noMinAvailability := deploymentutil . NewDeploymentCondition ( extensions . DeploymentAvailable , v1 . ConditionFalse , deploymentutil . MinimumReplicasUnavailable , "Deployment does not have minimum availability." )
deploymentutil . SetDeploymentCondition ( & status , * noMinAvailability )
}
return status
2016-06-25 09:31:32 +00:00
}
// isScalingEvent checks whether the provided deployment has been updated with a scaling event
// by looking at the desired-replicas annotation in the active replica sets of the deployment.
2017-02-26 18:53:45 +00:00
//
// rsList should come from getReplicaSetsForDeployment(d).
2017-03-04 00:10:27 +00:00
// podMap should come from getPodMapForDeployment(d, rsList).
2017-02-26 18:53:45 +00:00
func ( dc * DeploymentController ) isScalingEvent ( d * extensions . Deployment , rsList [ ] * extensions . ReplicaSet , podMap map [ types . UID ] * v1 . PodList ) ( bool , error ) {
newRS , oldRSs , err := dc . getAllReplicaSetsAndSyncRevision ( d , rsList , podMap , false )
2016-06-25 09:31:32 +00:00
if err != nil {
2016-06-28 11:31:03 +00:00
return false , err
2016-06-25 09:31:32 +00:00
}
allRSs := append ( oldRSs , newRS )
for _ , rs := range controller . FilterActiveReplicaSets ( allRSs ) {
2016-07-05 07:29:09 +00:00
desired , ok := deploymentutil . GetDesiredReplicasAnnotation ( rs )
2016-06-25 09:31:32 +00:00
if ! ok {
continue
}
2016-11-18 20:50:17 +00:00
if desired != * ( d . Spec . Replicas ) {
2016-06-28 11:31:03 +00:00
return true , nil
2016-06-25 09:31:32 +00:00
}
}
2016-06-28 11:31:03 +00:00
return false , nil
2016-06-25 09:31:32 +00:00
}
2017-02-26 18:53:45 +00:00
// newControllerRef returns a ControllerRef pointing to the deployment.
func newControllerRef ( d * extensions . Deployment ) * metav1 . OwnerReference {
2017-03-02 18:49:38 +00:00
blockOwnerDeletion := true
2017-02-26 18:53:45 +00:00
isController := true
return & metav1 . OwnerReference {
2017-03-02 18:49:38 +00:00
APIVersion : controllerKind . GroupVersion ( ) . String ( ) ,
Kind : controllerKind . Kind ,
Name : d . Name ,
UID : d . UID ,
BlockOwnerDeletion : & blockOwnerDeletion ,
Controller : & isController ,
2017-02-26 18:53:45 +00:00
}
}