k3s/pkg/controller/statefulset/stateful_set.go

308 lines
10 KiB
Go
Raw Normal View History

2016-04-25 19:24:40 +00:00
/*
Copyright 2016 The Kubernetes Authors.
2016-04-25 19:24:40 +00:00
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 statefulset
2016-04-25 19:24:40 +00:00
import (
"fmt"
"reflect"
"sort"
"time"
2017-01-11 14:09:48 +00:00
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
2017-01-30 18:39:54 +00:00
v1core "k8s.io/client-go/kubernetes/typed/core/v1"
clientv1 "k8s.io/client-go/pkg/api/v1"
2017-01-24 14:11:51 +00:00
"k8s.io/client-go/tools/cache"
2017-01-30 18:39:54 +00:00
"k8s.io/client-go/tools/record"
2017-01-30 18:39:54 +00:00
"k8s.io/kubernetes/pkg/api"
2016-11-18 20:50:17 +00:00
"k8s.io/kubernetes/pkg/api/v1"
apps "k8s.io/kubernetes/pkg/apis/apps/v1beta1"
"k8s.io/kubernetes/pkg/client/clientset_generated/clientset"
"k8s.io/kubernetes/pkg/client/legacylisters"
2017-01-11 14:09:48 +00:00
"k8s.io/apimachinery/pkg/runtime"
utilruntime "k8s.io/apimachinery/pkg/util/runtime"
"k8s.io/apimachinery/pkg/util/wait"
"k8s.io/apimachinery/pkg/watch"
2017-01-27 15:20:40 +00:00
"k8s.io/client-go/util/workqueue"
2016-04-25 19:24:40 +00:00
"k8s.io/kubernetes/pkg/controller"
"github.com/golang/glog"
)
const (
2016-10-26 20:44:07 +00:00
// period to relist statefulsets and verify pets
statefulSetResyncPeriod = 30 * time.Second
2016-04-25 19:24:40 +00:00
)
2016-10-26 20:44:07 +00:00
// StatefulSetController controls statefulsets.
type StatefulSetController struct {
// client interface
2016-11-18 20:50:17 +00:00
kubeClient clientset.Interface
// control returns an interface capable of syncing a stateful set.
2016-04-25 19:24:40 +00:00
// Abstracted out for testing.
control StatefulSetControlInterface
2016-04-25 19:24:40 +00:00
// podStore is a cache of watched pods.
podStore listers.StoreToPodLister
2016-04-25 19:24:40 +00:00
// podStoreSynced returns true if the pod store has synced at least once.
podStoreSynced cache.InformerSynced
// A store of StatefulSets, populated by setController.
setStore listers.StoreToStatefulSetLister
2016-10-26 20:44:07 +00:00
// Watches changes to all StatefulSets.
setController cache.Controller
// StatefulSets that need to be synced.
2016-08-19 18:49:05 +00:00
queue workqueue.RateLimitingInterface
2016-04-25 19:24:40 +00:00
}
2016-10-26 20:44:07 +00:00
// NewStatefulSetController creates a new statefulset controller.
2016-11-18 20:50:17 +00:00
func NewStatefulSetController(podInformer cache.SharedIndexInformer, kubeClient clientset.Interface, resyncPeriod time.Duration) *StatefulSetController {
2016-04-25 19:24:40 +00:00
eventBroadcaster := record.NewBroadcaster()
eventBroadcaster.StartLogging(glog.Infof)
2017-01-30 18:39:54 +00:00
eventBroadcaster.StartRecordingToSink(&v1core.EventSinkImpl{Interface: v1core.New(kubeClient.Core().RESTClient()).Events("")})
recorder := eventBroadcaster.NewRecorder(api.Scheme, clientv1.EventSource{Component: "statefulset"})
2016-04-25 19:24:40 +00:00
ssc := &StatefulSetController{
kubeClient: kubeClient,
control: NewDefaultStatefulSetControl(NewRealStatefulPodControl(kubeClient, recorder)),
queue: workqueue.NewNamedRateLimitingQueue(workqueue.DefaultControllerRateLimiter(), "statefulset"),
2016-04-25 19:24:40 +00:00
}
podInformer.AddEventHandler(cache.ResourceEventHandlerFuncs{
2016-10-26 20:44:07 +00:00
// lookup the statefulset and enqueue
AddFunc: ssc.addPod,
2016-10-26 20:44:07 +00:00
// lookup current and old statefulset if labels changed
UpdateFunc: ssc.updatePod,
2016-10-26 20:44:07 +00:00
// lookup statefulset accounting for deletion tombstones
DeleteFunc: ssc.deletePod,
2016-04-25 19:24:40 +00:00
})
ssc.podStore.Indexer = podInformer.GetIndexer()
2016-04-25 19:24:40 +00:00
ssc.setStore.Store, ssc.setController = cache.NewInformer(
2016-04-25 19:24:40 +00:00
&cache.ListWatch{
ListFunc: func(options metav1.ListOptions) (runtime.Object, error) {
return ssc.kubeClient.Apps().StatefulSets(v1.NamespaceAll).List(options)
2016-04-25 19:24:40 +00:00
},
WatchFunc: func(options metav1.ListOptions) (watch.Interface, error) {
return ssc.kubeClient.Apps().StatefulSets(v1.NamespaceAll).Watch(options)
2016-04-25 19:24:40 +00:00
},
},
2016-10-26 20:44:07 +00:00
&apps.StatefulSet{},
statefulSetResyncPeriod,
cache.ResourceEventHandlerFuncs{
AddFunc: ssc.enqueueStatefulSet,
2016-04-25 19:24:40 +00:00
UpdateFunc: func(old, cur interface{}) {
2016-10-26 20:44:07 +00:00
oldPS := old.(*apps.StatefulSet)
curPS := cur.(*apps.StatefulSet)
2016-04-25 19:24:40 +00:00
if oldPS.Status.Replicas != curPS.Status.Replicas {
2016-10-26 20:44:07 +00:00
glog.V(4).Infof("Observed updated replica count for StatefulSet: %v, %d->%d", curPS.Name, oldPS.Status.Replicas, curPS.Status.Replicas)
2016-04-25 19:24:40 +00:00
}
ssc.enqueueStatefulSet(cur)
2016-04-25 19:24:40 +00:00
},
DeleteFunc: ssc.enqueueStatefulSet,
2016-04-25 19:24:40 +00:00
},
)
// TODO: Watch volumes
ssc.podStoreSynced = podInformer.GetController().HasSynced
return ssc
2016-04-25 19:24:40 +00:00
}
2016-10-26 20:44:07 +00:00
// Run runs the statefulset controller.
func (ssc *StatefulSetController) Run(workers int, stopCh <-chan struct{}) {
2016-04-25 19:24:40 +00:00
defer utilruntime.HandleCrash()
defer ssc.queue.ShutDown()
2016-10-26 20:44:07 +00:00
glog.Infof("Starting statefulset controller")
if !cache.WaitForCacheSync(stopCh, ssc.podStoreSynced) {
utilruntime.HandleError(fmt.Errorf("timed out waiting for caches to sync"))
return
}
go ssc.setController.Run(stopCh)
2016-04-25 19:24:40 +00:00
for i := 0; i < workers; i++ {
go wait.Until(ssc.worker, time.Second, stopCh)
2016-04-25 19:24:40 +00:00
}
<-stopCh
2016-10-26 20:44:07 +00:00
glog.Infof("Shutting down statefulset controller")
2016-04-25 19:24:40 +00:00
}
2016-10-26 20:44:07 +00:00
// addPod adds the statefulset for the pod to the sync queue
func (ssc *StatefulSetController) addPod(obj interface{}) {
2016-11-18 20:50:17 +00:00
pod := obj.(*v1.Pod)
2016-04-25 19:24:40 +00:00
glog.V(4).Infof("Pod %s created, labels: %+v", pod.Name, pod.Labels)
set := ssc.getStatefulSetForPod(pod)
if set == nil {
2016-04-25 19:24:40 +00:00
return
}
ssc.enqueueStatefulSet(set)
2016-04-25 19:24:40 +00:00
}
2016-10-26 20:44:07 +00:00
// updatePod adds the statefulset for the current and old pods to the sync queue.
// If the labels of the pod didn't change, this method enqueues a single statefulset.
func (ssc *StatefulSetController) updatePod(old, cur interface{}) {
2016-11-18 20:50:17 +00:00
curPod := cur.(*v1.Pod)
oldPod := old.(*v1.Pod)
if curPod.ResourceVersion == oldPod.ResourceVersion {
// Periodic resync will send update events for all known pods.
// Two different versions of the same pod will always have different RVs.
return
}
set := ssc.getStatefulSetForPod(curPod)
if set == nil {
2016-04-25 19:24:40 +00:00
return
}
ssc.enqueueStatefulSet(set)
// TODO will we need this going forward with controller ref impl?
2016-04-25 19:24:40 +00:00
if !reflect.DeepEqual(curPod.Labels, oldPod.Labels) {
if oldSet := ssc.getStatefulSetForPod(oldPod); oldSet != nil {
ssc.enqueueStatefulSet(oldSet)
2016-04-25 19:24:40 +00:00
}
}
}
2016-10-26 20:44:07 +00:00
// deletePod enqueues the statefulset for the pod accounting for deletion tombstones.
func (ssc *StatefulSetController) deletePod(obj interface{}) {
2016-11-18 20:50:17 +00:00
pod, ok := obj.(*v1.Pod)
2016-04-25 19:24:40 +00:00
// When a delete is dropped, the relist will notice a pod in the store not
// in the list, leading to the insertion of a tombstone object which contains
// the deleted key/value. Note that this value might be stale. If the pod
2016-10-26 20:44:07 +00:00
// changed labels the new StatefulSet will not be woken up till the periodic resync.
2016-04-25 19:24:40 +00:00
if !ok {
tombstone, ok := obj.(cache.DeletedFinalStateUnknown)
if !ok {
utilruntime.HandleError(fmt.Errorf("couldn't get object from tombstone %+v", obj))
2016-04-25 19:24:40 +00:00
return
}
2016-11-18 20:50:17 +00:00
pod, ok = tombstone.Obj.(*v1.Pod)
2016-04-25 19:24:40 +00:00
if !ok {
utilruntime.HandleError(fmt.Errorf("tombstone contained object that is not a pod %+v", obj))
2016-04-25 19:24:40 +00:00
return
}
}
glog.V(4).Infof("Pod %s/%s deleted through %v.", pod.Namespace, pod.Name, utilruntime.GetCaller())
if set := ssc.getStatefulSetForPod(pod); set != nil {
ssc.enqueueStatefulSet(set)
2016-04-25 19:24:40 +00:00
}
}
2016-10-26 20:44:07 +00:00
// getPodsForStatefulSets returns the pods that match the selectors of the given statefulset.
func (ssc *StatefulSetController) getPodsForStatefulSet(set *apps.StatefulSet) ([]*v1.Pod, error) {
sel, err := metav1.LabelSelectorAsSelector(set.Spec.Selector)
2016-04-25 19:24:40 +00:00
if err != nil {
2016-11-18 20:50:17 +00:00
return []*v1.Pod{}, err
2016-04-25 19:24:40 +00:00
}
return ssc.podStore.Pods(set.Namespace).List(sel)
2016-04-25 19:24:40 +00:00
}
// getStatefulSetForPod returns the StatefulSet managing the given pod.
func (ssc *StatefulSetController) getStatefulSetForPod(pod *v1.Pod) *apps.StatefulSet {
sets, err := ssc.setStore.GetPodStatefulSets(pod)
2016-04-25 19:24:40 +00:00
if err != nil {
2016-10-26 20:44:07 +00:00
glog.V(4).Infof("No StatefulSets found for pod %v, StatefulSet controller will avoid syncing", pod.Name)
2016-04-25 19:24:40 +00:00
return nil
}
// More than one set is selecting the same Pod
if len(sets) > 1 {
utilruntime.HandleError(
fmt.Errorf(
"user error: more than one StatefulSet is selecting pods with labels: %+v",
pod.Labels))
// The timestamp sort should not be necessary because we will enforce the CreatedBy requirement by
// name
sort.Sort(overlappingStatefulSets(sets))
// return the first created set for which pod is a member
for i := range sets {
if isMemberOf(&sets[i], pod) {
return &sets[i]
}
}
glog.V(4).Infof("No StatefulSets found for pod %v, StatefulSet controller will avoid syncing", pod.Name)
return nil
2016-04-25 19:24:40 +00:00
}
return &sets[0]
2016-04-25 19:24:40 +00:00
}
2016-10-26 20:44:07 +00:00
// enqueueStatefulSet enqueues the given statefulset in the work queue.
func (ssc *StatefulSetController) enqueueStatefulSet(obj interface{}) {
2016-04-25 19:24:40 +00:00
key, err := controller.KeyFunc(obj)
if err != nil {
utilruntime.HandleError(fmt.Errorf("Cound't get key for object %+v: %v", obj, err))
2016-04-25 19:24:40 +00:00
return
}
ssc.queue.Add(key)
2016-04-25 19:24:40 +00:00
}
// processNextWorkItem dequeues items, processes them, and marks them done. It enforces that the syncHandler is never
// invoked concurrently with the same key.
func (ssc *StatefulSetController) processNextWorkItem() bool {
key, quit := ssc.queue.Get()
if quit {
return false
}
defer ssc.queue.Done(key)
if err := ssc.sync(key.(string)); err != nil {
utilruntime.HandleError(fmt.Errorf("Error syncing StatefulSet %v, requeuing: %v", key.(string), err))
ssc.queue.AddRateLimited(key)
} else {
ssc.queue.Forget(key)
}
return true
}
// worker runs a worker goroutine that invokes processNextWorkItem until the the controller's queue is closed
func (ssc *StatefulSetController) worker() {
for ssc.processNextWorkItem() {
2016-04-25 19:24:40 +00:00
}
}
// sync syncs the given statefulset.
func (ssc *StatefulSetController) sync(key string) error {
2016-04-25 19:24:40 +00:00
startTime := time.Now()
defer func() {
2016-10-26 20:44:07 +00:00
glog.V(4).Infof("Finished syncing statefulset %q (%v)", key, time.Now().Sub(startTime))
2016-04-25 19:24:40 +00:00
}()
obj, exists, err := ssc.setStore.Store.GetByKey(key)
2016-04-25 19:24:40 +00:00
if !exists {
2016-10-26 20:44:07 +00:00
glog.Infof("StatefulSet has been deleted %v", key)
return nil
2016-04-25 19:24:40 +00:00
}
if err != nil {
utilruntime.HandleError(fmt.Errorf("Unable to retrieve StatefulSet %v from store: %v", key, err))
return err
2016-04-25 19:24:40 +00:00
}
set := *obj.(*apps.StatefulSet)
pods, err := ssc.getPodsForStatefulSet(&set)
2016-04-25 19:24:40 +00:00
if err != nil {
return err
2016-04-25 19:24:40 +00:00
}
return ssc.syncStatefulSet(&set, pods)
2016-04-25 19:24:40 +00:00
}
// syncStatefulSet syncs a tuple of (statefulset, []*v1.Pod).
func (ssc *StatefulSetController) syncStatefulSet(set *apps.StatefulSet, pods []*v1.Pod) error {
glog.V(2).Infof("Syncing StatefulSet %v/%v with %d pods", set.Namespace, set.Name, len(pods))
if err := ssc.control.UpdateStatefulSet(set, pods); err != nil {
glog.V(2).Infof("Error syncing StatefulSet %s/%s with %d pods : %s", set.Namespace, set.Name, err)
return err
2016-04-25 19:24:40 +00:00
}
glog.V(2).Infof("Succesfully synced StatefulSet %s/%s successful", set.Namespace, set.Name)
return nil
2016-04-25 19:24:40 +00:00
}