mirror of
https://github.com/kyverno/kyverno.git
synced 2025-03-06 07:57:07 +00:00
152 lines
3.5 KiB
Go
152 lines
3.5 KiB
Go
|
package leaderelection
|
||
|
|
||
|
import (
|
||
|
"context"
|
||
|
"os"
|
||
|
"sync/atomic"
|
||
|
"time"
|
||
|
|
||
|
"github.com/go-logr/logr"
|
||
|
"github.com/pkg/errors"
|
||
|
"k8s.io/apimachinery/pkg/util/uuid"
|
||
|
"k8s.io/client-go/kubernetes"
|
||
|
"k8s.io/client-go/tools/leaderelection"
|
||
|
"k8s.io/client-go/tools/leaderelection/resourcelock"
|
||
|
)
|
||
|
|
||
|
type Interface interface {
|
||
|
|
||
|
// Run is a blocking call that runs a leader election
|
||
|
Run(ctx context.Context)
|
||
|
|
||
|
// ID returns this instances unique identifier
|
||
|
ID() string
|
||
|
|
||
|
// Name returns the name of the leader election
|
||
|
Name() string
|
||
|
|
||
|
// Namespace is the Kubernetes namespace used to coordinate the leader election
|
||
|
Namespace() string
|
||
|
|
||
|
// IsLeader indicates if this instance is the leader
|
||
|
IsLeader() bool
|
||
|
|
||
|
// GetLeader returns the leader ID
|
||
|
GetLeader() string
|
||
|
}
|
||
|
|
||
|
type Config struct {
|
||
|
name string
|
||
|
namespace string
|
||
|
startWork func()
|
||
|
stopWork func()
|
||
|
kubeClient kubernetes.Interface
|
||
|
lock resourcelock.Interface
|
||
|
leaderElectionCfg leaderelection.LeaderElectionConfig
|
||
|
leaderElector *leaderelection.LeaderElector
|
||
|
isLeader int64
|
||
|
log logr.Logger
|
||
|
}
|
||
|
|
||
|
func New(name, namespace string, kubeClient kubernetes.Interface, startWork, stopWork func(), log logr.Logger) (Interface, error) {
|
||
|
id, err := os.Hostname()
|
||
|
if err != nil {
|
||
|
return nil, errors.Wrapf(err, "error getting host name: %s/%s", namespace, name)
|
||
|
}
|
||
|
|
||
|
id = id + "_" + string(uuid.NewUUID())
|
||
|
|
||
|
lock, err := resourcelock.New(
|
||
|
resourcelock.LeasesResourceLock,
|
||
|
namespace,
|
||
|
name,
|
||
|
kubeClient.CoreV1(),
|
||
|
kubeClient.CoordinationV1(),
|
||
|
resourcelock.ResourceLockConfig{
|
||
|
Identity: id,
|
||
|
},
|
||
|
)
|
||
|
|
||
|
if err != nil {
|
||
|
return nil, errors.Wrapf(err, "error initializing resource lock: %s/%s", namespace, name)
|
||
|
}
|
||
|
|
||
|
e := &Config{
|
||
|
name: name,
|
||
|
namespace: namespace,
|
||
|
kubeClient: kubeClient,
|
||
|
lock: lock,
|
||
|
startWork: startWork,
|
||
|
stopWork: stopWork,
|
||
|
log: log,
|
||
|
}
|
||
|
|
||
|
e.leaderElectionCfg = leaderelection.LeaderElectionConfig{
|
||
|
Lock: e.lock,
|
||
|
ReleaseOnCancel: true,
|
||
|
LeaseDuration: 15 * time.Second,
|
||
|
RenewDeadline: 10 * time.Second,
|
||
|
RetryPeriod: 2 * time.Second,
|
||
|
Callbacks: leaderelection.LeaderCallbacks{
|
||
|
OnStartedLeading: func(ctx context.Context) {
|
||
|
atomic.StoreInt64(&e.isLeader, 1)
|
||
|
e.log.WithValues("id", e.lock.Identity()).Info("started leading")
|
||
|
|
||
|
if e.startWork != nil {
|
||
|
e.startWork()
|
||
|
}
|
||
|
},
|
||
|
|
||
|
OnStoppedLeading: func() {
|
||
|
atomic.StoreInt64(&e.isLeader, 0)
|
||
|
e.log.WithValues("id", e.lock.Identity()).Info("leadership lost, stopped leading")
|
||
|
if e.stopWork != nil {
|
||
|
e.stopWork()
|
||
|
}
|
||
|
},
|
||
|
|
||
|
OnNewLeader: func(identity string) {
|
||
|
if identity == e.lock.Identity() {
|
||
|
return
|
||
|
}
|
||
|
e.log.WithValues("current id", e.lock.Identity(), "leader", identity).Info("another instance has been elected as leader")
|
||
|
},
|
||
|
}}
|
||
|
|
||
|
e.leaderElector, err = leaderelection.NewLeaderElector(e.leaderElectionCfg)
|
||
|
if err != nil {
|
||
|
e.log.Error(err, "failed to create leaderElector")
|
||
|
os.Exit(1)
|
||
|
}
|
||
|
|
||
|
if e.leaderElectionCfg.WatchDog != nil {
|
||
|
e.leaderElectionCfg.WatchDog.SetLeaderElection(e.leaderElector)
|
||
|
}
|
||
|
|
||
|
return e, nil
|
||
|
}
|
||
|
|
||
|
func (e *Config) Name() string {
|
||
|
return e.name
|
||
|
}
|
||
|
|
||
|
func (e *Config) Namespace() string {
|
||
|
return e.namespace
|
||
|
}
|
||
|
|
||
|
func (e *Config) ID() string {
|
||
|
return e.lock.Identity()
|
||
|
}
|
||
|
|
||
|
func (e *Config) IsLeader() bool {
|
||
|
return atomic.LoadInt64(&e.isLeader) == 1
|
||
|
}
|
||
|
|
||
|
func (e *Config) GetLeader() string {
|
||
|
return e.leaderElector.GetLeader()
|
||
|
}
|
||
|
|
||
|
func (e *Config) Run(ctx context.Context) {
|
||
|
e.leaderElector.Run(ctx)
|
||
|
}
|